report_asset_observation
REST API endpoint for runless external asset observation eventsDAGSTER_K8S_PG_PASSWORD_SECRET
and DAGSTER_K8S_INSTANCE_CONFIG_MAP
will no longer be set in all pods.build_pyspark_zip
now takes an exclude
parameter that can be used to customize the set of excluded files.source_key_prefix
argument to load_assets_from_current_module
and load_assets_from_package_name
was ignoreddagster_embedded_elt
where the mode parameter was not being passed to Sling, and only one asset could be created at a timepipelineRun
configuration in the Helm chart is now deprecated. The same config can be set under dagster-user-deployments
setup_for_execution
and teardown_after_execution
calls to the inner IOManagers of the BranchingIOManager
- thank you @danielgafni!S3FakeResource.upload_fileobj()
signature is now consistent with boto3 S3.Client.upload_fileobj()
- thank you @jeanineharb!dbt_assets
now have an optional name parameter - thank you @AlexanderVR!report_asset_check
REST API endpoint for runless external asset check evaluation events. This is available in cloud as well.config
argument is now supported on @graph_multi_asset
DbtCliResource
.AssetExecutionContext
type annotation for the context
parameter in @asset_check
functions.profiles_dir=None
into DbtCliResource
would cause incorrect validation.DuckDBResource
and DuckDBIOManager
accept a connection_config
configuration that will be passed as config
to the DuckDB connection. Thanks @xjhc!--live-data-poll-rate
that allows configuring how often the UI polls for new asset data when viewing the asset graph, asset catalog, or overview assets page. It defaults to 2000 ms.report_asset_materialization
REST API endpoint for creating external asset materialization events. This is available in cloud as well.@dbt_assets
decorator now accepts a backfill_policy
argument, for controlling how the assets are backfilled.@dbt_assets
decorator now accepts a op_tags
argument, for passing tags to the op underlying the produced AssetsDefinition
.get_materialize_result
& get_asset_check_result
to PipesClientCompletedInvocation
acryl-datahub
pin in the dagster-datahub
package has been removed.PipesDatabricksClient
now performs stdout/stderr forwarding from the Databricks master node to Dagster.dagster-dbt-cloud
CLI.K8sRunLauncher
. See the docs for more information.Previously, the asset backfill page would display negative counts if failed partitions were manually re-executed. This has been fixed.
Fixed an issue where the run list dialog for viewing the runs occupying global op concurrency slots did not expand to fit the content size.
Fixed an issue where selecting a partition would clear the launchpad and typing in the launchpad would clear the partition selection
Fixed various issues with the asset-graph displaying the wrong graph
The IO manager’s handle_output
method is no longer invoked when observing an observable source asset.
[ui] Fixed an issue where the run config dialog could not be scrolled.
[pipes] Fixed an issue in the PipesDockerClient
with parsing logs fetched via the docker client.
[external assets] Fixed an issue in external_assets_from_specs
where providing multiple specs would error
[external assets] Correct copy in tooltip to explain why Materialize button is disabled on an external asset.
dagster-pipes
version used in the external process.is_dagster_pipes_process
has been removed from the dagster-pipes
package.EnvVar
utility will now raise an exception if it is used outside of the context of a Dagster resource or config class. The get_value()
utility will retrieve the value outside of this context.DbtCliResource
, an explicit target_path
can now be specified.DagsterDbtTranslator
and DagsterDbtTranslatorSettings
: see the docs for more information.