includeConfigInLaunchedRuns
flag to the Helm chart that can be used to automatically include configmaps, secrets, and volumes in any runs launched from code in a user code deployment. See https://docs.dagster.io/deployment/guides/kubernetes/deploying-with-helm#configure-your-user-deployment for more information.BackfillParams
(used for launching backfills), now has an allPartitions
boolean flag, which can be used instead of specifying all the individual partition names.gevent
and gevent-websocket
dependencies from dagster-graphql
Fixed sqlite3.OperationalError
error when viewing schedules/sensors pages in Dagit. This was affecting dagit instances using the default SQLite schedule storage with a SQLite version < 3.25.0
.
Fixed an issues where schedules and sensors would sometimes fail to run when the daemon and dagit were running in different Python environments.
Fixed an exception when the telemetry file is empty
fixed a bug with @graph
composition which would cause the wrong input definition to be used for type checks
[dagit] For users running Dagit with --path-prefix
, large DAGs failed to render due to a WebWorker error, and the user would see an endless spinner instead. This has been fixed.
[dagit] Fixed a rendering bug in partition set selector dropdown on Launchpad.
[dagit] Fixed the ‘View Assets’ link in Job headers
Fixed an issue where root input managers with resource dependencies would not work with software defined assets
dagster-census
is a new library that includes a census_resource
for interacting the Census REST API, census_trigger_sync_op
for triggering a sync and registering an asset once it has finished, and a CensusOutput
type. Thanks @dehume!dagster.yaml
that can be used to increase the time that Dagster waits when spinning up a gRPC server before timing out. For more information, see https://docs.dagster.io/deployment/dagster-instance#code-servers.assetMaterializations
that can be queried off of a DagsterRun
field. You can use this field to fetch the set of asset materialization events generated in a given run within a GraphQL query.@resource
decorator will now be used as resource descriptions, if no description is explicitly provided.dagit -m
or dagit -f
at a module or file that has asset definitions but no jobs or asset groups, and all the asset definitions will be loaded into Dagit.AssetGroup
now has a materialize
method which executes an in-process run to materialize all the assets in the group.AssetGroup
s can now contain assets with different partition_defs
.fs_asset_io_manager
, now include the path of the file where the values were saved.max_concurrent_runs
limit on the QueuedRunCoordinator
by setting it to -1
. Use this if you only want to limit runs using tag_concurrency_limits
.get_runs()
function to get a list of runs matching certain parameters from the dbt Cloud API (thanks @kstennettlull!)authenticator
field to the connection arguments for the snowflake_resource
(thanks @swotai!).container_kwargs
that allows you to specify additional arguments to pass to your docker containers when they are run.:
character would fail to parse correctly, and filtering would therefore fail. This has been fixed.run_id
can now be provided as an argument to execute_in_process
.dagit
’s empty state no longer mentions the legacy concept “Pipelines”.IOManager.load_input
method, you can add input metadata via InputContext.add_input_metadata
. These metadata entries will appear on the LOADED_INPUT
event and if the input is an asset, be attached to an AssetObservation
. This metadata is viewable in dagit
.dagit
and dagster-daemon
processes. This would manifest in schedules / sensors getting marked as “Unloadable” in dagit
, and ticks not being registered correctly. The fix involves changing how Dagster stores schedule/sensor state and requires a schema change using the CLI command dagster instance migrate
. Users who are not running into this class of bugs may consider the migration optional.root_input_manager
can now be specified without a context argument.root_input_manager
from being used with VersionStrategy
.dagit
writing to the same telemetry logs.dagit
, using the “Open in Launchpad” feature for a run could cause server errors if the run configuration yaml was too long. Runs can now be opened from this feature regardless of config length.dagit
, runs in the timeline view sometimes showed incorrect end times, especially batches that included in-progress runs. This has been fixed.dagit
launchpad, reloading a repository should present the user with an option to refresh config that may have become stale. This feature was broken for jobs without partition sets, and has now been fixed.typing
type as dagster_type
to input and output definition was incorrectly being rejected.