Hi, weird behaviour. Failed op, but job continued....
# ask-community
d
Hi, weird behaviour. Failed op, but job continued. Error message in that op:
Copy code
dagster_graphql.client.utils.DagsterGraphQLClientError: Exception occured during execution of query

query($runId: ID!) {
runOrError(runId: $runId) {
__typename
... on Run {
pipelineName
status
executionPlan {
steps {
key
kind
inputs {
dependsOn {
key
}
}
}
}
stepStats {
stepKey
status
}
stats {
... on RunStatsSnapshot {
stepsSucceeded
stepsFailed
}
}
}
... on PipelineRunNotFoundError {
message
}
... on PythonError {
message
}
}
}

with variables
{'runId': '1f108c08-904b-4bc2-98a7-6bdac6cd1fc0'}

  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/dagster/_core/execution/plan/execute_plan.py", line 265, in dagster_event_sequence_for_step
    for step_event in check.generator(step_events):
  File "/opt/dagster/dagster_home/cashback_spark/resources/databricks_pyspark_step_launcher_sp.py", line 312, in launch_step
    if self.graph_ql_client and self._is_pipeline_finished(run_id):
  File "/opt/dagster/dagster_home/cashback_spark/resources/databricks_pyspark_step_launcher_sp.py", line 576, in _is_pipeline_finished
    run_status = self.graph_ql_client.get_pipeline_op_status(run_id)
  File "/opt/dagster/dagster_home/cashback_spark/resources/dagster_graphql_client.py", line 134, in get_pipeline_op_status
    res_data: Dict[str, Dict[str, Any]] = self._execute(
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/dagster_graphql/client/client.py", line 100, in _execute
    raise DagsterGraphQLClientError(
The above exception was caused by the following exception:
requests.exceptions.ChunkedEncodingError: ("Connection broken: ConnectionResetError(104, 'Connection reset by peer')", ConnectionResetError(104, 'Connection reset by peer'))
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/dagster_graphql/client/client.py", line 98, in _execute
    return self._client.execute(gql(query), variable_values=variables)
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/gql/client.py", line 403, in execute
    return self.execute_sync(
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/gql/client.py", line 220, in execute_sync
    with self as session:
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/gql/client.py", line 702, in __enter__
    return self.connect_sync()
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/gql/client.py", line 686, in connect_sync
    self.session.fetch_schema()
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/gql/client.py", line 881, in fetch_schema
    execution_result = self.transport.execute(parse(get_introspection_query()))
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/gql/transport/requests.py", line 220, in execute
    response = self.session.request(
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/requests/sessions.py", line 587, in request
    resp = self.send(prep, **send_kwargs)
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/requests/sessions.py", line 745, in send
    r.content
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/requests/models.py", line 899, in content
    self._content = b"".join(self.iter_content(CONTENT_CHUNK_SIZE)) or b""
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/requests/models.py", line 818, in generate
    raise ChunkedEncodingError(e)
The above exception occurred during handling of the following exception:
urllib3.exceptions.ProtocolError: ("Connection broken: ConnectionResetError(104, 'Connection reset by peer')", ConnectionResetError(104, 'Connection reset by peer'))
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/requests/models.py", line 816, in generate
    yield from self.raw.stream(chunk_size, decode_content=True)
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/urllib3/response.py", line 628, in stream
    data = self.read(amt=amt, decode_content=decode_content)
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/urllib3/response.py", line 566, in read
    with self._error_catcher():
  File "/opt/conda/envs/dagster_env/lib/python3.10/contextlib.py", line 153, in __exit__
    self.gen.throw(typ, value, traceback)
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/urllib3/response.py", line 461, in _error_catcher
    raise ProtocolError("Connection broken: %r" % e, e)
The above exception occurred during handling of the following exception:
ConnectionResetError: [Errno 104] Connection reset by peer
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/urllib3/response.py", line 444, in _error_catcher
    yield
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/urllib3/response.py", line 567, in read
    data = self._fp_read(amt) if not fp_closed else b""
  File "/opt/conda/envs/dagster_env/lib/python3.10/site-packages/urllib3/response.py", line 533, in _fp_read
    return self._fp.read(amt) if amt is not None else self._fp.read()
  File "/opt/conda/envs/dagster_env/lib/python3.10/http/client.py", line 465, in read
    s = self.fp.read(amt)
  File "/opt/conda/envs/dagster_env/lib/python3.10/socket.py", line 705, in readinto
    return self._sock.recv_into(b)
t
Hi! Did the actual computation in that op work as intended? And has this happened more than once?