https://dagster.io/ logo
Title
d

Daniil

08/05/2021, 5:13 PM
Hi! I'm getting this error in dagit on pipeline view. pipeline overview tab doesn't show everything. i rolled my code back to state which is working fine on another machine but the error doesn't go away.
Operation name: PipelineOverviewQuery

Message: Event logs invalid for run id 17b38fc5-db54-4033-a53e-705f4fe19596

Path: ["pipelineSnapshotOrError","runs",0,"assets"]

Locations: [{"line":19,"column":9}]

Stack Trace:
  File "/usr/local/lib/python3.8/site-packages/graphql/execution/executor.py", line 452, in resolve_or_error
    return executor.execute(resolve_fn, source, info, **args)
  File "/usr/local/lib/python3.8/site-packages/graphql/execution/executors/sync.py", line 16, in execute
    return fn(*args, **kwargs)
  File "/usr/local/lib/python3.8/site-packages/dagster_graphql/schema/pipelines/pipeline.py", line 268, in resolve_assets
    return get_assets_for_run_id(graphene_info, self.run_id)
  File "/usr/local/lib/python3.8/site-packages/dagster_graphql/implementation/fetch_assets.py", line 62, in get_assets_for_run_id
    records = graphene_info.context.instance.all_logs(run_id)
  File "/usr/local/lib/python3.8/site-packages/dagster/core/instance/__init__.py", line 1000, in all_logs
    return self._event_storage.get_logs_for_run(run_id, of_type=of_type)
  File "/usr/local/lib/python3.8/site-packages/dagster/core/storage/event_log/sql_event_log.py", line 199, in get_logs_for_run
    events_by_id = self.get_logs_for_run_by_log_id(run_id, cursor, of_type)
  File "/usr/local/lib/python3.8/site-packages/dagster/core/storage/event_log/sql_event_log.py", line 178, in get_logs_for_run_by_log_id
    raise DagsterEventLogInvalidForRun(run_id=run_id) from err
If I try to run a pipeline i'm getting this in terminal:
dagster_dagit                | Exception in thread postgres-event-watch:
dagster_dagit                | Traceback (most recent call last):
dagster_dagit                |   File "/usr/local/lib/python3.8/threading.py", line 932, in _bootstrap_inner
dagster_dagit                |     self.run()
dagster_dagit                |   File "/usr/local/lib/python3.8/threading.py", line 870, in run
dagster_dagit                |     self._target(*self._args, **self._kwargs)
dagster_dagit                |   File "/usr/local/lib/python3.8/site-packages/dagster_postgres/event_log/event_log.py", line 260, in watcher_thread
dagster_dagit                |     dagster_event: EventRecord = deserialize_json_to_dagster_namedtuple(
dagster_dagit                |   File "/usr/local/lib/python3.8/site-packages/dagster/serdes/serdes.py", line 241, in deserialize_json_to_dagster_namedtuple
dagster_dagit                |     dagster_namedtuple = _deserialize_json_to_dagster_namedtuple(
dagster_dagit                |   File "/usr/local/lib/python3.8/site-packages/dagster/serdes/serdes.py", line 252, in _deserialize_json_to_dagster_namedtuple
dagster_dagit                |     return _unpack_value(seven.json.loads(json_str), whitelist_map=whitelist_map)
dagster_dagit                |   File "/usr/local/lib/python3.8/site-packages/dagster/serdes/serdes.py", line 276, in _unpack_value
dagster_dagit                |     check.invariant(
dagster_dagit                |   File "/usr/local/lib/python3.8/site-packages/dagster/check/__init__.py", line 167, in invariant
dagster_dagit                |     raise CheckError(f"Invariant failed. Description: {desc}")
dagster_dagit                | dagster.check.CheckError: Invariant failed. Description: Attempted to deserialize class "EventLogEntry" which is not in the whitelist.
can you please help, how do i fix this error?
a

alex

08/05/2021, 5:34 PM
Updating
dagit
should allow it to process these event logs that were written by a version that is ahead of it
d

Daniil

08/05/2021, 5:37 PM
thanks. will try that