Arturs Stramkals
12/14/2021, 9:03 PMA/B
and 1/2/3
, and I want to access downstream from 3
a metadata property defined in DynamicOutput
of A
?Mathew Lee
12/14/2021, 9:17 PMManny Schneck
12/15/2021, 3:52 AMManny Schneck
12/15/2021, 4:01 AMDefaultRunLauncher
. If I figure something out that speeds up local job tests I'll share.Josh Taylor
12/15/2021, 4:06 AMArun Kumar
12/15/2021, 11:52 AMdagster-snowflake
resource.
Any thoughts on why this could happen?
An exception was thrown during execution that is likely a framework error, rather than an error in user code.
dagster.check.CheckError: Invariant failed. Description: Pipeline run analyses_exposures_loader (b15f4f49-05ae-45ad-ab00-60bf07c9797f) in state PipelineRunStatus.FAILURE, expected NOT_STARTED or STARTING
Stack Trace:
File "/usr/local/lib/python3.7/site-packages/dagster/grpc/impl.py", line 86, in core_execute_run
yield from execute_run_iterator(recon_pipeline, pipeline_run, instance)
, File "/usr/local/lib/python3.7/site-packages/dagster/core/execution/api.py", line 77, in execute_run_iterator
pipeline_run.pipeline_name, pipeline_run.run_id, pipeline_run.status
, File "/usr/local/lib/python3.7/site-packages/dagster/check/__init__.py", line 170, in invariant
raise CheckError(f"Invariant failed. Description: {desc}")
Mathew Lee
12/15/2021, 2:49 PMMykola Palamarchuk
12/15/2021, 7:10 PMRodrigo Parra
12/15/2021, 7:32 PMwon
12/15/2021, 8:12 PMThomas Mignon
12/15/2021, 8:25 PMsample_dataset = configured(get_dataset, name="sample_dataset")({"is_sample": True})
To something like that
sample_dataset = configured(get_dataset, name="sample_dataset")(context["is_sample"])
Nick Dellosa
12/15/2021, 9:55 PMNitin Madhavan
12/16/2021, 7:21 AMPartha
12/16/2021, 8:32 AMyield RunRequest(run_key=s3_key, run_config = {"ops": {"op_trigger_lambda": {"config": {"s3_key": s3_key}}}})
We have planned to deploy this in AWS ECS (as mentioned in the "deploy_ecs" example, which uses EcsRunLauncher).
My Question - Does each Run Request will be invoked in parallel or in serial, because in docs it mentioned as queue? If it is not parallel, then how can this be converted to parallel ? Could you please help me here ?Tadas Barzdžius
12/16/2021, 11:44 AMrunLauncher:
type: CeleryK8sRunLauncher
config:
CeleryK8sRunLauncher:
workerQueues:
- name: "dagster"
replicaCount: 5
- name: "database"
replicaCount: 50
But still only one deployment is created celery workkers. What am I doing incorrectly?Mohammad Nazeeruddin
12/16/2021, 1:30 PMCharles Lariviere
12/16/2021, 2:55 PMconfig_schema
(and not Ins
)? Since we can configure Op inputs in run configuration, I was expecting to also be able to do that with the Configured API, but I’m getting errors that make me think it isn’t the case.Diana Stan
12/16/2021, 5:49 PMSebastian Napiorkowski
12/16/2021, 6:13 PMScott Hood
12/16/2021, 6:29 PMJeremy Fisher
12/16/2021, 6:48 PMThomas Mignon
12/16/2021, 7:08 PMconfigured()(callback)
a configuration that i can write in the dagit interface as follow :
ops:
my_op:
config:
callback: 0
So my question is : what i need to write in the callback of configured, in order to have access to context.op_config['callback']
?Thomas Mignon
12/16/2021, 7:12 PMThomas Mignon
12/16/2021, 8:02 PMHenry Qin
12/16/2021, 8:17 PMK8JobExecutor
?Bryan Chavez
12/16/2021, 9:07 PM@run_status_sensor(pipeline_run_status=PipelineRunStatus.SUCCESS)
def ingest_asset_materialization(context: RunStatusSensorContext):
job_name = context.pipeline_run.pipeline_name
metadata = {
"run_id": context.pipeline_run.run_id,
"pipeline_name": job_name,
}
yield AssetMaterialization(
asset_key=job_name,
description="Job successfully finished",
metadata=metadata,
)
David Farnan-Williams
12/16/2021, 10:15 PMdchau
12/16/2021, 10:19 PMThomas Mignon
12/17/2021, 8:56 AMThomas Mignon
12/17/2021, 8:56 AM