Mehdi OUAGHLANI
04/19/2022, 2:21 PMGrigoriy Sterin
04/19/2022, 2:25 PMdagster.core.errors.DagsterExecutionStepExecutionError: Error occurred while executing op...
.
And here goes the most interesting part: underlying ECS jobs keep running and Dagster job also keeps running forever (Dagit shows it's status as STARTED
), but nothing actually happens in this job, since it has already failed (but somehow Dagster doesn't know about it).
Has anyone seen something like this before?
Dagster version: 0.14.7
Alec Ryan
04/19/2022, 2:49 PMGrigoriy Sterin
04/19/2022, 3:38 PMMakas Tzavellas
04/19/2022, 4:30 PMChris Evans
04/19/2022, 5:02 PMdagster.check.CheckError: Invariant failed.
File "/Users/chrisevans/Repositories/data-platform/dags/bi/.venv/lib/python3.9/site-packages/dagster/core/execution/plan/utils.py", line 47, in solid_execution_error_boundary
yield
File "/Users/chrisevans/Repositories/data-platform/dags/bi/.venv/lib/python3.9/site-packages/dagster/core/execution/plan/inputs.py", line 607, in _load_input_with_input_manager
value = input_manager.load_input(context)
File "/Users/chrisevans/Repositories/data-platform/dags/bi/.venv/lib/python3.9/site-packages/dagster/core/storage/fs_io_manager.py", line 152, in load_input
context.add_input_metadata({"path": MetadataValue.path(os.path.abspath(filepath))})
File "/Users/chrisevans/Repositories/data-platform/dags/bi/.venv/lib/python3.9/site-packages/dagster/core/execution/context/input.py", line 325, in add_input_metadata
if self.asset_key:
File "/Users/chrisevans/Repositories/data-platform/dags/bi/.venv/lib/python3.9/site-packages/dagster/core/execution/context/input.py", line 216, in asset_key
check.invariant(len(matching_input_defs) == 1)
File "/Users/chrisevans/Repositories/data-platform/dags/bi/.venv/lib/python3.9/site-packages/dagster/check/__init__.py", line 1167, in invariant
raise CheckError("Invariant failed.")
Dan Mahoney
04/19/2022, 6:52 PMfrom dagster import repository
from openlineage.dagster.sensor import openlineage_sensor
from hello_cereal import hello_cereal_job
@repository
_def_ hello_cereal_repository():
openlineage_sensor_def = openlineage_sensor(
_minimum_interval_seconds_=60,
_record_filter_limit_=60,
)
return [hello_cereal_job, openlineage_sensor_def]
Thoughts?Huib Keemink
04/19/2022, 7:41 PMgeoHeil
04/19/2022, 7:54 PM
only displayed in the job view of dagit and not in the asset graph? Is this a bug? I would like to see these tags show up in both views.Ming Fang
04/20/2022, 1:01 AMload_assets_from_dbt_project.
Shouldn't dbt seeds be treated as dagster assets too?Josh Taylor
04/20/2022, 1:24 AMBryan Chavez
04/20/2022, 4:50 AMSara
04/20/2022, 7:13 AMgeoHeil
04/20/2022, 9:57 AMrequired_resource_keys
. As a result, pyspark must be instanciated first (and this costs some overhead). I s there any way (without making a 2nd copy of the multimodal IO manager without the pyspark resource to get rid of this delay? When trying to pass "pyspark": None,
dagster complains. So far, it looks for me like I need to specify a dummy resource instead. Is this the right way to go?geoHeil
04/20/2022, 10:29 AMEmanuele Domingo
04/20/2022, 11:02 AMAlec Ryan
04/20/2022, 11:49 AMgeoHeil
04/20/2022, 12:32 PMcontext.dagster_type.typing_type
is of type any
as the asset seems to be not directly consumed by a downstream asset.Dan Mahoney
04/20/2022, 3:17 PMSensor openlineage_sensor skipped: Last cursor: {"last_storage_id": 9, "running_pipelines": {"97e2efdf-9499-4ffd-8528-d7fea5b9362c": {"running_steps": {}, "repository_name": "hello_cereal_repository"}}}
and no OpenLineage event is generated.
I’m not sure if this is dagster itself or the plugin. I’ve attached my repos.py, hello_cereal.py, serial_job.py and workspace.yaml files.
Any thoughts??Simon
04/20/2022, 4:03 PMOut
does (https://docs.dagster.io/_apidocs/ops#dagster.Out) but that seems like I'd be hardcoding it to a fixed partition (I don't really understand the usecase for this tbh). Is there something else I need to do to link an Op to a partitioned Asset?Mark Fickett
04/20/2022, 4:46 PM@op
decorator to introduce some common setup code? I don't think a resource can do it since I want access to the op's context
(and a single-process executor wouldn't call it for each op). I tried making a wrapping decorator but I get errors from Dagster's inspection of the argument lists:
def my_op(*args, **kwargs):
"""Dagster @op that opens a custom context manager based on some shared state."""
def wrapper(func):
@op(*args, **kwargs)
def raw_op(context, *args, **kwrags): # my wrapper that does a little extra work
with my_custom_setup(context):
func(context, *args, **kwargs) # the original function that would normally be decorated with @op
return raw_op
return wrapper
jasono
04/20/2022, 5:38 PMAaron Bailey
04/20/2022, 7:03 PMAlec Ryan
04/20/2022, 7:15 PMDailyPartitionsDefinition
to load_assets_from_dbt_project
?Liezl Puzon
04/20/2022, 7:40 PMCharlie Bini
04/20/2022, 8:06 PMPermissive
that I can use in a config_schema
except the only allowable keys are defined but not mandatory?Bennett Norman
04/20/2022, 8:11 PMFrancis Addae
04/20/2022, 8:16 PM@job
def my_pipeline():
e = checkETL.check_sql_query()
#assert e == True
#run dbt Model
if __name__ == "__main__":
result = my_pipeline.execute_in_process()
# assert result.output_value ==True
Mark Fickett
04/20/2022, 8:18 PMstep_key
like my_subgraph.opname
, but docs say it's deprecated. What's the right thing to use for a similar value? And does context.solid_def.name
match that value? Including some notion of graph hierarchy in the key is useful.Liezl Puzon
04/20/2022, 10:00 PMsqlalchemy.exc.OperationalError: (psycopg2.OperationalError) could not translate host name "dagster-postgresql" to address: Name or service not known
Liezl Puzon
04/20/2022, 10:00 PMsqlalchemy.exc.OperationalError: (psycopg2.OperationalError) could not translate host name "dagster-postgresql" to address: Name or service not known
global:
postgresqlSecretName: "dagster-postgresql-secret"
daniel
04/21/2022, 1:40 AMLiezl Puzon
04/21/2022, 1:46 AMhelm upgrade --install dagster dagster/dagster --version 0.14.3 -f values/production.yaml
and seemed like it’s fine when I go back to postgres DB in clusterhelm upgrade --install dagster dagster/dagster --version 0.14.3 -f values/production.yaml
after I update the postgresql:
field to point to external?daniel
04/21/2022, 1:47 AMLiezl Puzon
04/21/2022, 1:48 AMdaniel
04/21/2022, 1:50 AMLiezl Puzon
04/21/2022, 1:51 AMscheduler:
module: dagster.core.scheduler
class: DagsterDaemonScheduler
schedule_storage:
module: dagster_postgres.schedule_storage
class: PostgresScheduleStorage
config:
postgres_db:
username: postgres
password:
env: DAGSTER_PG_PASSWORD
hostname: "X.X.X.X"
db_name: postgres
port: 5432
params:
dbname: postgres
password: postgres
port: 5432
user: postgres
run_launcher:
module: dagster_k8s
class: K8sRunLauncher
config:
load_incluster_config: true
job_namespace: dagster
image_pull_policy: Always
service_account_name: dagster
dagster_home:
env: DAGSTER_HOME
instance_config_map:
env: DAGSTER_K8S_INSTANCE_CONFIG_MAP
postgres_password_secret:
env: DAGSTER_K8S_PG_PASSWORD_SECRET
env_config_maps:
- env: DAGSTER_K8S_PIPELINE_RUN_ENV_CONFIGMAP
run_storage:
module: dagster_postgres.run_storage
class: PostgresRunStorage
config:
postgres_db:
username: postgres
password:
env: DAGSTER_PG_PASSWORD
hostname: "X.X.X.X"
db_name: postgres
port: 5432
params:
dbname: postgres
password: postgres
port: 5432
user: postgres
event_log_storage:
module: dagster_postgres.event_log
class: PostgresEventLogStorage
config:
postgres_db:
username: postgres
password:
env: DAGSTER_PG_PASSWORD
hostname: "X.X.X.X"
db_name: postgres
port: 5432
params:
dbname: postgres
password: postgres
port: 5432
user: postgres
compute_logs:
module: dagster.core.storage.noop_compute_log_manager
class: NoOpComputeLogManager
daniel
04/21/2022, 1:53 AMLiezl Puzon
04/21/2022, 1:53 AMdaniel
04/21/2022, 1:53 AMLiezl Puzon
04/21/2022, 1:53 AMhelm upgrading
and checking that nowdaniel
04/21/2022, 1:55 AMLiezl Puzon
04/21/2022, 1:55 AMdagster-dagit
and see if its updatingdaniel
04/21/2022, 1:57 AMLiezl Puzon
04/21/2022, 1:57 AMdaniel
04/21/2022, 1:58 AMLiezl Puzon
04/21/2022, 2:01 AMdaniel
04/21/2022, 2:03 AMLiezl Puzon
04/21/2022, 2:21 AMdaniel
04/21/2022, 2:23 AM