Breaking Changes
AssetMaterializations
no longer accepts a dagster_type
argument. This reverts the change
billed as "AssetMaterializations
can now have type information attached as metadata." in the
previous release.New
AssetMaterializations
can now have type information attached as metadata. See the materializations tutorial for moreBugfixes
context['ts']
was not passed properlytask_acks_late: true
that resulted in a 409 Conflict error
from Kubernetes. The creation of a Kubernetes Job will now be aborted if another Job with the same name existsDocs
New
CeleryK8sRunLauncher
supports termination of pipeline runs. This can be accessed via the
“Terminate” button in Dagit’s Pipeline Run view or via “Cancel” in Dagit’s All Runs page. This
will terminate the run master K8s Job along with all running step job K8s Jobs; steps that are
still in the Celery queue will not create K8s Jobs. The pipeline and all impacted steps will
be marked as failed. We recommend implementing resources as context managers and we will execute
the finally block upon termination.K8sRunLauncher
supports termination of pipeline runs.AssetMaterialization
events display the asset key in the Runs view.Bugfixes
DagsterInstance
was leaving database connections open due to not being
garbage collected.Enum
in resource config schemas resulted in an error.New
configured
API makes it easy to create configured versions of resources.Materialization
event type in favor of the new AssetMaterialization
event type,
which requires the asset_key
parameter. Solids yielding Materialization
events will continue
to work as before, though the Materialization
event will be removed in a future release.intermediate_storage_defs
argument to ModeDefinition
, which accepts a
list of IntermediateStorageDefinition
s, e.g. s3_plus_default_intermediate_storage_defs
.
As before, the default includes an in-memory intermediate and a local filesystem intermediate
storage.system_storage_defs
argument to ModeDefinition
in favor of
intermediate_storage_defs
. system_storage_defs
will be removed in 0.10.0 at the earliest.@intermediate_storage
decorator, which makes it easy to define intermediate
storages.s3_file_manager
and local_file_manager
resources to replace the file managers
that previously lived inside system storages. The airline demo has been updated to include
an example of how to do this:
https://github.com/dagster-io/dagster/blob/0.8.8/examples/airline_demo/airline_demo/solids.py#L171.Bugfixes
default_value
config on a field now works as expected. #2725Breaking Changes
dagster
and dagit
CLI commands no longer add the working directory to the
PYTHONPATH when resolving modules, which may break some imports. Explicitly installed python
packages can be specified in workspaces using the python_package
workspace yaml config option.
The python_module
config option is deprecated and will be removed in a future release.New
--path-prefix
to the dagit CLI. #2073date_partition_range
util function now accepts an optional inclusive
boolean argument. By default, the function does not return include the partition for which the end time of the date range is greater than the current time. If inclusive=True
, then the list of partitions returned will include the extra partition.MultiDependency
or fan-in inputs will now only cause the solid step to skip if all of the
fanned-in inputs upstream outputs were skippedBugfixes
input_hydration_config
argumentsalias
on a solid output will produce a useful error message (thanks @iKintosh!)daily_schedule
) for certain workspace.yaml formats