dagster dev
or the Dagster UI would display an error when loading jobs created with op or asset selections.@multi_asset
s are in use has been drastically improved.the_asset.with_attributes
is called without providing a group name. Previously, the existing group name was erroneously dropped. Thanks @ion-elgreco!dbt source freshness
.MetadataValue
in Essentials course. Thanks @stianthaulow!tag_keys
argument on DagsterInstance.get_run_tags
is no longer optional. This has been done to remove an easy way of accidentally executing an extremely expensive database operation.AssetSelection.
dagster-snowflake
now requires snowflake-connector-python>=3.4.0
@sling_assets
accepts an optional name parameter for the underlying opdagster-openai
library is now available.DagsterDbtTranslatorSettings
called enable_duplicate_source_asset_keys
that allows users to set duplicate asset keys for their dbt sources. Thanks @hello-world-bfree!ConfigurableResource
.SlingConnectionResource
where a blank keyword argument would be emitted as an environment variabledbt source freshness
would cause an error.DbtArtifacts
has been added for managing the behavior of rebuilding the manifest during development but expecting a pre-built one in production.send sample alert
button now exists on both the alert policies page and in the alert policies editor to make it easier to debug and configure alerts without having to wait for an event to kick them off.SlingConnectionResource
that raised an error when connecting to a database.graph_multi_assets
with check_specs
now support subsetting.run_retries.retry_on_op_or_asset_failures
setting that can be set to false to make run retries only occur when there is an unexpected failure that crashes the run, allowing run-level retries to co-exist more naturally with op or asset retries. See the docs for more information.dagster dev
now sets the environment variable DAGSTER_IS_DEV_CLI
allowing subprocesses to know that they were launched in a development context.@multi_observable_source_asset
decorator enables defining a set of assets that can be observed together with the same function.@sling_assets
and Resource SlingConnectionResource
have been added for the [dagster-embedded-elt.sling](http://dagster-embedded-elt.sling)
package. Deprecated build_sling_asset
, SlingSourceConnection
and SlingTargetConnection
.QueuedRunCoordinator
.dagster-polars
has been added as an integration. Thanks @danielgafni!@dbt_assets
now supports loading projects with semantic models.@dbt_assets
now supports loading projects with model versions.get_asset_key_for_model
now supports retrieving asset keys for seeds and snapshots. Thanks @aksestok!@asset
decorator causing a false positive in Pyright strict mode. Thanks @tylershunt!security_context
field on the k8s_job_executor
didn't correctly set the security context on the launched step pods. Thanks @krgn!ObserveResult
s with no data_version
.FreshnessPolicy
s on observable source assets. These assets will be considered “Overdue” when the latest value for the “dagster/data_time” metadata value is older than what’s allowed by the freshness policy.DbtCliResource
now include metadata from the dbt adapter response. This includes fields like rows_affected
, query_id
from the Snowflake adapter, or bytes_processed
from the BigQuery adapter.k8s_job_executor
.context.log.exception
in a sensor or schedule did not properly capture exception information.@observable_source_asset
-decorated functions can now return an ObserveResult
. This allows including metadata on the observation, in addition to a data version. This is currently only supported for non-partitioned assets.AutoMaterializeRule.skip_on_not_all_parents_updated_since_cron
class allows you to construct AutoMaterializePolicys
which wait for all parents to be updated after the latest tick of a given cron schedule.Breaking
type_check_fn
on a custom type was
required to return None (=passed) or else raise Failure
(=failed). Now, a type_check_fn
may
return True
/False
to indicate success/failure in the ordinary case, or else return a
TypeCheck
. The newsuccess
field on TypeCheck
now indicates success/failure. This obviates
the need for the typecheck_metadata_fn
, which has been removed.CompositeSolidExecutionResult
rather than a SolidExecutionResult
.dagster.core.storage.sqlite_run_storage.SqliteRunStorage
has moved to
dagster.core.storage.runs.SqliteRunStorage
. Any persisted dagster.yaml
files should be updated
with the new classpath.is_secret
has been removed from Field
. It was not being used to any effect.environmentType
and configTypes
fields have been removed from the dagster-graphql
Pipeline
type. The configDefinition
field on SolidDefinition
has been renamed to
configField
.Bugfix
PresetDefinition.from_files
is now guaranteed to give identical results across all Python
minor versions.DagsterKubernetesPodOperator
has been fixed.New
@pyspark_solid
decorator.Nits
features
in the dagster.yaml
will no longer have any effect.dagit
no longer prematurely returns control to terminal on Windowsraise_on_error
is now available on the execute_solid
test utilitycheck_dagster_type
added as a utility to help test type checks on custom typesSet
and Tuple
typesretryRunId
, stepKeys
execution parameters instead of a reexecutionConfig
input objectAdds a type_check
parameter to PythonObjectType
, as_dagster_type
, and @as_dagster_type
to
enable custom type checks in place of default isinstance
checks.
See documentation here:
https://dagster.readthedocs.io/en/latest/sections/learn/tutorial/types.html#custom-type-checks
Improved the type inference experience by automatically wrapping bare python types as dagster types.
Reworked our tutorial (now with more compelling/scary breakfast cereal examples) and public API documentation. See the new tutorial here: https://dagster.readthedocs.io/en/latest/sections/learn/tutorial/index.html
New solids explorer in Dagit allows you to browse and search for solids used across the repository.
Enabled solid dependency selection in the Dagit search filter.
+{solid_name}
.{solid_name}+
.+{solid_name}+
.Added a terminate button in Dagit to terminate an active run.
Added an --output
flag to dagster-graphql
CLI.
Added confirmation step for dagster run wipe
and dagster schedule wipe
commands (Thanks
@shahvineet98).
Fixed a wrong title in the dagster-snowflake
library README (Thanks @Step2Web).
@pipeline
and @composite_solid
to automatically give solids
aliases with an incrementing integer suffix when there are conflicts. This removes to the need
to manually alias solid definitions that are used multiple times.dagster schedule wipe
command to delete all schedules and remove all schedule cron jobsexecute_solid
test util now works on composite solids.--remote
flag to dagster-graphql
for querying remote Dagit servers.latest
on Docker Hub were erroneously
published with an older version of Dagster (#1814)dagster schedule start --start-all
command (#1812)dagster schedule restart
. Also added a
flag to restart all running schedules: dagster schedule restart --restart-all-running
.