[ui] Step compute logs are shown under “Last Materialization” in the asset sidebar.
[ui] Truncated asset names now show a tooltip when hovered in the asset graph.
[ui] The “Propagate changes” button has been removed and replaced with “Materialize Stale and Missing” (which was the “Propagate changes” predecessor).
[ui] Fixed an issue that prevented filtering by date on the job-specific runs tab.
[ui] “F” key with modifiers (alt, ctrl, cmd, shift) no longer toggles the filter menu on pages that support filtering.
[ui] Fix empty states on Runs table view for individual jobs, to provide links to materialize an asset or launch a run for the specific job, instead of linking to global pages.
[ui] When a run is launched from the Launchpad editor while an editor hint popover is open, the popover remained on the page even after navigation. This has been fixed.
[ui] Fixed an issue where clicking on the zoom controls on a DAG view would close the right detail panel for selected nodes.
[ui] Fixed an issue shift-selecting assets with multi-component asset keys.
[ui] Fixed an issue with the truncation of the asset stale causes popover.
When using a TimeWindowPartitionMapping with a start_offset or end_offset specified, requesting the downstream partitions of a given upstream partition would yield incorrect results. This has been fixed.
When using AutoMaterializePolicys with observable source assets, in rare cases, a second run could be launched in response to the same version being observed twice. This has been fixed.
When passing in hook_defs to define_asset_job, if any of those hooks had required resource keys, a missing resource error would surface when the hook was executed. This has been fixed.
Fixed a typo in a documentation URL in dagster-duckdb-polars tests. The URL now works correctly.
[dagster-dbt] Added methods to DbtManifest to fetch asset keys of sources and models: DbtManifest.get_asset_key_for_model, DbtManifest.get_asset_key_for_source. These methods are utilities for defining python assets as dependencies of dbt assets via @asset(key=manifest.get_asset_key_for_model(...).
[dagster-dbt] The use of the state_path parameter with DbtManifestAssetSelection has been deprecated, and will be removed in the next minor release.
Added experimental support for limiting global op/asset concurrency across runs.
Assets with lazy auto-materialize policies are no longer auto-materialized if they are missing but don’t need to be materialized in order to help downstream assets meet their freshness policies.
[ui] The descriptions of auto-materialize policies in the UI now include their skip conditions along with their materialization conditions.
[dagster-dbt] Customized asset keys can now be specified for nodes in the dbt project, using meta.dagster.asset_key. This field takes in a list of strings that are used as the components of the generated AssetKey.
[dagster-dbt] Customized groups can now be specified for models in the dbt project, using meta.dagster.group. This field takes in a string that is used as the Dagster group for the generated software-defined asset corresponding to the dbt model.
Fixed an issue where the dagster-msteams and dagster-mlflow packages could be installed with incompatible versions of the dagster package due to a missing pin.
Fixed an issue where the dagster-daemon run command sometimes kept code server subprocesses open longer than it needed to, making the process use more memory.
Previously, when using @observable_source_assets with AutoMaterializePolicies, it was possible for downstream assets to get “stuck”, not getting materialized when other upstream assets changed, or for multiple down materializations to be kicked off in response to the same version being observed multiple times. This has been fixed.
Fixed a case where the materialization count for partitioned assets could be wrong.
Fixed an error which arose when trying to request resources within run failure sensors.
[dagster-wandb] Fixed handling for multi-dimensional partitions. Thanks @chrishiste
[dagster-dbt] By default, freshness policies and auto materialize policies on dbt assets can now be specified using the dagster field under +meta configuration. The following are equivalent:
Added AssetExecutionContext to replace OpExecutionContext as the context object passed in to @asset functions.
TimeWindowPartitionMapping now contains an allow_nonexistent_upstream_partitions argument that, when set to True, allows a downstream partition subset to have nonexistent upstream parents.
Unpinned the alembic dependency in the dagster package.
[ui] A new “Assets” tab is available from the Overview page.
[ui] The Backfills table now includes links to the assets that were targeted by the backfill.
Dagster is now compatible with a breaking change introduced in croniter==1.4.0. Users of earlier versions of Dagster can pin croniter<1.4.
Fixed an issue introduced in 1.3.8 which prevented resources from being bound to sensors when the specified job required late-bound resources.
Fixed an issue which prevented specifying resource requirements on a @run_failure_sensor.
Fixed an issue where the asset reconciliation sensor failed with a “invalid upstream partitions” error when evaluating time partitions definitions with different start times.
[dagster-k8s] Fixed an issue where annotations are not included in the Dagster Helm chart for the pod that is created when configuring the Helm chart to run database migrations.
[ui] Fixed an issue with filtering runs by created date on the Runs page.
[ui] The “upstream partitions missing” warning no longer appears in the asset backfill dialog if the upstream partitioned asset is a source asset.
[dagster-dbt] Fixed an issue where asset dependencies for dbt models with ephemeral models in between them would sometimes be improperly rendered.
Evaluation history for AutoMaterializePolicys will now be cleared after 1 week.
[dagster-dbt] Several improvements to @dbt_assets:
profile and target can now be customized on the DbtCli resource.
If a partial_parse.msgpack is detected in the target directory of your dbt project, it is now copied into the target directories created by DbtCli to take advantage of partial parsing.
The metadata of assets generated by @dbt_assets can now be customized by overriding DbtManifest.node_info_to_metadata.
Execution duration of dbt models is now added as default metadata to AssetMaterializations.
Fixed an issue where overriding the container name of a code server pod using serverK8sConfig.containerConfig.name did not actually change the container name.
Multipartitioned assets with one time dimension can now depend on earlier partitions of themselves.
define_asset_job now accepts a hooks argument.
Added support for sqlalchemy==2.x
[ui] The Runs page has been revamped with better filtering support
[ui] The automaterialize policy page for SDA’s using the experimental AutomaterializePolicy feature now indicates time periods where no materializations happened due to no materialization conditions being met
[dagster-k8s] The Dagster Helm chart now includes an additionalInstanceConfig key that allows you to supply additional configuration to the Dagster instance.
[dagster-aws] The EcsRunLauncher now uses a different task definition family for each job, instead of registering a new task definition revision each time a different job is launched.
[dagster-aws] The EcsRunLauncher now includes a run_ecs_tags config key that lets you configure tags on the launched ECS task for each run.
When a sensor had yield statement and also returned a SkipReason, the SkipReason would be ignored. This has been fixed.
[dagster-cloud] Fixed a bug in the docker user code launcher that was preventing code location containers from being properly cleaned up.
Fixed an issue where the Dagster UI would sometimes raise a `RuntimeError: dictionary changed size during iteration exception while code servers were being reloaded.
Fixed an issue where the Dagster daemon reloaded your code server every 60 seconds when using the new experimental dagster code-server start CLI, instead of only reloading your code when you initiate a reload from the Dagster UI.
Fixed a GraphQL error which would occur when loading the default config for jobs without config.
[dagster-dbt] Fixed an error which would arise when trying to load assets from a DBT Cloud instance using the Pythonic-style resource.
@observable_source_asset-decorated functions can now return a DataVersionsByPartition to record versions for partitions.
@dbt_assets
DbtCliTask's created by invoking DbtCli.cli(...) now have a method .is_successful(), which returns a boolean representing whether the underlying CLI process executed the dbt command successfully.
Descriptions of assets generated by @dbt_assets can now be customized by overriding DbtManifest.node_info_to_description.
Added support for streaming upload of compute logs to Dagster Cloud
The ECS agent now supports setting server_ecs_tags and run_ecs_tags that apply to each service or task created by the agent. See the docs for more information.
Fixed run filtering for calls to instance.get_run_partition_data in Dagster Cloud.