lewis card
06/10/2021, 1:05 PMdocker rm $(docker ps -aq)
to remove all the stopped containers. Really you'd want the dagster daemon to be removing these itself, any chance this be implemented?Sarah Gruskin
06/10/2021, 9:49 PMArun Kumar
06/11/2021, 9:39 AMOutputContext
that I can pass to the get_asset_key() have the solids input information?Jack Whelan
06/11/2021, 10:03 AMCharles Lariviere
06/11/2021, 1:41 PMPipelineRun
objects from within a sensor? For context, I would like to get alerted when a pipeline has been in STARTING
/ STARTED
status for more than X hours since pipeline runs occasionally become zombies with our k8s deployment. I can get PipelineRun
objects from context.instance.get_runs()
but it’s not clear to me from looking at the class definition that status timestamps are available — should I instead look for the event stream from that PipelineRun
, if so, is that easily query-able? Thanks!Arun Kumar
06/11/2021, 9:13 PMrun_config_fn_for_partition
in addition to the partition config?Serge Smertin
06/13/2021, 5:48 PMchrispc
06/14/2021, 6:41 AMTraceback (most recent call last):
File "C:\Users\s4957336\Anaconda3\envs\borrar\lib\site-packages\dagster\core\execution\poll_compute_logs.py", line 61, in <module>
execute_polling(sys.argv[1:])
File "C:\Users\s4957336\Anaconda3\envs\borrar\lib\site-packages\dagster\core\execution\poll_compute_logs.py", line 53, in execute_polling
with open(ipc_output_file, "w"):
FileNotFoundError: [Errno 2] No such file or directory: 'C:\\Users\\s4957336\\AppData\\Local\\Temp\\1\\tmpo_zr47w6\\execute-windows-tail-15bc135d998546caa23116bbff00ceb1'
2021-06-14 02:33:51 - dagster - ERROR - Mexico_CTMS_Corp - a1cb3fdf-19ef-4676-a6b0-b3c7610ec0f9 - 22036 - PIPELINE_FAILURE - Execution of pipeline "Mexico_CTMS_Corp" failed. An exception was thrown during execution.
Exception: Timed out waiting for tail process to start
Stack Trace:
File "C:\Users\s4957336\Anaconda3\envs\borrar\lib\site-packages\dagster\core\execution\api.py", line 762, in pipeline_execution_iterator
for event in pipeline_context.executor.execute(pipeline_context, execution_plan):
File "C:\Users\s4957336\Anaconda3\envs\borrar\lib\site-packages\dagster\core\executor\in_process.py", line 38, in execute
yield from iter(
File "C:\Users\s4957336\Anaconda3\envs\borrar\lib\site-packages\dagster\core\execution\api.py", line 841, in __iter__
yield from self.iterator(
File "C:\Users\s4957336\Anaconda3\envs\borrar\lib\site-packages\dagster\core\execution\plan\execute_plan.py", line 72, in inner_plan_execution_iterator
active_execution.verify_complete(pipeline_context, step.key)
File "C:\Users\s4957336\Anaconda3\envs\borrar\lib\contextlib.py", line 120, in __exit__
next(self.gen)
File "C:\Users\s4957336\Anaconda3\envs\borrar\lib\site-packages\dagster\core\storage\compute_log_manager.py", line 56, in watch
yield
File "C:\Users\s4957336\Anaconda3\envs\borrar\lib\contextlib.py", line 120, in __exit__
next(self.gen)
File "C:\Users\s4957336\Anaconda3\envs\borrar\lib\site-packages\dagster\core\storage\local_compute_log_manager.py", line 51, in _watch_logs
yield
File "C:\Users\s4957336\Anaconda3\envs\borrar\lib\contextlib.py", line 120, in __exit__
next(self.gen)
File "C:\Users\s4957336\Anaconda3\envs\borrar\lib\site-packages\dagster\core\execution\compute_logs.py", line 31, in mirror_stream_to_file
yield pids
File "C:\Users\s4957336\Anaconda3\envs\borrar\lib\contextlib.py", line 120, in __exit__
next(self.gen)
File "C:\Users\s4957336\Anaconda3\envs\borrar\lib\site-packages\dagster\core\execution\compute_logs.py", line 75, in tail_to_stream
yield pids
File "C:\Users\s4957336\Anaconda3\envs\borrar\lib\contextlib.py", line 120, in __exit__
next(self.gen)
File "C:\Users\s4957336\Anaconda3\envs\borrar\lib\site-packages\dagster\core\execution\compute_logs.py", line 104, in execute_windows_tail
raise Exception("Timed out waiting for tail process to start")
I am not sure why dagster is looking into this path FileNotFoundError: [Errno 2] No such file or directory: 'C:\\Users\\s4957336\\AppData\\Local\\Temp\\1\\tmpo_zr47w6\\execute-windows-tail-15bc135d998546caa23116bbff00ceb1'
if I configured the dagster.yaml in this way:
scheduler:
module: dagster.core.scheduler
class: DagsterDaemonScheduler
run_launcher:
module: dagster.core.launcher
class: DefaultRunLauncher
run_coordinator:
module: dagster.core.run_coordinator
class: QueuedRunCoordinator
config:
max_concurrent_runs: 25
run_storage:
module: dagster_postgres.run_storage
class: PostgresRunStorage
config:
postgres_url: "<postgresql://user:pwd@hostname>:port/dagster"
local_artifact_storage:
module: dagster.core.storage.root
class: LocalArtifactStorage
config:
base_dir: C:\Users\s4957336\Documents\caps\local_artifact_storage
compute_logs:
module: dagster.core.storage.local_compute_log_manager
class: LocalComputeLogManager
config:
base_dir: C:\Users\username\Documents\caps\logs
The folder logs is storing the compute logsJack Whelan
06/14/2021, 12:01 PMMarco
06/14/2021, 4:23 PMArun Kumar
06/14/2021, 7:52 PMannotations
to all the pipeline jobs. Is there any way to specify this in the helm for all the jobs, or should I add them to all the pipeline definitions dagster-k8s/config
?Oskar
06/15/2021, 2:39 AM--db-statement-timeout
but it did not help. I'm running v0.11.12. Any ideas?VxD
06/15/2021, 5:50 AMYan
06/15/2021, 11:32 AMKieron Ellis
06/15/2021, 3:04 PMDaniel Carleton
06/15/2021, 4:31 PMEmily
06/15/2021, 4:48 PMuse_https
flag (thanks again!) but we are now running into this error while trying to launch a pipeline execution. we could see the failed run in the UI, so it did try to execute, but this error does not occur when trying to launch within the UI itself. im not really sure where this is coming from. (code run in thread)
---------------------------------------------------------------------------
DagsterGraphQLClientError Traceback (most recent call last)
<ipython-input-13-0164b5809f7d> in <module>
2 "tatari_pipeline",
3 run_config=dct,
----> 4 mode="local",
5 )
/usr/local/lib/python3.7/site-packages/dagster_graphql/client/client.py in submit_pipeline_execution(self, pipeline_name, repository_location_name, repository_name, run_config, mode, preset, tags)
230 # query_result_type is a ConflictingExecutionParamsError, a PresetNotFoundError
231 # a PipelineNotFoundError, a PipelineRunConflict, or a PythonError
--> 232 raise DagsterGraphQLClientError(query_result_type, query_result["message"])
233
234 def get_run_status(self, run_id: str) -> PipelineRunStatus:
DagsterGraphQLClientError: ('PythonError', 'sqlalchemy.exc.OperationalError: (psycopg2.OperationalError) SSL connection has been closed unexpectedly\n\n[SQL: INSERT INTO event_logs (run_id, event, dagster_event_type, timestamp, step_key, asset_key, partition) VALUES (%(run_id)s, %(event)s, %(dagster_event_type)s, %(timestamp)s, NULL, NULL, NULL) RETURNING event_logs.run_id, event_logs.id]\n[parameters: {\'run_id\': \'5c42b0e4-7366-4bc4-8d70-cce9a81269ee\', \'event\': \'{"__class__": "EventRecord", "dagster_event": {"__class__": "DagsterEvent", "event_specific_data": null, "event_type_value": "PIPELINE_ENQUEUED", "lo ... (225 characters truncated) ... ne_name": "tatari_pipeline", "run_id": "5c42b0e4-7366-4bc4-8d70-cce9a81269ee", "step_key": null, "timestamp": 1623773911.8121505, "user_message": ""}\', \'dagster_event_type\': \'PIPELINE_ENQUEUED\', \'timestamp\': datetime.datetime(2021, 6, 15, 16, 18, 31, 812150)}]\n(Background on this error at: <http://sqlalche.me/e/14/e3q8>)\n')
Daniel Carleton
06/15/2021, 5:07 PMRetryRequested
for solid retries, but can't find anything for timeouts.Scott Peters
06/15/2021, 9:27 PMworkspace.yaml
, dagit
only shows 1 pipeline:Scott Peters
06/15/2021, 9:28 PMfrom dagster import pipeline, solid
@solid
def get_name():
return 'dagster'
@solid
def hello(context, name: str):
<http://context.log.info|context.log.info>(f"Hello, {name}!")
@pipeline
def hello_pipeline():
hello(get_name())
Scott Peters
06/15/2021, 9:29 PMimport requests
import csv
from dagster import pipeline, solid
@solid
def hello_cereal(context):
repsonse = requests.get("<https://docs.dagster.io/assets/cereal.csv>")
lines = repsonse.text.split("\n")
cereals = [row for row in csv.DictReader(lines)]
<http://context.log.info|context.log.info>(f"Found {len(cereals)} cereals")
return cereals
@pipeline
def hello_cereal_pipeline():
hello_cereal()
Scott Peters
06/15/2021, 9:29 PMload_from:
- python_file: hello_cereal.py
load_from:
- python_file: hello_world.py
Scott Peters
06/15/2021, 9:29 PMScott Peters
06/15/2021, 9:30 PMScott Peters
06/15/2021, 9:55 PMScott Peters
06/16/2021, 12:07 AMpython api
to execute pipelines, how do I send them to the current instance of dagit
?Scott Peters
06/16/2021, 12:07 AMpython api
, it is running on an ephemeral instance instead of my locally hosted instance 127.0.0.2:3000
Scott Peters
06/16/2021, 12:11 AMfrom dagster import execute_pipeline
import sys
sys.path.append('.')
from hello_cereal import hello_cereal_pipeline
if __name__ == '__main__':
execute_pipeline(hello_cereal_pipeline)
Scott Peters
06/16/2021, 12:33 AM