Xu Zhang
08/01/2021, 12:19 AMJonathan Mak
08/01/2021, 4:05 AMexecute(_shell_command_ = cmd, _output_logging_ = 'STREAM', _log_ = context.log, _cwd_ = '/my/dir/path')
with dagster-shell but the temporary script directory was still set somewhere else, am I doing anything wrong there?paul.q
08/02/2021, 1:26 AMcron_schedule="0 3 * * *"
in our schedule, the weekend runs were previously inhibited, I presume due to the run_key having already been used? We can (and should), of course, change the cron_schedule to add MON-FRI, but did we just fluke the desired behaviour before 0.12.x?Adrian Lisko
08/02/2021, 9:35 AM<ip>/some-path
. I understand that this works in traefik by using stripPrefix, which uses X-Forwarded-Prefix header. Any idea what I have to change in dagit to make it work? Otherwise I get blank page, because the ui fetches the web assets from default path /
Francois-DE
08/02/2021, 12:36 PMsean
08/02/2021, 4:53 PM@solid
decorator is not being understood. Is this a known issue, or is there somewhere that explains how to properly configure PyRight to handle Dagster? Thanks.
(Note that goto-definition and other language server functionality is properly working, the dagster library is on PyRight's search path)
(Note also that Pyright seems to think solid
is a module rather than a function, that probably has something to do with it).sean
08/02/2021, 4:55 PMRohan Ahire
08/02/2021, 6:11 PMChris Chan
08/02/2021, 9:46 PMXu Zhang
08/03/2021, 5:22 AMSandeep Aggarwal
08/03/2021, 12:25 PM@graph
experimental API, that seems to try unifying the concept of solids, pipelines and composition, but I am not able to figure out how to use it for graph/pipeline composition.Tadas Barzdžius
08/04/2021, 11:17 AMAlejandro DE LA CRUZ LOPEZ
08/04/2021, 12:45 PMNoah Sanor
08/04/2021, 4:05 PMResourceDefinition.mock_resource
in tests? I'd like to be able to assert that methods are called on the resource if possible.madhurt
08/04/2021, 6:36 PMmadhurt
08/04/2021, 7:27 PMAkshat Nigam
08/04/2021, 8:27 PMworkspace.yaml
for python_package:
or python_file:
DBT needs it for its SQL Models.
Now, as far as, Dagster is running in in_process_executor
mode, they (Dagster & DBT Solids) can easily access the EFS, as:
1. We have mounted EFS to main Dagster Deployment.
2. All solids will be executed in same Dagster Deployment as a system process, which will also has the access to EFS.
But the question comes, when Dagster will be running in celery_k8s_job_executor
mode, where each solid is executed in a separate ephemeral kubernetes pod.
_*InBecause, the EFS PV/PVC changes are done for main dagster deployment. I am not that much expert in k8s, but is it possible, if those ephemeral kubernetes pod uses the same main helm chart image as base image, which already has a mount with EFS, the DBTs will have access to EFS as well? It will be really great if someone can give some feedback on this. Thanks.mode, will DBT solids which will get executed in a separate ephemeral k8s pods, have access to the EFS?*_celery_k8s_job_executor
Chris Evans
08/04/2021, 11:27 PMpsycopg2-binary<2.9
. psycopg2-binary==2.9.1
has smoothed the installation for M1 macs.Abednego Santoso
08/05/2021, 5:01 AMupdate_cohort_source = dbt_rpc_run_and_wait.configured(
{"models": ["tag:cohort"]},
name="update_cohort_source",
)
Basically, I wanna add RetryPolicy to this solid, but I have no idea how to add that to this kind of solid. Any suggestion?George Pearse
08/05/2021, 1:43 PMChris Evans
08/05/2021, 5:01 PMRunning dagit...
Traceback (most recent call last):
File "/opt/homebrew/bin/dagit", line 5, in <module>
from dagit.cli import main
File "/opt/homebrew/lib/python3.9/site-packages/dagit/__init__.py", line 1, in <module>
from dagster.core.utils import check_dagster_package_version
ModuleNotFoundError: No module named 'dagster.core'
Running dagit...
Traceback (most recent call last):
File "/opt/homebrew/bin/dagster", line 5, in <module>
from dagster.cli import main
ModuleNotFoundError: No module named 'dagster.cli'
Daniil
08/05/2021, 5:13 PMOperation 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?Lesliefenwick
08/05/2021, 8:01 PMasset_key
downstream?
Basically, I am pulling in a local file utilizing the yield AssetMaterialization
@solid()
def solid__get_file(context):
file = os.path.abspath(f"some_file.csv")
yield AssetMaterialization(
asset_key="file",
metadata={
"file": EventMetadata.path(
file
)
}
)
yield Output(None)
How do I pass this into a solid downstream?William Reed
08/05/2021, 11:08 PMcurl -X POST <http://localhost:15020/quitquitquit>
to the end of the jobs’ commands and it will shutdown the sidecars. How can I do that with the Helm chart though? Thank you.takan
08/06/2021, 4:36 AMworkspace.yaml
is the only way? For example in Airflow, there is gitsync or volume mount to manage many dags but I wonder how I should go about managing many pipelines and repositories on dagster. Thanks 🙂Will Skelton
08/06/2021, 1:21 PMYahel Carmon
08/06/2021, 3:01 PMXu Zhang
08/06/2021, 3:57 PMmadhurt
08/06/2021, 5:52 PMNothing
i.e. the handle_output()
of the IOManager will always have obj
as None
. Thus, the dependencies are specified using input_defs=[InputDefinition("name_of_previous_solid", Nothing)]
for the next solid. I still want the logic of load_input
of my custom IOManager to work before we start executing this next solid. But it seems it skips it altogether. Any suggestions on what can be done?Chris Le Sueur
08/06/2021, 6:17 PM