New
-
The new
@graph_asset
and@graph_multi_asset
decorators make it more ergonomic to define graph-backed assets. -
Dagster will auto-infer dependency relationships between single-dimensionally partitioned assets and multipartitioned assets, when the single-dimensional partitions definition is a dimension of the
MultiPartitionsDefinition
. -
A new
Test sensor
/Test schedule
button that allows you to perform a dry-run of your sensor / schedule. Check out the docs on this functionality here for sensors and here for schedules. -
[dagit] Added (back) tag autocompletion in the runs filter, now with improved query performance.
-
[dagit] The Dagster libraries and their versions that were used when loading definitions can now be viewed in the actions menu for each code location.
-
New
bigquery_pandas_io_manager
can store and load Pandas dataframes in BigQuery. -
[dagster-snowflake, dagster-duckdb] SnowflakeIOManagers and DuckDBIOManagers can now default to loading inputs as a specified type if a type annotation does not exist for the input.
-
[dagster-dbt] Added the ability to use the “state:” selector
-
[dagster-k8s] The Helm chart now supports the full kubernetes env var spec for Dagit and the Daemon. E.g.
dagit: env: - name: “FOO” valueFrom: fieldRef: fieldPath: metadata.uid
Bugfixes
- Previously, graphs would fail to resolve an input with a custom type and an input manager key. This has been fixed.
- Fixes a bug where negative partition counts were displayed in the asset graph.
- Previously, when an asset sensor did not yield run requests, it returned an empty result. This has been updated to yield a meaningful message.
- Fix an issue with a non-partitioned asset downstream of a partitioned asset with self-dependencies causing a GQL error in dagit.
- [dagster-snowflake-pyspark] Fixed a bug where the PySparkTypeHandler was incorrectly loading partitioned data.
- [dagster-k8s] Fixed an issue where run monitoring sometimes failed to detect that the kubernetes job for a run had stopped, leaving the run hanging.
Documentation
- Updated contributor docs to reference our new toolchain (
ruff
,pyright
). - (experimental) Documentation for the dynamic partitions definition is now added.
- [dagster-snowflake] The Snowflake I/O Manager reference page now includes information on working with partitioned assets.
All Changes
1.1.19...1.1.20
See All Contributors
disable check_same_thread on in-memory sqlite storage (#12229)
by @alangenfeld
[direct invoke] yield implicit Nothing Output (#12309)
by @alangenfeld
Fix multipartitions run length encoding error (#12329)
by @clairelin135
[freshness-policies] Allow setting freshness policies when using graph-backed assets (#12357)
by @OwenKephart
Add skip reason to asset sensor (#12343)
by @OwenKephart
Fix partitions backfill deserialization error (#12238)
by @clairelin135
Move CachingRepositoryData.from_list and from_dict into standalone function (#12321)
by @schrockn
refactor(databricks): divest from databricks_api in favor of databricks-cli (#12153)
by @rexledesma
nullsafe array index access (#12362)
by @salazarm
Change schedule button text (#12361)
by @dpeng817
[dagit] add full serialized error to graphql errors (#12228)
by @alangenfeld
[dagster-pandas][dagster-pandera] assign a typing_type for generated pandas dataframe DagsterTypes (#12363)
by @OwenKephart
[typing/static] Execution API types (#12330)
by @smackesey
[refactor] DependencyDefinition renames (#12338)
by @smackesey
[refactor] execute_step renames (#12354)
by @smackesey
[typing/runtime] Standardize StepInputSource.load_input_object (#12342)
by @smackesey
[refactor] Delete NodeInput.solid_name (#12339)
by @smackesey
[refactor] NodeDefiniton.iterate_solid_defs -> iterate_op_defs (#12336)
by @smackesey
[refactor] GraphDefinition method renames (#12335)
by @smackesey
[2/n][structured config] Enable struct config resources, IO managers to depend on other resources (#11645)
by @benpankow
[refactor] local var/private arg solid -> node (#12337)
by @smackesey
DagsterLibraryRegistry (#12266)
by @alangenfeld
[refactor] misc core solid -> node renames (#12368)
by @smackesey
[refactor] dagster._core.definitions.solid_container -> node_container (#12369)
by @smackesey
[refactor] Assorted local var solid -> node (#12370)
by @smackesey
Fix intermittent dynamic partitions table SQLite concurrency error (#12367)
by @clairelin135
change storage signature for run tags (#12348)
by @prha
1.1.19 Changelog (#12378)
by @OwenKephart
guide to how assets relate to ops and graphs (#12204)
by @sryza
[pythonic config] Rename pythonic config classes (#12235)
by @benpankow
updates tests to handle new kubernetes resources field (#12395)
by @alangenfeld
[structured config] Migrate resources from project-fully-featured to struct config resources (#11785)
by @benpankow
refactor(databricks): add types to databricks.py (#12364)
by @rexledesma
refactor(databricks): consolidate types (#12366)
by @rexledesma
add dagster_libraries to ListRepositoriesResponse (#12267)
by @alangenfeld
[graphql] add RepositoryLocation.dagsterLibraryVersions (#12268)
by @alangenfeld
[dagit] add dagster libraries menu to code location row (#12315)
by @alangenfeld
1.1.19 changelog: reorder code block (#12402)
by @yuhan
refactor(databricks): use databricks_cli's raw api client (#12377)
by @rexledesma
[docs] [snowflake] Add partitions to snowflake guide (#12231)
by @jamiedemaria
Add valid start time check to materialized time partitions subsets (#12403)
by @clairelin135
Add api docs for some PartitionsDefinition and PartitionMapping classes (#12365)
by @sryza
Add text to timestamp dropdown (#12379)
by @dpeng817
[refactor] IExecutionStep.solid_handle -> node_handle (#12371)
by @smackesey
[asset-reconciliation] Factor in more run statuses (#12412)
by @OwenKephart
[refactor] *ExecutionContext.solid_config -> op_config (#12372)
by @smackesey
[refactor] ResolvedRunConfig.solids -> ops (#12373)
by @smackesey
Automation: versioned docs for 1.1.19
by @elementl-devtools
[refactor] assorted Dagstermill renames (#12380)
by @smackesey
[refactor] Context
solid renames (#12374)
by @smackesey
lambda_solid -> solid (#10816)
by @smackesey
[refactor] Assorted pipeline_run -> dagster_run (#12383)
by @smackesey
Make a script to template out new dagster packages (#12389)
by @jamiedemaria
[library template] add registry call (#12418)
by @alangenfeld
[db io managers] connection refactor (#12258)
by @jamiedemaria
Code location alerting docs (#12411)
by @dpeng817
[refactor] remove @solid decorator (#10952)
by @smackesey
[refactor] Delete PipelineRunsFilter (#12384)
by @smackesey
[db io managers] add default_load_type (#12356)
by @jamiedemaria
[refactor] Delete RunRecord.pipeline_run (#12385)
by @smackesey
[refactor] pipeline_run_from_storage -> dagster_run_from_storage (#12386)
by @smackesey
[Docs RFC] Dynamic Partitions (#12227)
by @clairelin135
Auto infer multipartition <-> single dimension mapping (#12400)
by @clairelin135
[refactor] execution pipeline_run -> dagster_run (#12388)
by @smackesey
[test-api-update] execution_tests/dynamic_tests (#12427)
by @smackesey
Consider the run worker unhealthy is the job has no active pods but the run is in a non-terminal state (#11510)
by @gibsondan
fix: only inspect schema when we may create tables (#12269)
by @plaflamme
More helpful asset key mismatch errors (#12008)
by @benpankow
Add docs for testing schedules/sensors via UI (#12381)
by @dpeng817
document missing breaking change in 1.1.19 changelog (#12424)
by @sryza
BigQuery IO manager (#11425)
by @jamiedemaria
[dagster-gcp-pandas] API docs fix (#12450)
by @jamiedemaria
[graphql] launch backfills over assets with different partitionings, if all roots have same partitioning (#11827)
by @sryza
Fix resolution error with input manager key and custom dagster type (#12449)
by @clairelin135
[dagster-dbt] Add ability to use the "state:" selector (#12432)
by @OwenKephart
Revert "More helpful asset key mismatch errors (#12008)" (#12459)
by @benpankow
[dagit] Add missing React keys to prevent new warning toasts (#12210)
by @bengotow
[CustomConfirmationDialog] Allow overriding the button text (#12444)
by @salazarm
add another todo to create_dagster_package (#12453)
by @jamiedemaria
[dagster-gcp-pandas] register library in init (#12469)
by @jamiedemaria
[bugfix] fix projected logical version resolution for asset downstream of self-dep (#12443)
by @smackesey
fix: resolve correct legacy arguments for emr pyspark step launcher (#12419)
by @rexledesma
[dagster-dbt] Add missing files for tests (#12471)
by @OwenKephart
Add task_role_arn and execution_role_arn to EcsContainerContext (#12358)
by @gibsondan
dagster-census api docs (#12413)
by @yuhan
graph_asset and graph_multi_asset decorators (#10152)
by @sryza
[dagster-snowflake-pyspark] fix bug loading partitions (#12472)
by @jamiedemaria
Add stale status causes (#11953)
by @smackesey
Update Contributing doc with instructions for ruff/pyright (#12481)
by @smackesey
[bigquery] mark bigquery io manager experimental (#12479)
by @jamiedemaria
fix (#12477)
by @salazarm
add graphql fields for querying run tags (#12409)
by @prha
add partial tag autocomplete for run filter input (#12410)
by @prha
Update GQL to expose StaleStatus and StaleStatusCause (#11952)
by @smackesey
Support env valueFrom in Helm chart (#12425)
by @johannkm
Fix state status logical version test (#12484)
by @smackesey
use opt_nullable_mapping for dagster library versions (#12487)
by @alangenfeld
fix ruff (#12486)
by @alangenfeld
[pythonic resources] Clean up initialization of env vars, treat resource objects as immutable (#12445)
by @benpankow
[structured config] Add support for Selectors w/ pydantic discriminated unions (#11280)
by @benpankow
[pythonic resources] Last set of class renames (#12490)
by @benpankow
Allow setting logical version inside op (#12189)
by @smackesey
Add example of customizing task role and execution role arn to the ECS agent docs (#12491)
by @gibsondan
Remove existing RunConfig class (#12488)
by @benpankow
[pythonic config] Add structured RunConfig object for specifying runtime, job config (#11965)
by @benpankow
[draft][pythonic config][docs] Introduce intro to Resources doc utilizing Pythonic resources (#12260)
by @benpankow
[draft][pythonic config][docs] Introduce intro to Config doc utilizing Pythonic config (#12349)
by @benpankow
1.1.20 changelog (#12506)
by @benpankow
[fix] fix sphinx airflow version parsing (#12507)
by @benpankow
1.1.20
by @elementl-devtools