Major Changes
- Software-defined assets are now marked fully stable and are ready for prime time - we recommend using them whenever your goal using Dagster is to build and maintain data assets.
- You can now organize software defined assets into groups by providing a group_name on your asset definition. These assets will be grouped together in Dagit.
- Software-defined assets now accept configuration, similar to ops. E.g.
from dagster import asset @asset(config_schema={"iterations": int}) def my_asset(context): for i in range(context.op_config["iterations"]): ...
- Asset definitions can now be created from graphs via
AssetsDefinition.from_graph
:@graph(out={"asset_one": GraphOut(), "asset_two": GraphOut()}) def my_graph(input_asset): ... graph_asset = AssetsDefinition.from_graph(my_graph)
execute_in_process
andGraphDefinition.to_job
now both accept aninput_values
argument, so you can pass arbitrary Python objects to the root inputs of your graphs and jobs.- Ops that return Outputs and DynamicOutputs now work well with Python type annotations. You no longer need to sacrifice static type checking just because you want to include metadata on an output. E.g.
from dagster import Output, op @op def my_op() -> Output[int]: return Output(5, metadata={"a": "b"})
- You can now automatically re-execute runs from failure. This is analogous to op-level retries, except at the job level.
- You can now supply arbitrary structured metadata on jobs, which will be displayed in Dagit.
- The partitions and backfills pages in Dagit have been redesigned to be faster and show the status of all partitions, instead of just the last 30 or so.
- The left navigation pane in Dagit is now grouped by repository, which makes it easier to work with when you have large numbers of jobs, especially when jobs in different repositories have the same name.
- The Asset Details page for a software-defined asset now includes a Lineage tab, which makes it easy to see all the assets that are upstream or downstream of an asset.
Breaking Changes and Deprecations
Software-defined assets
This release marks the official transition of software-defined assets from experimental to stable. We made some final changes to incorporate feedback and make the APIs as consistent as possible:
- Support for adding tags to asset materializations, which was previously marked as experimental, has been removed.
- Some of the properties of the previously-experimental AssetsDefinition class have been renamed. group_names is now group_names_by_key, asset_keys_by_input_name is now keys_by_input_name, and asset_keys_by_output_name is now keys_by_output_name, asset_key is now key, and asset_keys is now keys.
- Removes previously experimental IO manager
fs_asset_io_manager
in favor of merging its functionality withfs_io_manager
.fs_io_manager
is now the default IO manager for asset jobs, and will store asset outputs in a directory named with the asset key. Similarly, removedadls2_pickle_asset_io_manager
,gcs_pickle_asset_io_manager
, ands3_pickle_asset_io_manager
. Instead,adls2_pickle_io_manager
,gcs_pickle_io_manager
, ands3_pickle_io_manager
now support software-defined assets. - (deprecation) The namespace argument on the
@asset
decorator and AssetIn has been deprecated. Users should use key_prefix instead. - (deprecation) AssetGroup has been deprecated. Users should instead place assets directly on repositories, optionally attaching resources using with_resources. Asset jobs should be defined using
define_assets_job
(replacingAssetGroup.build_job
), and arbitrary sets of assets can be materialized using the standalone function materialize (replacingAssetGroup.materialize
). - (deprecation) The
outs
property of the previously-experimental@multi_asset
decorator now prefers a dictionary whose values areAssetOut
objects instead of a dictionary whose values areOut
objects. The latter still works, but is deprecated. - The previously-experimental property on
OpExecutionContext
calledoutput_asset_partition_key
is now deprecated in favor ofasset_partition_key_for_output
Event records
- The
get_event_records
method on DagsterInstance now requires a non-None argumentevent_records_filter
. Passing aNone
value for theevent_records_filter
argument will now raise an exception where previously it generated a deprecation warning. - Removed methods
events_for_asset_key
andget_asset_events
, which have been deprecated since 0.12.0.
Extension libraries
- [dagster-dbt] (breaks previously-experimental API) When using the load_assets_from_dbt_project or load_assets_from_dbt_manifest , the AssetKeys generated for dbt sources are now the union of the source name and the table name, and the AssetKeys generated for models are now the union of the configured schema name for a given model (if any), and the model name. To revert to the old behavior:
dbt_assets = load_assets_from_dbt_project(..., node_info_to_asset_key=lambda node_info: AssetKey(node_info["name"])
. - [dagster-k8s] In the Dagster Helm chart, user code deployment configuration (like secrets, configmaps, or volumes) is now automatically included in any runs launched from that code. Previously, this behavior was opt-in. In most cases, this will not be a breaking change, but in less common cases where a user code deployment was running in a different kubernetes namespace or using a different service account, this could result in missing secrets or configmaps in a launched run that previously worked. You can return to the previous behavior where config on the user code deployment was not applied to any runs by setting the includeConfigInLaunchedRuns.enabled field to false for the user code deployment. See the Kubernetes Deployment docs for more details.
- [dagster-snowflake] dagster-snowflake has dropped support for python 3.6. The library it is currently built on, snowflake-connector-python, dropped 3.6 support in their recent 2.7.5 release.
Other
- The
prior_attempts_count
parameter is now removed from step-launching APIs. This parameter was not being used, as the information it held was stored elsewhere in all cases. It can safely be removed from invocations without changing behavior. - The
FileCache
class has been removed. - Previously, when schedules/sensors targeted jobs with the same name as other jobs in the repo, the jobs on the sensor/schedule would silently overwrite the other jobs. Now, this will cause an error.
New since 0.14.20
-
A new
define_asset_job
function allows you to define a selection of assets that should be executed together. The selection can be a simple string, or an AssetSelection object. This selection will be resolved into a set of assets once placed on the repository.from dagster import repository, define_asset_job, AssetSelection string_selection_job = define_asset_job( name="foo_job", selection="*foo" ) object_selection_job = define_asset_job( name="bar_job", selection=AssetSelection.groups("some_group") ) @repository def my_repo(): return [ *my_list_of_assets, string_selection_job, object_selection_job, ]
-
[dagster-dbt] Assets loaded with
load_assets_from_dbt_project
andload_assets_from_dbt_manifest
will now be sorted into groups based on the subdirectory of the project that each model resides in. -
@asset
and@multi_asset
are no longer considered experimental. -
Adds new utility methods
load_assets_from_modules
,assets_from_current_module
,assets_from_package_module
, andassets_from_package_name
to fetch and return a list of assets from within the specified python modules. -
Resources and io managers can now be provided directly on assets and source assets.
from dagster import asset, SourceAsset, resource, io_manager @resource def foo_resource(): pass @asset(resource_defs={"foo": foo_resource}) def the_resource(context): foo = context.resources.foo @io_manager def the_manager(): ... @asset(io_manager_def=the_manager) def the_asset(): ...
Note that assets provided to a job must not have conflicting resource for the same key. For a given job, all resource definitions must match by reference equality for a given key.
-
A
materialize_to_memory
method which will load the materializations of a provided list of assets into memory:from dagster import asset, materialize_to_memory @asset def the_asset(): return 5 result = materialize_to_memory([the_asset]) output = result.output_for_node("the_asset")
-
A
with_resources
method, which allows resources to be added to multiple assets / source assets at once:from dagster import asset, with_resources, resource @asset(required_resource_keys={"foo"}) def requires_foo(context): ... @asset(required_resource_keys={"foo"}) def also_requires_foo(context): ... @resource def foo_resource(): ... requires_foo, also_requires_foo = with_resources( [requires_foo, also_requires_foo], {"foo": foo_resource}, )
-
You can now include asset definitions directly on repositories. A
default_executor_def
property has been added to the repository, which will be used on any materializations of assets provided directly to the repository.from dagster import asset, repository, multiprocess_executor @asset def my_asset(): ... @repository(default_executor_def=multiprocess_executor) def repo(): return [my_asset]
-
The
run_storage
,event_log_storage
, andschedule_storage
configuration sections of thedagster.yaml
can now be replaced by a unifiedstorage
configuration section. This should avoid duplicate configuration blocks with yourdagster.yaml
. For example, instead of:# dagster.yaml run_storage: module: dagster_postgres.run_storage class: PostgresRunStorage config: postgres_url: { PG_DB_CONN_STRING } event_log_storage: module: dagster_postgres.event_log class: PostgresEventLogStorage config: postgres_url: { PG_DB_CONN_STRING } schedule_storage: module: dagster_postgres.schedule_storage class: PostgresScheduleStorage config: postgres_url: { PG_DB_CONN_STRING }
You can now write:
storage: postgres: postgres_url: { PG_DB_CONN_STRING }
-
All assets where a
group_name
is not provided are now part of a group calleddefault
. -
The group_name parameter value for
@asset
is now restricted to only allow letters, numbers and underscore. -
You can now set policies to automatically retry Job runs. This is analogous to op-level retries, except at the job level. By default the retries pick up from failure, meaning only failed ops and their dependents are executed.
-
[dagit] The new repository-grouped left navigation is fully launched, and is no longer behind a feature flag.
-
[dagit] The left navigation can now be collapsed even when the viewport window is wide. Previously, the navigation was collapsible only for small viewports, but kept in a fixed, visible state for wide viewports. This visible/collapsed state for wide viewports is now tracked in localStorage, so your preference will persist across sessions.
-
[dagit] Queued runs can now be terminated from the Run page.
-
[dagit] The log filter on a Run page now shows counts for each filter type, and the filters have higher contrast and a switch to indicate when they are on or off.
-
[dagit] The partitions and backfill pages have been redesigned to focus on easily viewing the last run state by partition. These redesigned pages were previously gated behind a feature flag — they are now loaded by default.
-
[dagster-k8s] Overriding labels in the K8sRunLauncher will now apply to both the Kubernetes job and the Kubernetes pod created for each run, instead of just the Kubernetes pod.
Bugfixes
- [dagster-dbt] In some cases, if Dagster attempted to rematerialize a dbt asset, but dbt failed to start execution, asset materialization events would still be emitted. This has been fixed.
- [dagit] On the Instance Overview page, the popover showing details of overlapping batches of runs is now scrollable.
- [dagit] When viewing Instance Overview, reloading a repository via controls in the left navigation could lead to an error that would crash the page due to a bug in client-side cache state. This has been fixed.
- [dagit] When scrolling through a list of runs, scrolling would sometimes get stuck on certain tags, specifically those with content overflowing the width of the tag. This has been fixed.
- [dagit] While viewing a job page, the left navigation item corresponding to that job will be highlighted, and the navigation pane will scroll to bring it into view.
- [dagit] Fixed a bug where the “Scaffold config” button was always enabled.
Community Contributions
- You can now provide dagster-mlflow configuration parameters as environment variables, thanks @chasleslr!
Documentation
- Added a guide that helps users who are familiar with ops and graphs understand how and when to use software-defined assets.
- Updated and reorganized docs to document software-defined assets changes since 0.14.0.
- The Deploying in Docker example now includes an example of using the
docker_executor
to run each step of a job in a different Docker container. - Descriptions for the top-level fields of Dagit GraphQL queries, mutations, and subscriptions have been added.
All Changes
0.14.0...0.15.0
See All Contributors
add fallback error state for snapshot types (#6671)
by @prha
Getting Started and Basic Tutorial fixes (#6673)
by @jmsanders
run timeline blank state (#6674)
by @prha
[multiproc] default to spawn (#6676)
by @alangenfeld
Asset Observations Doc (#6630)
by @clairelin135
Restore missing repo.py file (#6677)
by @gibsondan
[dagster-aws] Fix bug when logging records from pyspark_step_launcher (#6680)
by @OwenKephart
Automation: versioned docs for 0.14.0
by @elementl-devtools
Changelog (#6667)
by @clairelin135
Fix formatting on schedules feature in changelog (#6686)
by @gibsondan
Pin grpcio-health-checking (#6685)
by @johannkm
fix changelog page in docs (#6694)
by @yuhan
redirect ecs page (#6695)
by @yuhan
Remove crons from our example dockerfiles (#6645)
by @gibsondan
pin markupsafe (#6713)
by @alangenfeld
add cursor label to tick timeline (#6712)
by @prha
whitelist_for_serdes WorkerStatus enum (#6716)
by @johannkm
docstrings for AssetGroup and AssetGroup.build_job (#6696)
by @dpeng817
0.14.1 changelog (#6720)
by @alangenfeld
Remove bad invariant from back when sensor status was a fixed status, not a default status (#6711)
by @gibsondan
Automation: versioned docs for 0.14.1
by @elementl-devtools
Add a check in run execution that the run actually exists, just like in step execution (#6689)
by @gibsondan
add back mutation tests for sensor/schedules with default status (#6721)
by @prha
Export build_reconstructable_target to match cragified docs (#6317)
by @prha
add build_run_status_sensor_context (#6543)
by @jamiedemaria
Rename metadata (remove "Event") in graphql/dagit (#6656)
by @smackesey
Speed up get_assets_for_run_id when there are a lot of events (#6735)
by @gibsondan
undefined (#6742)
by @alangenfeld
Fix invariant check in databricks job/pipeline path (#6718)
by @iswariyam
make Content Gap an issue label instead of part of title (#6745)
by @sryza
0.14.0 migration.md (#6715)
by @clairelin135
Move bollinger example to AssetGroup and add README (#6749)
by @sryza
move software-defined assets toy to asset collection (#6643)
by @sryza
rename conditional branching example to nyt and add README (#6757)
by @sryza
[docs infra] remove old versions from versioned_navigation (#6704)
by @yuhan
fix typo in ops rst (#6758)
by @yuhan
update error messages for ExternalAssetDependency/ExternalAssetDependedBy (#6748)
by @OwenKephart
[Docs] Upgrade Next.js to 12.1.0 (#6722)
by @keyz
[docs infra] fix changelog's On This Page (#6706)
by @yuhan
fix(helm): remove registry field (#6744)
by @rexledesma
docs(helm): update chart metadata (#6778)
by @rexledesma
respect default_value in loadable input check (#6771)
by @alangenfeld
display non-sda assets in asset catalog (#6779)
by @prha
replace EventMetadata in docs (#6774)
by @smackesey
Migrate user event docs to use log_event, various docs cleanups (#6772)
by @dpeng817
[dagster-dbt] fix issues with dbt asset integration (#6777)
by @OwenKephart
Filter custom events from stats_for_run query (#6781)
by @johannkm
[Dagit] Fix missing op name in the asset sidebar (#6765)
by @bengotow
add validate_run_config to api docs (#6782)
by @prha
add api doc for op_def, graph_def (#6776)
by @prha
[examples] dbt -> dbt-core in dbt_example (#6786)
by @OwenKephart
[dagit] Show full asset paths on details pages, tweak filter interactions (#6764)
by @bengotow
Add small toggles to Asset Details graphs, consolidate localStorage-backed state (#6762)
by @bengotow
[dagster-shell] Fix deadlock with large output (#6435) (#6490)
by @kbd
[dagster-dbt] pin some stuff (#6791)
by @OwenKephart
deflake test_retry_policy (#6644)
by @alangenfeld
0.14.2 changelog (#6789)
by @sryza
add run_request_for_partition for job definition (#6790)
by @prha
Add a "log framework error" hook to execute_step invocations, similar to the one in execute_run (#6690)
by @gibsondan
fix up reexecution api example docs (#6787)
by @prha
reorganize dagster.check module (#6750)
by @smackesey
Adjustments/condensing of dagster.check (#6751)
by @smackesey
Automation: versioned docs for 0.14.2
by @elementl-devtools
fix: use run status to determine success for an in-process result (#6784)
by @rexledesma
namedtuple to NamedTuple (1st batch) (#6752)
by @smackesey
corrected export message from "~/dagster_home" to ~"/dagster_home" (#6327)
by @Proteusiq
docs: remove duplicate entries under integrations (#6724)
by @kahnwong
namedtuple to NamedTuple (2nd batch) (#6753)
by @smackesey
namedtuple to NamedTuple (3rd batch) (#6767)
by @smackesey
namedtuple to NamedTuple (4th batch) (#6785)
by @smackesey
[docs infra] speed up vercel build with ISR (#6773)
by @yuhan
[docs infra] no s3 when pulling versioned content (#6705)
by @yuhan
Still write cursors even when a sensor tick fails (#6807)
by @gibsondan
Direct invocation of assets for unit testing (#6761)
by @jamiedemaria
Partition docs updates (#6814)
by @jamiedemaria
fix pandera link on integrations page (#6813)
by @smackesey
[docs] regenerate yarn.lock (#6815)
by @alangenfeld
[events] remove message field (#6769)
by @alangenfeld
[dagster-postgres] improve connection retry (#6831)
by @alangenfeld
set ErrorSource when retry request limit exceeded (#6806)
by @alangenfeld
Update black, isort (#6714)
by @smackesey
Exclude materializing run from materialization warning run count (#6692)
by @clairelin135
rename PipelineRunsFilter => RunsFilter (#6811)
by @prha
assorted function type annotations (batch 1) (#6800)
by @smackesey
restore old metadata name deprecation warnings (#6688)
by @smackesey
Also override cpu/memory in containerOverrides (#6836)
by @jmsanders
move toys from build_assets_job to AssetGroup (#6801)
by @sryza
Simplify IWorkspace API (#6821)
by @gibsondan
[dagster-aws] Add secretsmanager resources (#6802)
by @benpankow
chore(daemon): retrieve daemon heartbeats in batch (#6843)
by @rexledesma
Revert isort Makefile config to use git ls-files (#6845)
by @smackesey
fix: query heartbeats db once (#6854)
by @rexledesma
[examples] Modern Data Stack + SDA Example (#6862)
by @OwenKephart
add table api doc page (#6840)
by @smackesey
[dagit] Avoid copying definition-time tags into launchpad state (#6851)
by @bengotow
[dagit] Replace black tag tooltips with as-needed, selectable ones (#6844)
by @bengotow
default to fs_asset_io_manager in AssetGroup (#6859)
by @sryza
move slack apidoc example to op/job (#6855)
by @sryza
Remove @abstractproperty (#6867)
by @johannkm
gate bucketing queries on sqlalchemy version (#6841)
by @prha
Don't carry forward all container definitions (#6850)
by @jmsanders
when multiple repos have the same asset, have graphql return the non-source one (#6856)
by @sryza
[dagit] Add a helper for building instance/runs paths, resolved #6847 (#6848)
by @bengotow
[dagster-fivetranAdd Fivetran Resync Op (#6868)
by @dwallace0723
[dagit] Use a custom hook to manage query polling (#6805)
by @bengotow
enable cross-job asset partitions (#6865)
by @sryza
[dagit] Add a gradient behind the Gantt chart step selector now
by @souterjk
remove gitignore setting from isort (#6872)
by @smackesey
Random formatting fixes (#6888)
by @dpeng817
AssetGroup.from_modules (#6884)
by @sryza
isort dagster-aws conftest (#6892)
by @sryza
fix expansion so its shell-neutral (#6894)
by @smackesey
build_assets_job -> AssetGroup in SDA guide (#6879)
by @sryza
Changelog (#6908)
by @dpeng817
add entries to 0.14.3 changelog (#6909)
by @sryza
Rename build_run_status_sensor_context in changelog (#6904)
by @gibsondan
make EventLogEntry.message change safe to downgrade (#6912)
by @alangenfeld
For those whome detest wordwrap in vscode (#6887)
by @dpeng817
Solid error message migration (#6883)
by @dpeng817
Error when amultiple asset groups are used in one repo, when a job is passed in with the asset group reserved name (#6891)
by @dpeng817
assorted sensor and schedule fixes (#6759)
by @jamiedemaria
[examples] For modern_data_stack_assets, more detailed README, helper script (#6914)
by @OwenKephart
fix bug with subset selection (#6921)
by @OwenKephart
enable vixie-style cron strings (#6810)
by @prha
Automation: versioned docs for 0.14.3
by @elementl-devtools
In run status sensors, snapshot the status in a PipelineRunReaction rather than pulling it from the PipelineRun object (#6931)
by @gibsondan
[dagster-airbyte][examples] fix bug with empty prefix (#6932)
by @OwenKephart
RFC: resolve k8s job and ops tag entirely using k8s_model_from_dict (#6205)
by @gibsondan
revert stray dagster[lint] for BK mypy (#6936)
by @smackesey
Migrate reference to solid in error message (#6935)
by @dpeng817
dagit-debug fix in-mem daemon heartbeats (#6943)
by @alangenfeld
[docs] details on mapping dynamic outputs (#6140)
by @alangenfeld
[docs] op retries concepts section (#6818)
by @alangenfeld
fix makefile issue with check_black/check_isort (#6944)
by @smackesey
change query to be compatible with sqlalchemy 1.3 (#6930)
by @prha
add a blank state message for the asset table (#6792)
by @prha
fix black
by @alangenfeld
Remove
update_doc_snapshot from root Makefile (#6837)
by @smackesey
namedtuple to NamedTuple (5th batch) (#6917)
by @smackesey
function type annotations (batch 2) (#6933)
by @smackesey
when building AssetGroups from modules, gather lists of assets (#6967)
by @sryza
remove legacy version of hacker news schedule (#6797)
by @sryza
ungate run batching (#6966)
by @prha
Use AssetGroup in hacker news demo (#6965)
by @sryza
AssetGroup.from_current_module (#6959)
by @sryza
[Dagit] Nits and polish based on user feedback (#6799)
by @bengotow
add support for filtering ticks by status (#6919)
by @prha
[dagit] Only warn about the backfill daemon when backfills are present (#6846)
by @bengotow
switch arg name for metadata value class (#6675)
by @smackesey
[dagit] Use a virtualized list in <SuggestWIP /> to fix launchpad partition picker perf (#6852)
by @bengotow
Fix missing partition bars in large partition data-sets (#6877)
by @souterjk
Quote selection to avoid grabbing downstreams with the same name prefix when viewing upstream graph, fix react table unhappy log (#6907)
by @souterjk
make all optional params explicit (#6934)
by @smackesey
Adds pez popover as requested in #6470 (#6871)
by @souterjk
fix pylint for modern data stack example (#6975)
by @smackesey
dev_install tweaks (#6970)
by @smackesey
partitioned assets toy (#6960)
by @sryza
Update create-new-project.mdx (#6898)
by @frcode
Add short-circuit in run start time if run failed to start (#6991)
by @gibsondan
Allow PathMetadataValue to accept os.PathLike input (#6920)
by @abkfenris
Raise run_task errors (#6993)
by @jmsanders
[dagit] React.FunctionComponent -> React.FC (#7002)
by @hellendag
Fix partitioned asset jobs with double downstream non-partitioned (#6986)
by @sryza
add ipython_genutils as dagit, dagstermill dep (#7016)
by @smackesey
Set up graphql mutation for setting a sensor cursor value (#6922)
by @prha
[dagit] Fix warning icon tests, add one for present-but-stopped schedule (#7026)
by @bengotow
Stop building duplicate downstream asset dependencies (#7001) (#7012)
by @bengotow
[dagit] Add error handling to Asset "Rematerialize Partitions" modal (#7011)
by @bengotow
[dagit] Fix tooltips in Gantt chart, use monospace font and middle truncation (#7025)
by @bengotow
[dagit] Fix right Asset Graph panel missing if saved "explorer" state is absent (#7013)
by @bengotow
Fix dagster k8s typo (#7028)
by @johannkm
Add sequence and mapping check functions (#7006)
by @smackesey
change backcompat pin to nbconvert (#7027)
by @smackesey
[dagit] Hide the asset group job on the instance overview (#7019)
by @bengotow
[dagit] When materializing assets, link to run instead of showing it (#7014)
by @bengotow
Assorted typing additions and adjustments (#7007)
by @smackesey
remove unneeded deps from dagit tox file (#7022)
by @gibsondan
Switch sensor/schedule view to show tick list instead of run list (#6861)
by @prha
update AssetGraph dedup logic (#7021)
by @smackesey
Make parse_run_config_input more defensive (#7003)
by @gibsondan
Expose metadata on AssetNode (and source assets) directly (#6900)
by @smackesey
adds source asset metadata to dagit (#7015)
by @smackesey
Adllow telemetry URL to be overridden with env var (#6946)
by @dpeng817
Remove space from dbt example notebook path (#7038)
by @smackesey
add tick batching to schedule storage (#6995)
by @prha
add batch tick loader for repository-scoped schedule/sensor ticks (#6997)
by @prha
K8s executor filter down to dagster events (#7000)
by @johannkm
Allow the use of environment variables in k8s_job_executor (#7031)
by @johannkm
[bug] hacky fix for step launcher behavior (#6866)
by @OwenKephart
make resource config available when loading from assets outside job (#7029)
by @sryza
Rename step jobs 'dagster-step' in k8s and docker (#6982)
by @johannkm
minor improvements to check (#7036)
by @smackesey
test raising exceptions in AssetGroup in deterministic order (#6945)
by @jamiedemaria
SDA docs fixes (#6905)
by @jamiedemaria
skip test_giant_external_repository_streaming_grpc (#7049)
by @alangenfeld
Fault tolerance docs (#5432)
by @johannkm
Silence experimental warnings triggered by internal code (#6873)
by @jamiedemaria
K8s docs ignore tag and show executor (#7053)
by @johannkm
Assorted fixes to the hackernews assets demo (#7030)
by @sryza
Support the same Secrets config syntax as ECS (#6985)
by @jmsanders
fix the sqlite gating logic (#7058)
by @prha
[dagster-airbyte] [dagster-fivetran] cleanup + tests (#7056)
by @OwenKephart
Reuse ECS task definitions (#7009)
by @jmsanders
Update last_materialization_timestamp to also update on observation (#6885)
by @clairelin135
Optimize Latest Runs Query (#7066)
by @clairelin135
[dagit] Remove default InstanceWarning mocks injecting randomness (#7054)
by @bengotow
fix tag batching with tag-based filters (#7055)
by @prha
Fix #6512 (#6969)
by @petehunt
K8s check run health test (#7070)
by @johannkm
hn local repo that uses duckdb as warehouse (#6968)
by @sryza
fix bug in fetch_assets.get_asset_nodes_by_asset_key (#7063)
by @sryza
Clear out 'dependsOn' when creating a default ECS task definition (#6929)
by @gibsondan
[dagit] Render status page navigation when factory floor loading (#7079)
by @benpankow
run mypy on dagster-graphql (#7075)
by @prha
fix logic for turning schedule ticks into hour boundaries when there's an offset (#7071)
by @gibsondan
Fixes #7082 (#7086)
by @smackesey
Fix failing check.path test on windows (#7077)
by @smackesey
[dagit] refactor graphql execute methods (#7065)
by @alangenfeld
dagster-snowflake drop 3.6 support (#7092)
by @alangenfeld
[dagit] Fix Gantt chart layout hang on certain graph structures #6942 (#7085)
by @bengotow
Log failed compute log to event log rather than buried in a logging output (#7093)
by @gibsondan
[dagit] Disallow use of gql from graphql.macro (#7042)
by @bengotow
[dagit] Add sensors/schedules to the asset details page (#7041)
by @bengotow
[dagit] Keep user-entered tags when changing presets / partitions (#7068)
by @bengotow
Add gitpod.yml (#7088)
by @petehunt
[dagit] Lower factory floor timeline fidelity to seconds from ms (#7091)
by @benpankow
[dagit] Show job failures on asset graph, fix in-progress runs on global graph (#7067)
by @bengotow
Optionally use sidecars (#7087)
by @jmsanders
Fix kwarg case with invocation (#7095)
by @dpeng817
Return an empty secrets list for task definitions (#7096)
by @jmsanders
Fixup ECS secrets docs (#7097)
by @jmsanders
0.14.4 changelog (#7099)
by @yuhan
refetch the backfill before updating, to avoid clobbering cancels (#7094)
by @prha
Automation: versioned docs for 0.14.4
by @elementl-devtools
fix perms in dagit (#7115)
by @prha
Remove hard failure if missing inputs (#7116)
by @dpeng817
Fix internal code metadata warnings (#7112)
by @smackesey
0.14.5 Changelog (#7119)
by @jmsanders
Automation: versioned docs for 0.14.5
by @elementl-devtools
batch run fetches in sensor daemon (#6950)
by @prha
gcs asset io manager (#7081)
by @jamiedemaria
Don't give up if the terminate() call raises an exception during force-termination (#7110)
by @gibsondan
[dagit] Add optional close button to Alert component (#7107)
by @benpankow
Add dagit test to make sure Permission flags stay in sync (#7117)
by @prha
expose compute_kind tag value on gql AssetNode (#7120)
by @smackesey
replace internal uses of
MetadataEntry static api (#7126)
by @smackesey
dynamic out bug fix (#6780)
by @alangenfeld
Create oss-issues.yml (#7132)
by @yuhan
fix docs search: js_render shouldnt be true (#7146)
by @yuhan
mypy version bump (#7149)
by @smackesey
docs(sda): fix typos and edit wording (#7136)
by @rexledesma
add permissions guard for schedule mutations (#7133)
by @prha
enable saving run key for ticks that skip runs because of run key idempotence (#7130)
by @prha
add tick tooltip info for skipped ticks due to run key idempotence (#7131)
by @prha
Rename the InstanceMigratedError to be less pushy about migrating (#7141)
by @gibsondan
[postgres] share db engine with watcher_thread (#7143)
by @alangenfeld
Add Map to config type API docs (#7154)
by @gibsondan
Pass on PythonError handling that should be using PythonErrorFragment (#7152)
by @gibsondan
[oss telemetry] Get rid of telemetry version (#6760)
by @dpeng817
only show warning when force termination checkbox is checked (#7157)
by @prha
rename several internal submodules (#7134)
by @smackesey
Remove another cron from example dockerfile (#7155)
by @gibsondan
Be more willing to return serialized errors in schedule/sensor/grpc partition methods (#7164)
by @gibsondan
docs: fix spelling (#7166)
by @antquinonez
[multiprocess] tweak preload modules logic (#7142)
by @alangenfeld
feat(dagster-k8s): add run id label to run/step workers (#7167)
by @rexledesma
docs(logging): remove example about capturing from the root logger (#7168)
by @rexledesma
docs: fix typo in job/graph concepts page (#7172)
by @antquinonez
[docs] fix dynamic graph examples (#7174)
by @alangenfeld
Fix inclusion of tests in our published packages (#7169)
by @smackesey
RFC: add partition tags to partitioned config (#7111)
by @prha
add gcs pickle asset manager to api docs (#7177)
by @jamiedemaria
[dagster-databricks] better retry support for step launchers (#7171)
by @OwenKephart
fix lint/mypy failures (#7183)
by @prha
Automation: versioned docs for 0.14.6
by @elementl-devtools
0.14.6 changelog (#7184)
by @jamiedemaria
update docs on Dict type (#7179)
by @jamiedemaria
docs: use word "op" instead of "solid" (#7195)
by @joe-hdai
refactor: rename is_failure to is_failure_or_canceled (#7200)
by @rexledesma
Time window partitions with custom minute, hour, day offsets (#7125)
by @jamiedemaria
Fixup ECS docs (#7193)
by @jmsanders
Update version placeholder "dev" to "0+dev" (#7175)
by @smackesey
fix: prevent runs filter from accepting an empty list of run ids (#7217)
by @rexledesma
refactor: remove screenshots (#7225)
by @rexledesma
refactor: remove scala modules (#7226)
by @rexledesma
get MetadataValue.dagster_run to show up in apidoc (#7231)
by @sryza
Azure asset IO Manager (#7201)
by @jamiedemaria
PartitionedConfig testing helpers (#7216)
by @jamiedemaria
[postgres] dont dispose engine in watch thread (#7241)
by @alangenfeld
feat(helm): add configuration for Dagster telemetry (#7190)
by @rexledesma
add some type annotations for code loading (#7244)
by @sryza
feat: add alert failure event (#7238)
by @rexledesma
[dagit] Remove the Asset Node context menu (#7151)
by @bengotow
Only consider repos defining the asset with a corresponding op for multiple repo notice (#7186)
by @bengotow
[dagit] Fix Gantt chart layout hang on certain graphs, round 2 #6942 (#7188)
by @bengotow
[dagit] If re-executing from failure fails, default to from failure again #5019 (#7189)
by @bengotow
[dagit] Ignore source assets for “Materialize All” button (#7196)
by @bengotow
[dagit] Load “Launch Asset partitions” modal when it’s opened + every time (#7207)
by @bengotow
[dagit] Explicitly add the dagster/step_selection tag to asset runs (#7213)
by @bengotow
Remove redundant k8s launcher event (#7250)
by @johannkm
Allow asset observations in IO Managers (#6653)
by @clairelin135
update docs for adls2 asset io manager (#7252)
by @jamiedemaria
0.14.7 changelog (#7256)
by @OwenKephart
Update CHANGES.md
by @prha
Automation: versioned docs for 0.14.7
by @elementl-devtools
fix typecheck for In.dagster_type (#7242)
by @smackesey
[dagit] RunTimeline: Fix overlap with ongoing run (#7245)
by @hellendag
[dagster-io/ui] Remove WIP suffixes (#7229)
by @hellendag
[dagit] Modify "Open in Launchpad" from Run (#7263)
by @hellendag
RFC: Add register_run_asset event (#7098)
by @clairelin135
Add table to keep track of schedule data migrations 1/5 (#7182)
by @prha
add schema for instigators table, keyed by selector 2/5 (#7185)
by @prha
double-write selector_id to ticks, jobs, instigators 3/5 (#7191)
by @prha
add tick selector index migration (#7198)
by @prha
Read instigator state / ticks off of selector_id instead of origin id 5/5 (#7268)
by @prha
[dagster-io/ui] Declaration files for TS, Rollup for built JS (#7220)
by @hellendag
Ensure telemetry logging dir is created before using logger (#7192)
by @dpeng817
cross-repo assets toy (#7210)
by @sryza
update apidoc for non_argument_deps (#7271)
by @clairelin135
enable loaded_input metadata entries to display in Dagit (#7255)
by @clairelin135
[@dagster-io/ui] Cleanup for publish (#7270)
by @hellendag
Remove empty k8s_job_task file (#7286)
by @johannkm
Add MenuLink shim for internal compatibility (#7297)
by @hellendag
Avoid mentioning pipelines in Dagit empty state (#7288)
by @sryza
fix invariant in batch tick loader (#7280)
by @prha
[dagster-airbyte] fix airbyte materializations without streamStats (#7281)
by @OwenKephart
point top-level workspace to latest toys (#6876)
by @sryza
[dagster-io/ui] Eliminate RR dependency (#7285)
by @hellendag
fix selector injection for k8s-celery test (#7307)
by @prha
remove experimental warning for mysql storage (#7290)
by @prha
make some edits to changelog (#7264)
by @prha
[@dagster-io/ui] Clean up deps (#7302)
by @hellendag
[dagit] Fix config refresh when reloading repo (#7325)
by @hellendag
[@dagster-io/ui] Prepare for 1.0.3 (#7326)
by @hellendag
Add run_id as execute_in_process arg (#7317)
by @dpeng817
Fixes to root input manager memoization and no context provided (#7316)
by @dpeng817
add apple m1 instructions to contributor guide (#7279)
by @jamiedemaria
Fix celery docker executor failing on None metadata (#7330)
by @jamiedemaria
replace old celery docs site (#7331)
by @jamiedemaria
[dagster-dbt] fix issue w/ conflicting dbt op names for assets (#7311)
by @OwenKephart
docs infra: remove github/slack bot from docs site (#7315)
by @yuhan
[dagit] Fix CodeMirror show-hint error (#7334)
by @hellendag
0.14.8 Release Notes (#7336)
by @clairelin135
add email icon (#7346)
by @salazarm
[dagit] Don't show instigation switch for assets (#7347)
by @hellendag
[dagit] Add "Copy config" button to "View tags and config" dialog (#7348)
by @hellendag
[dagit] Allow toggling repos in bulk (#7344)
by @hellendag
[dagit] Store whitespace state in localStorage (#7350)
by @hellendag
[dagit] Adjust details in Run header (#7345)
by @hellendag
[dagit] Add feature flag to collapse the left Jobs navigation by default (#7204)
by @bengotow
Automation: versioned docs for 0.14.8
by @elementl-devtools
update README - include github discussion (#7339)
by @yuhan
[@dagster-io/eslint-config] Create shared config (#7328)
by @hellendag
[@dagster-io/eslint-config] Fix dependencies (#7354)
by @hellendag
Add Slack icon (#7355)
by @salazarm
support container kwargs for celery-docker (#7335)
by @jamiedemaria
[dagster-dbt] Add /runs method to DbtCloudResourceV2 (#7258)
by @kstennettlull
[dagster-dbt] add "build" to DBT_RUN_RESULTS_COMMANDS (#7362)
by @OwenKephart
[dagit] Show timestamps for “failed to start” runs, other metadata tweaks (#7359)
by @bengotow
Fix contention bug in windows (#7353)
by @dpeng817
fix dagster-ge library (#7369)
by @prha
have fs io manager record path metadata entry (#7261)
by @sryza
AssetGroup.materialize_in_process (#7260)
by @sryza
Add authenticator field to conn_args (#6983)
by @swotai
Make shell ops inherit env vars from outside environment (#6513)
by @kbd
Allow jobs to be passed in lazily to repository definitions (#7382)
by @gibsondan
[dagit] Make the “Latest Run” tag on the Job page auto-refresh (#7360)
by @bengotow
[dagit] Move data fetching for the asset graph into hooks (#7363)
by @bengotow
autodiscover assets at module scope (#7247)
by @sryza
[hacker news] pin duckdb (#7390)
by @alangenfeld
Let InProcessRepositoryLocationOrigin take in multiple repos (#7386)
by @gibsondan
[dagster-fivetran] Fix format strings (#6436)
by @mgasner
[dagster-airbyte] Handle 204 reponse in Airbyte Library (#7209)
by @HAMZA310
run materializations (#7394)
by @prha
[dagit] Fix default Dagit page in single repo, multiple jobs case (#7368)
by @bengotow
Add grpc server timeout config to instance settings (#7387)
by @gibsondan
infer resource descriptions from docstrings (#7309)
by @sryza
[dagit] Async layout of large asset graphs (#7366)
by @bengotow
[dagit] Align terminology and data structures in asset / op graph layout (#7372)
by @bengotow
[dagit] Move asset-graph out of workspace dir, non-graph code to /assets (#7373)
by @bengotow
Update AssetKeyTable.last_run_id upon materialization planned (#7319)
by @clairelin135
asset tutorial (#7269)
by @sryza
Add a field to the now-somewhat-poorly-named RepositoryPythonOrigin that can add 'deployment target' information within a repo location (#6925)
by @gibsondan
Add EcsContainerContext (just with secrets for now) (#7176)
by @gibsondan
Add K8sContainerContext for configuring k8s pods from the repository location (#7203)
by @gibsondan
Fixed typo in deploying-with-helm.mdx (#7416)
by @LeoHuckvale
[dagit] Use react-scripts@5.0.2 (#7393)
by @hellendag
[dagit] Add arrow key and double click interactions to asset graph #6407 (#7374)
by @bengotow
[dagit] Allow colon in run tag value (#7409)
by @hellendag
Re-execute run instance method (#7417)
by @johannkm
skip adls test (#7420)
by @jamiedemaria
add open launch pad to run details page (#7304)
by @salazarm
Fix prerequisite typos in docs (#7424)
by @johannkm
[@dagster-io/eslint-config] Enable object-shorthand (#7423)
by @hellendag
Filter out asset_materialization_planned event logs client-side (#7397)
by @clairelin135
Make user repo filters per deployment (#7376)
by @salazarm
[postgres] urlquote usernames as well (#7430)
by @alangenfeld
[toys] squelch warnings (#7419)
by @alangenfeld
docs for gRPC sever timeout flag (#7400)
by @gibsondan
Fix master and add DagsterEventType import (#7435)
by @clairelin135
avoid extra experimental warning when asset has partitions def (#7431)
by @sryza
Add option to disable max_concurrent_runs (#7327)
by @johannkm
RFC: Fetch Cross-Repo Asset Deps (#7259)
by @clairelin135
make k8s container context volumes and volume mounts use snake case, not camel case (#7437)
by @gibsondan
move expensive tests out of core_tests (#7436)
by @gibsondan
allow AssetGroups to have assets with different partitions defs (#7388)
by @sryza
Update key for saving data in useExecutionSessionStorage (#7333)
by @salazarm
asset partitioned io manager (#7413)
by @sryza
Unbreak stopping unloadable schedules/sensors (#7446)
by @gibsondan
[dagit] Check for asset group job prefix to support multiple groups per repo (#7418)
by @bengotow
changelog for 0.14.9 (#7450)
by @sryza
update isort comment formatting (#7448)
by @smackesey
bump black to 22.3.0 (#7449)
by @smackesey
Automation: versioned docs for 0.14.9
by @elementl-devtools
Typo in the create a new project doc (#7441)
by @ascrookes
Fix issue with blank telemetry instance id file (#7433)
by @dpeng817
Show repo selector in unloadable schedules/sensors instead of repo location metadata (#7444)
by @gibsondan
Split up screenshot specs (#7460)
by @sryza
resource dependencies for root input managers (#7459)
by @sryza
avoid framework code triggering metadata_entries warning (#7412)
by @sryza
allow combining memoization with step selection (#6431)
by @sryza
refactor: remove local storage file that was committed (#7440)
by @rexledesma
[dagster-graphql] remove gevent (#7402)
by @alangenfeld
[dagit] Apply middle truncation to long asset nodes, hide run info (#7187)
by @bengotow
[dagit] Use CodeMirror for all config displays (#7467)
by @hellendag
Add container_context to gRPC server and Helm chart (#7236)
by @gibsondan
Add asset metadata to one of the dagster_test asset groups (#7462)
by @bengotow
Fix back-compat for new helm chart param for container context (#7476)
by @gibsondan
[graph] use the correct input definition for type checks (#7453)
by @alangenfeld
[dagit] Repair async graph layout for path-prefix (#7480)
by @hellendag
Add docs to k8s docs about includeConfigInLaunchedRuns (#7477)
by @gibsondan
Acquire leases when using ADLS (#7410)
by @jamiedemaria
Update Materialization Warning (#7265)
by @clairelin135
[dagit] Fix Suggest (#7489)
by @hellendag
Make the scheduler/sensor daemons key the schedules that it inspects by selector ID, not origin ID (#7492)
by @gibsondan
Add right of search bar prop to top nav (#7500)
by @salazarm
add flag argument to backfill all partitions in launch backfill graphql mutation (#7499)
by @prha
[dagit] Fix job header “View assets” link, add missing graphQL types (#7493)
by @bengotow
fix sqlite gating logic for batch tick queries (#7505)
by @prha
[dagster-census] Census Integration Library (#7249)
by @dehume
[dagit] Show a better error on invalid run filters (#7494)
by @hellendag
Add log message to grpc health check (#7506)
by @johannkm
refactor: remove duplicate solids in event log test (#7511)
by @johannkm
correct workspaces icon (#7504)
by @salazarm
[dagit] More cleanup of query callsites performing background polling (#7508)
by @bengotow
[dagit] Avoid resetting hidden repos on each page load #7519 (#7520)
by @bengotow
[dagit] Allow disabling keyboard shortcuts (#7515)
by @hellendag
Update pylint and associated config (#6517)
by @smackesey
0.14.10 Changelog (#7521)
by @johannkm
fix asset partitions runtime check (#7525)
by @smackesey
[dagit] Tiny fix for “asset graph search, dropdown stops showing when ">" character is used” (#7514)
by @bengotow
[dagit] Move yarn analyze to packages/app (#7523)
by @hellendag
[dagit] Clean up lodash imports (#7526)
by @hellendag
[dagit] Display repositories in a stable order (#7518)
by @bengotow
Automation: versioned docs for 0.14.10
by @elementl-devtools
[hooks] fix resource reqs in nested graphs (#7529)
by @alangenfeld
[instigator] dont throw in start/stop if already in desired state (#7483)
by @alangenfeld
[dagit] Fix InstigationTick "Skipped" message if zero runs (#7527)
by @hellendag
Get rid of mode in JobDefinition constructor (#7497)
by @dpeng817
Fix issue where we were calling the partition function n times, where n is the number of partitions returned by the function (#7539)
by @gibsondan
[bugfix] Check that oldData is defined before trying to migrate (#7537)
by @salazarm
Assorted tox updates (#6971)
by @smackesey
0.14.11 changelog (#7543)
by @gibsondan
Automation: versioned docs for 0.14.11
by @elementl-devtools
Reexecute run mutation using just parent run (#7510)
by @johannkm
Updated changelog for 0.14.12 (#7545)
by @gibsondan
Revert "[bugfix] Check that oldData is defined before trying to migrate (#7537)" and "Update key for saving data in useExecutionSessionStorage (#7333)" (#7551)
by @gibsondan
[graphql] subscription handle_graphql_errors (#7482)
by @alangenfeld
Automation: versioned docs for 0.14.12
by @elementl-devtools
[dagit] Add bulk re-execution dialog to Runs page (#7451)
by @hellendag
Downgrade tox pip for Python 3.6 (#7547)
by @smackesey
annotate dagster.builtins.Nothing with correct type (#7546)
by @smackesey
Pylint: Add encoding to open() (#7548)
by @johannkm
asset op tags (#7472)
by @sryza
[dagit] Show asset “compute kind” in the global asset graph (#7516)
by @bengotow
[dagit] Hide __asset_group partition sets from search bar (#7556)
by @bengotow
Add typing-extensions >=3.10 as dependency. (#7555)
by @smackesey
validate tags in partition sets (to turn dicts into strings) (#7554)
by @gibsondan
[dagit] Feature flag for disabling WebSocket usage (#7557)
by @hellendag
[dagit] Add opNames field to AssetNode (#7565)
by @hellendag
add DEFAULT_PYTHON_VERSIONS env var for BK (#7553)
by @smackesey
add DEFAULT_PYTHON_VERSIONS env var for BK (#7553)
by @smackesey
[1/n] Interop Stack: Use AssetJobInfo at runtime instead of OutputDefinition (#7473)
by @OwenKephart
[2/n] Interop Stack: Use AssetJobInfo to construct ExternalAssetNodes (#7475)
by @OwenKephart
[dagit] Introduce sticky table headers (#7568)
by @hellendag
[dagit] Truncate global search result list (#7569)
by @hellendag
Test test_create_reexecuted_run_from_failure (#7566)
by @johannkm
Tag behavior option for reexecute method (#7574)
by @johannkm
add setuptools as dep (#7576)
by @smackesey
fix errors (#7577)
by @smackesey
Register a new task definition for IAM changes (#7564)
by @jmsanders
Improve typing of schedule/sensor and hooks (#7560)
by @smackesey
All steps option for rexecute method (#7575)
by @johannkm
[docs] fix multi asset sensor example (#7583)
by @alangenfeld
Create runs during event log tests (#7502)
by @johannkm
[dagit] Refactor ExecutionSessionStorage (#7559)
by @hellendag
fix(helm): support numeric type image tags (#7579)
by @jrouly
[dagit] Add bulk re-execution of all steps (#7591)
by @hellendag
ResourceDefinition.none_resource instead of no_step_launcher (#7381)
by @sryza
Remove unused imports from event log tests (#7592)
by @johannkm
[dagit] Fix asset graph navigation edge cases (#6955, #7208) (#7532)
by @bengotow
fullbuild in branch name for full BK build (#7595)
by @smackesey
document partitioned assets (#7466)
by @sryza
fix secretsmanager example doc (#7593)
by @prha
Add ConfigSchema type alias (#7596)
by @smackesey
lint dagster_tests (#7594)
by @alangenfeld
add dialect-specific update logic (#7572)
by @prha
fix volumes example for docker run launcher (#7607)
by @gibsondan
[tests] set platform on docker build (#7603)
by @alangenfeld
Use explicitly set env vars rather than autoenvvar prefixes for the grpc command (#7611)
by @gibsondan
Fixes for running the user-code-deployment helm chart in a different namespace than the system namespace (#7597)
by @gibsondan
standardize additional_message kwarg in check methods (#7605)
by @smackesey
[3/n] Interop Stack: Remove asset key from inputs/outputs (#7550)
by @OwenKephart
fix(helm): allow max concurrent runs to be 0 (#7618)
by @rexledesma
[4/n] Interop Stack: node_def on AssetsDefinition can be graph (#7573)
by @OwenKephart
Asset key to node handle mapping (#7599)
by @clairelin135
[dagster-aws] update emr pyspark step launcher (#7604)
by @OwenKephart
Make dagster-user-deployments service account set up a role and role binding by default, like the main dagster chart service account (#7622)
by @gibsondan
Add resources to K8sContainerContext (#7619)
by @gibsondan
[dagit] Add "shared key path" outlines, experimental asset graph flag (#7608)
by @bengotow
[@dagster-io/ui] Separate tsconfig for build (#7584)
by @hellendag
Fixup XXXSource docs (#7629)
by @gibsondan
Changelog 0.14.13 (#7631)
by @dpeng817
AssetGroup.prefixed (#7395)
by @sryza
AssetsDefinition.from_graph (#7620)
by @clairelin135
[Testing] Support for resolvers in ApolloTestProvider (#7612)
by @salazarm
[dagit] Show default value for config (#7598)
by @hellendag
[docker] improve test time (#7589)
by @alangenfeld
Update mypy config and bump version (#7625)
by @smackesey
[dagster-ge] drop 3.6 (#7638)
by @alangenfeld
Automation: versioned docs for 0.14.13
by @elementl-devtools
Unify all alembic scripts into single directory, creating single history (#7411)
by @prha
enable mypy checking on dagit (#7626)
by @smackesey
[dagit] Add dummy graphName field to AssetNode (#7637)
by @hellendag
[RFC] lighter weight pull request template (#7538)
by @alangenfeld
[dagit] AssetView: Don't show historical view message if it's not (#7639)
by @hellendag
allow flexible types for SourceAsset key arg (#7633)
by @sryza
add graphql fields to quickly query partition status (#7614)
by @prha
add option to GraphQueryInput to apply changes without hitting enter (#7635)
by @prha
Refactors the PartitionGraph component to be divorced from the actual graphql query (#7616)
by @prha
Adds a new partition page behind a feature flag (#7617)
by @prha
enable adding asset groups together (#7634)
by @sryza
Fix mypy config for dagster main package (#7644)
by @smackesey
allow multiple asset groups on a repository (#7649)
by @sryza
refactor: remove airline demo (#7653)
by @rexledesma
to_source_assets (#7643)
by @sryza
adding a Terminate Run method for in-progress execution to the Python GraphQL client (#7443)
by @Javier162380
fix apidoc for fs io manager (#7671)
by @sryza
Fix celery docker jobs that involve writing directly to command-line output (#7665)
by @gibsondan
Fix docs lib links (#7680)
by @johannkm
Fix configmaps that need to be manually set when running the user deployments helm chart in a different namespace (#7660)
by @gibsondan
Add all repos to hacker_news __init__.py (#7677)
by @gibsondan
remove primitive types from apidoc (#7674)
by @sryza
Add py.typed to dagster and all extension libs (#7561)
by @smackesey
[eslint-config] Bump dependencies (#7681)
by @hellendag
[dagster-airbyte] terminate airbyte sync w python process (#7687)
by @OwenKephart
[dagster-dbt] remove annoying color formatting strings from log output (#7688)
by @OwenKephart
Pull out PostgresEventWatcher into its own module and parameterize it more (#7666)
by @gibsondan
graph and job apidoc fixes (#7673)
by @sryza
docs: fix example for multiprocess run config (#7693)
by @rexledesma
finish dagster-fivetran types (#7563)
by @smackesey
finish dagster-airbyte types (#7562)
by @smackesey
chore(graphql): add linter to ensure docstrings on graphene graphql objects (#7669)
by @rexledesma
docs(graphql): add docstrings to mutations.py (#7691)
by @rexledesma
Move EventSpecificData out of TYPE_CHECKING (#7697)
by @smackesey
Add ability to set mapping key on op/solid invocation context (#7364)
by @dpeng817
Make Output generic (#7202)
by @dpeng817
update fake adls resource to work with leases (#7587)
by @jamiedemaria
add core partition status storage query (#7662)
by @prha
docs: specify the correct mysql event log module (#7703)
by @rexledesma
Revert "Make Output generic (#7202)" (#7715)
by @dpeng817
Add bool metadata type (#7694)
by @clairelin135
Add platform arg and other improvements to dagster-docker CLI (#7698)
by @smackesey
Add a guard around dagit's JSON parsing of incoming requests (#7714)
by @gibsondan
Switch new partition page to use more efficient partition status query (#7663)
by @prha
[docs] retry policy invocation example (#7716)
by @alangenfeld
docs: fix example with lazy loading repository (#7704)
by @rexledesma
update slack api call in op hook docs (#7712)
by @jamiedemaria
Improve Buildkite test version specification API (#7699)
by @smackesey
use ">" for multi-component selection in AssetGroup.build_job (#7661)
by @sryza
finish dagster-pagerduty types (#7668)
by @smackesey
enable providing asset_key to build_output_context (#7696)
by @sryza
[dagit] Support special cron strings (#7717)
by @hellendag
solid -> op in dagster-slack (#7684)
by @sryza
Typing additions (#7039)
by @smackesey
[instance] rm get_addresses_for_step_output_versions (#7601)
by @alangenfeld
Add run tags for repository/location names (#6893)
by @prha
Surface retried error in Dagit (#7692)
by @johannkm
RFC: Keep firing hooks even if a framework exception is raised mid-execution (#7652)
by @gibsondan
combine validate_tags and check_tags to JSONify nested tags (#7720)
by @gibsondan
test dynamic_output output for node (#7718)
by @clairelin135
[postgres] dont use urlquote_plus (#7723)
by @alangenfeld
[docs] fix jobs from graphs example (#7722)
by @alangenfeld
Make output generic (#7719)
by @dpeng817
Missed changes for Dagit surface retry error (#7731)
by @johannkm
Change head_bucket to list_objects. (#7485)
by @trevenrawr
RFC: include schema in default dbt asset keys (#7645)
by @sryza
populate op names and graph name for ExternalAssetNode (#7721)
by @OwenKephart
add extra sensor state fetch to minimize chance of clobber state (#7738)
by @prha
Workaround for mypy cache bug (#7732)
by @smackesey
fix run list for new partitions view (#7742)
by @prha
0.14.14 changelog (#7743)
by @prha
Make Output and DynamicOutput no longer be tuple types (#7740)
by @dpeng817
[dagit] Use a CSP header instead of meta tag (#7727)
by @hellendag
Add a test with various wait/act use cases (#7728)
by @hellendag
Add job/op equivalents to execution context (#7734)
by @johannkm
Rename ReexecutionPolicy -> ReexecutionStrategy (#7746)
by @johannkm
[dagit] Update tsconfig to es2022, update browserslist (#7749)
by @hellendag
[dagit] Use Array flat (#7754)
by @hellendag
remove usable_as_dagster_type from integrations (#7682)
by @sryza
Automation: versioned docs for 0.14.14
by @elementl-devtools
enable returning lists of run requests from sensor/schedule evaluation functions (#7755)
by @prha
remove usable_as_dagster_type from types concept page (#7758)
by @sryza
[easy] fix missing space in error message for util function (#7761)
by @gibsondan
[dagit] Add more security headers (#7764)
by @hellendag
Additional asset graph improvements (#7707)
by @bengotow
[dagit] Add Reload All button to the asset catalog, remove repo filter (#7708)
by @bengotow
[dagit] Better indentation guide in our CodeMirrors (#7765)
by @hellendag
Allow python objects to be passed as top-level inputs to job (#7032)
by @dpeng817
Add a static method on DefaultRunLauncher that launches a run without a workspace (#7777)
by @gibsondan
Revert "Allow python objects to be passed as top-level inputs to job (#7032)" (#7779)
by @dpeng817
Allow repositories to contain asset definitions and source assets for the same asset key (#7781)
by @sryza
fix error message when can't find upstream asset for dep (#7648)
by @sryza
Allow TextInput to have a type of number (#7778)
by @salazarm
fix error with inferring description from empty docstring (#7788)
by @sryza
[dagit] Add hover actions to run Tags (#7751)
by @hellendag
Fixes to the apidocs page (#7729)
by @sryza
[dagit] Show asset nodes on Asset Details (#7689)
by @hellendag
[dagit] Make log filter input clearable (#7805)
by @hellendag
[eslint-config] Add recommended jest lint (#7807)
by @hellendag
pin xmltodict to fix aws test failures, until moto 3.1.9 (#7806)
by @prha
update s3 sensor docs to use context.cursor instead of context.last_run_key (#7748)
by @prha
Add namespaces / prefixes to the hacker news assets demo (#7782)
by @sryza
toposort frozenset workaround (#7793)
by @smackesey
Increase executor event log poll interval (#7803)
by @johannkm
Add a few __init__.py in test packages (#7809)
by @smackesey
remove TableSchema experimental warnings (#7799)
by @smackesey
snowflake io manager (#7726)
by @sryza
Change the fake repo that simulates an import error while loading dagster code (#7816)
by @gibsondan
remove jinja / nbconvert pin (#7819)
by @prha
[dagit] Use
/instead of
> for displaying asset paths (#7818)
by @bengotow
fix snowflake io manager tests on python 3.7 (#7824)
by @sryza
link to examples in concepts pages (#7753)
by @jamiedemaria
[docs] job execution (#7776)
by @alangenfeld
[dagit] Clean up my todos (#7810)
by @hellendag
[dagit] Fix global search for repeated item keys (#7827)
by @hellendag
sys.meta_path import mapping layer (#7040)
by @smackesey
Allow passing posargs to tox commands (#7822)
by @smackesey
Rename check > _check (#7808)
by @smackesey
context.partition_time_window (#7795)
by @sryza
take out airline demo from make dev_install (#7839)
by @sryza
[dagit] Make schedule/sensor tags more prominent in RunTags (#7834)
by @hellendag
add BoolMetadataValue to __all__ in dagster/__init__.py (#7838)
by @sryza
[dagit server] guard on async websocket send (#7833)
by @alangenfeld
[top-level inputs 1/2] Move InvalidSubsetError try-catch up a level (#7780)
by @dpeng817
docs design update (#7531)
by @yuhan
Remove test-connection pod (#7842)
by @gibsondan
remove validate_asset_key_string (#7811)
by @sryza
partitioned assets from graphs (#7837)
by @sryza
fallback logic for resolvers (#7766)
by @OwenKephart
migrate concept docs code snippet paths to graph/job/op (#6775)
by @sryza
[rfc] generic + returnable dynamic outputs (#7744)
by @dpeng817
[dagster-dbt] dbt build + AssetObservations from tests (#7783)
by @OwenKephart
[dagit] New “folder grid” asset view behind experimental flag (#7767)
by @bengotow
Handle backcompat asset observation (#7831)
by @clairelin135
[dagit] Remove search item key (#7830)
by @hellendag
use generic Output type annotations in hacker news (#7600)
by @sryza
changelog 0.14.15 (#7850)
by @yuhan
[dagit] add log-level flag (#7853)
by @alangenfeld
[changelog][skip ci] dagit line and autofmt (#7857)
by @alangenfeld
[dagit] tweak websocket disable (#7860)
by @alangenfeld
Limit pods per run with k8s_job_executor (#7846)
by @johannkm
additions to the 0.14.15 changelog (#7856)
by @sryza
fix asset key prefixes in MDS assets example (#7855)
by @sryza
[helm] dagit.logLevel (#7862)
by @alangenfeld
warn for instance.get_event_records calls without an event type filter (#7848)
by @prha
[top-level inputs 2/2] top level inputs on job and execute_in_process (#7786)
by @dpeng817
Automation: versioned docs for 0.14.15
by @elementl-devtools
rm duplicate changelog entry from navigation (#7873)
by @gibsondan
Fix error message assertions in Helm tests (#7858)
by @johannkm
Toxfile adjustments (adding mypy) (#7867)
by @smackesey
[resources on repos 1/n] Reorganize job/pipeline/graph duplication error logic in repository (#7817)
by @dpeng817
docs: fix vercel build (#7876)
by @yuhan
enable @asset-decorated functions to accept kwargs (#7871)
by @sryza
fix type error (#7887)
by @smackesey
dagster-dbt types (#7878)
by @smackesey
Add health check for ECS tasks (#7695)
by @jamiedemaria
[cloud dagit] Add optional nav tabs parameter for settings root page (#7892)
by @benpankow
feat(helm): support custom configmap for workspace (#7882)
by @johannkm
add data migration for run repo tags (#7815)
by @prha
make docker_compose_cm a contextmanager rather than a fixture (#7905)
by @gibsondan
[@dagster-io/eslint-config] v1.0.4 (#7913)
by @hellendag
docs: fix flash white box (#7877)
by @yuhan
InputContext.upstream_output is missing key when source asset (#7919)
by @sryza
remove handle_schema_errors that wrap db errors with schema outdated exceptions (#7886)
by @prha
Enable asset partitioning support for @multi_asset defined assets (#7908)
by @aroig
update multiple dynamic outs example (#7917)
by @jamiedemaria
dagster-databricks mypy (#7879)
by @smackesey
[1/n] Subsetting Stack: use subset_selector for AssetGoup.build_job (#7796)
by @OwenKephart
Don't call it a 'framework error' when a run worker unexpectedly restarts (#7885)
by @gibsondan
chore(helm): remove local from compute log manager options (#7924)
by @rexledesma
Executor and dagster-docker typing (#7881)
by @smackesey
remove markupsafe pin (#7898)
by @bollwyvl
[2/n] Subsetting Stack: AssetsDefinition subsetting (#7797)
by @OwenKephart
fix docstring (#7948)
by @OwenKephart
RFC: Better error handling when an ExternalRepository grpc call fails (#7929)
by @gibsondan
Use correct configured link in resources (#7949)
by @gibsondan
add CLI command to print the storage schema version (#7910)
by @prha
[dagit] Present location reload errors after “Workspace > Reload All” (#7907)
by @bengotow
[dagit] Asset details: Graph/op links (#7655)
by @hellendag
Fix detection of parent process death (#7914)
by @aroig
Merge identical get_location and get_repository_location methods (#7952)
by @gibsondan
add missing check to AssetsDefinition.from_graph (#7960)
by @sryza
Fix issue where azure IO manager was sometimes failing on recursive deletes (#7956)
by @gibsondan
make input defs deterministic (#7957)
by @clairelin135
[events] can_load mitigation (#7955)
by @alangenfeld
fix slack image link on Getting Started (#7964)
by @yuhan
Typing for automation package (#7812)
by @smackesey
make StepLauncher and friends public (#7945)
by @smackesey
feat(helm): bump minimum supported kubernetes version to 0.19 (#7925)
by @rexledesma
Asset Subselection (#7835)
by @clairelin135
various fixes for new partition page (#7950)
by @prha
[dagster-airbyte] don't cancel completed syncs (#7888)
by @OwenKephart
[dagster-dbt] small tweaks (#7967)
by @OwenKephart
Error rather than warn when an event log query comes in that tries to use an int cursor on an event log DB that needs a RunShardedEventsCursor (#7970)
by @gibsondan
Still make cursor editable if it is not set (#7969)
by @gibsondan
[daemon] tweak per-thread instance/workspace setup (#7965)
by @alangenfeld
Revert "feat(helm): bump minimum supported kubernetes version to 0.19 (#7925)" (#7968)
by @rexledesma
0.14.16 Changelog (#7976)
by @johannkm
fix reexecution (#7980)
by @clairelin135
Automation: versioned docs for 0.14.16
by @elementl-devtools
[dagit] Fix SearchBootstrapQuery to be lazy (#7981)
by @hellendag
split graphql query for the backfill page (#7986)
by @prha
Remove can_terminate from run launchers and run coordinators, use a status check instead in graphql (#7983)
by @gibsondan
style(helm): remove unnecessary pylint suppressions (#7923)
by @rexledesma
provide job_timeout_in_seconds in dataproc resource config (#7941)
by @3cham
[dagit] Replace opName with opNames everywhere (#7977)
by @hellendag
Set default hour of day and minute of hour in build_schedule_from_partitioned_job based on the offsets of the parittioned job (#7954)
by @gibsondan
WIP: Don't fetch every single run in the InstanceBackfillsQuery (#7985)
by @gibsondan
[dagit] Show assets on run pages in more scenarios (#7874)
by @bengotow
[dagit] Do not display the partition_set, step_selection tags on asset group runs (#7953)
by @bengotow
[dagit] WebSocketProvider: Time out and fall back to disabled (#7978)
by @hellendag
Coerce asset_key on AssetIn (#8009)
by @aroig
Fix issue where we added the run ID repeatedly to the runs for the tick during scheduler failure recovery (#8003)
by @gibsondan
Load fewer backfills on each page (#7998)
by @gibsondan
add loading indicator for job backfills (#8004)
by @prha
Remove duplicate count_resume_run_attempts method (#7915)
by @johannkm
Make asset related checks more robust (#8008)
by @aroig
Fix relative path for pytest fixture in backcompat tests (#7999)
by @dpeng817
feat(helm): allow name override for Dagit deployment (#8005)
by @rexledesma
Add a __main__.py to dagster/daemon (#8012)
by @gibsondan
dagster-buildkite refactor (#7813)
by @smackesey
Fix unsightly scrollbar in custom alert (#8018)
by @gibsondan
create get_records_for_run for event log storage, using an opaque string cursor (#7973)
by @prha
Fix error when dagit passes in a non-dict string to run config valiation (#8020)
by @gibsondan
[dagster-io/ui] Fix Dialog header/footer alignment (#7975)
by @hellendag
[dagit] Disable unloadables if no permissions (#8021)
by @hellendag
use mkdir -p in migration guide
by @johannkm
[dagit] Sectioned left nav (#8017)
by @hellendag
Handle InvalidSubsetError in launch run results (#8014)
by @gibsondan
Use dagster-postgres in alembic migration guide (#7992)
by @johannkm
Generate buildkite headers inside dagster-buildkite (#7987)
by @smackesey
bug fix: should allow re-executing all dynamic steps generated from mapper step (#7979)
by @yuhan
refactor: has_index for migrations (#8034)
by @johannkm
In-progress indicator for graph-backed assets (#8015)
by @clairelin135
resource defs on asset def (#7918)
by @dpeng817
Load all code artifacts on grpc server startup, not just pipelines/jobs (#8040)
by @gibsondan
Accept string values for non_argument_deps (#8023)
by @shalabhc
add example Python incompatibilities on Py 3.6 (#8036)
by @smackesey
Add missing deps for docs-snippets and skip 36 in BK (#8048)
by @smackesey
docs: update readme with social links (#8046)
by @rexledesma
OpExecutionContext.output_asset_key (#7961)
by @sryza
Add missing method to SnowflakePandasTypeHandler (#8051)
by @gibsondan
[dagit] Flip section arrow in left nav (#8056)
by @hellendag
[dagster-io/ui] Make disabled+checked Switch state more obvious (#8033)
by @hellendag
[dagit] Enable sectioned left nav by default (#8039)
by @hellendag
[3/n] Subsetting Stack: dbt assets can be subset (#7798)
by @OwenKephart
Raise error upon incomplete graph-backed asset subset (#8041)
by @clairelin135
throw error for empty asset key (#8069)
by @smackesey
[dagit] Use dialog for multiple schedules/sensors in left nav (#8065)
by @hellendag
remove dynamic mapping and collect section from jobs concepts page (#7844)
by @sryza
grammar (#7984)
by @dwinston
Pass in engine rather than connection in SnowflakePandasTypeHandler (#8070)
by @gibsondan
[dagit] Launchpad: Show disabled "Scaffold" and "Remove" buttons instead of hiding them (#8066)
by @hellendag
chore(buildkite): mention user in private channel (#8071)
by @rexledesma
[dagster-dbt] allow for static manifest.json-based selection (#8047)
by @OwenKephart
[asset-resources 2/n][rfc] io manager defs directly on asset defs (#7920)
by @dpeng817
adding a FromSourceAsset StepInputSource (#7942)
by @OwenKephart
Add protobuf pin to dagster (#8078)
by @gibsondan
Skip flaky snowflake+pandas tests (#8081)
by @gibsondan
docs: revamp the README (#8052)
by @rexledesma
0.14.17 changelog (#8083)
by @smackesey
Fix upstream context handling in fs_asset_io_manager (#8007)
by @aroig
KnownState.ready_outputs (#8016)
by @alangenfeld
Automation: versioned docs for 0.14.17
by @elementl-devtools
chore: mark FileCache for deprecation in 0.15.0 (#7922)
by @rexledesma
remove step stats query (#8089)
by @clairelin135
Revert "throw error for empty asset key (#8069)" (#8093)
by @gibsondan
migrate from deprecated sqlalchemy methods (#7864)
by @alangenfeld
fix typos (#8090)
by @OwenKephart
Add skip for flaky grpc server test (#8097)
by @gibsondan
chore(buildkite): ignore notifications on canceled builds (#8099)
by @rexledesma
[dagit] Break apart LaunchpadSessionContainer (#8101)
by @hellendag
[dagit] Small changes to the asset catalog (#7993)
by @bengotow
[dagit] Track partition set sort order for Launchpad (#8104)
by @hellendag
Lint rule to make sure queries requiring QueryVariables have them (#8102)
by @salazarm
Make dagster-images build work when it is called outside of a git repo (#8088)
by @gibsondan
Fix configuration schema for k8s executor (#8107)
by @fahadkh
[dagit] Clean up some yarn peer deps (#8108)
by @hellendag
Add latestRun resolver to AssetsLatestInfo (#8072)
by @clairelin135
Handle op outputs in default asset IO manager (#8074)
by @clairelin135
[dagit] Add last materialization, latest run columns to the asset table (#7996)
by @bengotow
fix(mypy): refine types (#8129)
by @rexledesma
[dagit] Remove the global asset graph in preparation for asset group graphs (#8125)
by @bengotow
[dagit] Rename isAssetGroup => isHiddenAssetGroupJob for clarity (#8124)
by @bengotow
fix(helm): allow numeric quoted strings as image tags (#8120)
by @rexledesma
docs: add a button to copy/paste code snippets (#8106)
by @yuhan
[asset-resources 4/n][rfc] Refactor resource requirement checking code (#7947)
by @dpeng817
fix(helm): use templated comment (#8137)
by @rexledesma
docs(helm): add doc hint for dagster-user-deployments.imagePullSecrets (#8112)
by @ceefour
Added group_name to asset (#8110)
by @shalabhc
Fix invocation on ops that use generic dynamic outputs (#8133)
by @dpeng817
[dagit] Show more information for last run on Schedules/Sensors (#8130)
by @hellendag
[dagit] Remove asset graph bundling based on path prefixes, experimental flag (#8127)
by @bengotow
KnownState parent run info (#8030)
by @alangenfeld
add metadata to jobs (#7849)
by @jamiedemaria
fix dagit-debug (#8148)
by @alangenfeld
add kwargs to pipeline snapshot from storage (#8149)
by @jamiedemaria
Fix label sanitization for strings that end in a period (#8151)
by @gibsondan
[dagit] Show counts next to log filter tags (#8141)
by @hellendag
increase test_ping timeout (#8150)
by @alangenfeld
[dagit] Fix duplicate styled-components (#8144)
by @hellendag
Basic asset config (#7590)
by @smackesey
Avoid launching ECS runs with large overrides (#8152)
by @jmsanders
Optionally tag images as latest (#8132)
by @jmsanders
chore(helm): christen the code server service port name as grpc (#8142)
by @calebfornari
feat(helm): allow the postgresql scheme to be configurable (#8126)
by @peay
[dagit] Remove clear-site-data header (#8134)
by @hellendag
[dagit] Allow run termination on queued run (#8157)
by @hellendag
[dagit] Add active state to left nav items (#8147)
by @hellendag
[asset-resources 5/n] io manager defs on source assets (#8105)
by @dpeng817
[dagster-io/eslint-config] v1.0.5 (#8121)
by @hellendag
fix(helm): use pre-2022 bitnami repository (#8166)
by @rexledesma
Asset config gql resolver (#8163)
by @smackesey
Allow environment variables in
dagster-mlflow schema (#7997)
by @chasleslr
changes (#8169)
by @OwenKephart
[dagit] asset Config (#8154)
by @smackesey
clean up create_pg_connection (#8165)
by @alangenfeld
[dagit] Add a Lineage tab to the Asset Details page (#8143)
by @bengotow
[easy] 0.14.18 => 0.14.19 in changelog (#8180)
by @gibsondan
revert "Scaffold Config" always enabled (#8181)
by @smackesey
Add asset groups to graphql (#8140)
by @shalabhc
[0.15.0] remove attempt count from step launching APIs (#8068)
by @alangenfeld
[dagit] Make the left nav stay open/closed (#8173)
by @hellendag
step launcher fix up (#8186)
by @alangenfeld
Explicit asset key args to assetsLatestInfo (#8178)
by @clairelin135
Improve documentation around Output objects and op output annotations. (#8139)
by @dpeng817
Automation: versioned docs for 0.14.19
by @elementl-devtools
Revert "Automation: versioned docs for 0.14.19" (#8190)
by @gibsondan
Automation: versioned docs for 0.14.19
by @elementl-devtools
[docs] - RFC: add a Learning More section to the asset tutorial [CON-17] (#8031)
by @sryza
Merge Asset IO functionality with Library IO managers (#8189)
by @clairelin135
let tag inherit pointer style (#8208)
by @salazarm
extract event connection to top-level graphql query (#8077)
by @prha
Fixes for asset graphql tests to make them easier to generalize and call with other graphql context fixtures (#8199)
by @gibsondan
[instance] rm events_for_asset_key and get_asset_events (#7602)
by @alangenfeld
Restrict group names to VALID_NAME_REGEX_STR (#8214)
by @shalabhc
[asset-resources 6/n] with_resources method (#8019)
by @dpeng817
fix encoding for windows test (#8227)
by @prha
Migration: add columns action_type and selector_id to bulk_actions (#7995)
by @johannkm
Create unified storage configuration for
dagster.yaml (#7283)
by @prha
Add image pull secrets to k8s container context (#8221)
by @gibsondan
[dagit] Update MenuLink to support a disabled state (#8200)
by @bengotow
[docs] - Document partitioned IO managers [CON-37] (#8191)
by @smackesey
ungate new partitions backfill (#8224)
by @prha
[dagit] Add top level Asset Group pages, Asset Groups in left nav (#8203)
by @bengotow
Fix upgrade story for new scheme field in postgres (#8220)
by @gibsondan
fix workspace.yaml formatting (#8182)
by @smackesey
docs: improve search 1/ (#8229)
by @yuhan
[dagit] Add asset group filter to the Asset Catalog (#8204)
by @bengotow
methods [1/2] (#8225)
by @clairelin135
Graph-backed asset IO Fix (#8171)
by @clairelin135
bring back source asset metadata (#8195)
by @sryza
[dagit] Asset graph GraphQL query audit + cleanup (#8205)
by @bengotow
[dagit] Remove flat left nav (#8231)
by @hellendag
[assets] cycle resolution (#8222)
by @OwenKephart
[docs] add multi_assets docs page [CON-33] (#8192)
by @OwenKephart
Assets now have a default group name (#8226)
by @shalabhc
Move config editor to core so we can reuse in admin portal (#8237)
by @salazarm
Renamed the prefix for auto created jobs from '__ASSET_GROUP' to '__ASSET_JOB'. (#8235)
by @shalabhc
Derive origin from pipeline run instead of the arg to ExecuteRunArgs (#8156)
by @gibsondan
unique name for assets in adls2 tests (#8232)
by @jamiedemaria
docs: improve search 2/ (#8244)
by @yuhan
AssetSelection (#8202)
by @smackesey
[for 0.15.0] default includeConfigInLaunchedRuns in helm chart to true (#7488)
by @gibsondan
[dagit] Don't block scroll when mouse hits custom tooltip (#8242)
by @hellendag
[dagit] Switch asset group pages to /list and /lineage instead of ?tab= (#8250)
by @bengotow
[docs] Asset Job Schedules/Sensors [CON-28, CON-29] (#8155)
by @clairelin135
[docs] - Document asset metadata [CON-31] (#8084)
by @erinkcochran87
[docs] - Upstream changes for assets [CON-36] (#8175)
by @erinkcochran87
add data migration to bulk actions table for backfill jobs (#8153)
by @prha
[docs] - Asset config [CON-89] (#8119)
by @erinkcochran87
[docs] - Update Ops & Asset pages for release [CON-21] (#8158)
by @erinkcochran87
Override resource defs when invoking assets (#8217)
by @dpeng817
Add resource defs to source asset, handle transitive dependencies (#8223)
by @dpeng817
asset defs directly on repository (#8197)
by @sryza
[docs] - Graph-backed assets [CON-34] (#8174)
by @erinkcochran87
methods [2/2] (#8236)
by @clairelin135
[assets] UnresolvedAssetJobDefinition (#8207)
by @OwenKephart
[dagster-dbt] update dbt keys (#8228)
by @OwenKephart
with_resources top level export (#8264)
by @dpeng817
chore(buildkite): separate docs only changes (#8261)
by @rexledesma
[docs] Asset storage description in filesystem IO Manager docs (#8240)
by @clairelin135
[dagit] Add Materialize button to the Asset Catalog (#8206)
by @bengotow
Added the default group name for assets defined using Out(...) (#8259)
by @shalabhc
[assets] Allow graph_name to be None when not specified (#8247)
by @bengotow
[dagit] Asset group styling adjustments, polish (#8246)
by @bengotow
add backfill blank state (#8267)
by @prha
Fix descriptor that only references solid (#8159)
by @dpeng817
add an "environment" key to EcsRunLauncher / EcsContainerContext that sets env vars (#8243)
by @gibsondan
[dagit] Add a Materialize All button to Asset Details > Lineage (#8248)
by @bengotow
[assets] Update modern-data-stack assets (#8271)
by @OwenKephart
[assets] fix tests (#8275)
by @OwenKephart
docs: improve search 3/ handle GH discussion entries in search results (#8252)
by @yuhan
[docs] - Cross-repository assets [CON-32] (#8075)
by @erinkcochran87
Fix hackernews after change to AssetGroup behavior (#8269)
by @dpeng817
[docs] - Document non-argument deps for assets [CON-16] (#7962)
by @erinkcochran87
assets_from_package_module -> load_assets_from_package_module (#8280)
by @dpeng817
validate resources for assets passed directly to a repository (#8270)
by @dpeng817
Standalone materialize method (#8268)
by @dpeng817
[0.15.0] move from warnings to errors for sensor/schedule target duplication (#7861)
by @dpeng817
refactor: remove FileCache (#7701)
by @rexledesma
[assets] add partition_def and config to define_asset_job (#8282)
by @OwenKephart
Add docs for top level job inputs (#8212)
by @dpeng817
default executor on repo (#8272)
by @dpeng817
Deprecate asset namespace (#8274)
by @smackesey
Fix black (#8288)
by @johannkm
Add kvs table to oss (#8213)
by @johannkm
[dagit] Hold the lineage graph zoom level constant as you navigate (#8251)
by @bengotow
Add max_retries to user editable tags (#8285)
by @johannkm
fix is_subclass bug where issubclass(list[str], DagsterType) throws a surprising exception (#8287)
by @gibsondan
take experimental decorators off of asset APIs (#8260)
by @sryza
fix group_name in to_source_assets (#8279)
by @sryza
KVS storage methods (#8249)
by @johannkm
[dagster-dbt] Fix bug where a dbt invocation that did not successfully start could emit materialization events. (#8293)
by @OwenKephart
Fix typo in multi_asset docstring (#8292)
by @johannkm
Make dagster/reexecution_strategy tag editable (#8286)
by @johannkm
asset selection tweaks (#8290)
by @smackesey
Revert "KVS storage methods (#8249)"
by @johannkm
only return config field for solids (#8278)
by @clairelin135
docs: fix white box flashing when navigating between pages (#8281)
by @yuhan
[dagit] Fix JS error on repo reload (#8297)
by @hellendag
[docs] - Move assets into intro tutorial + up in sidenav [CON-18] (#8241)
by @erinkcochran87
un-asset-group-ify SDA guide (#8283)
by @dpeng817
asset concepts page without AssetGroups (#7901)
by @sryza
0.14.20 Changelog (#8301)
by @johannkm
solid -> op in message for omitted outputs (#7903)
by @sryza
[docs] - Resources in assets [CON-27] (#8168)
by @erinkcochran87
[docs] - SDA guide for existing Dagster users [CON-30] (#8188)
by @sryza
fix subclass test on py36 (#8302)
by @gibsondan
[dagit] Repair issue where last ten runs are missing for job (#8305)
by @hellendag
Deprecate AssetGroup (#8276)
by @smackesey
remove experimental materialization tags (#6650)
by @prha
Automation: versioned docs for 0.14.20
by @elementl-devtools
[docs] - Remove advanced tutorials [CON-290] (#8298)
by @erinkcochran87
RFC: asset tutorial without AssetGroups (#7909)
by @sryza
[dagit] Don’t let description overflow on asset details page (#8309)
by @bengotow
[dagit] Small left-nav design adjustments (#8307)
by @bengotow
[dagit] Make the warning icon optional in AppTopNav (#8294)
by @hellendag
Add docker executor example to deploy_docker (#8219)
by @gibsondan
AssetSelection.assets (#8316)
by @sryza
upload backcompat artifacts to bk (#8184)
by @jamiedemaria
[dagster-io/ui] Expose some text input styles (#8318)
by @hellendag
output_asset_partition_key -> asset_partition_key_for_output (#8327)
by @sryza
[dagit] Fix text overflow behavior in the left nav, keep open if one repo (#8324)
by @bengotow
[dagit] Run timeline: make popover scrollable (#8319)
by @hellendag
docs: make sidenav sticky [DREL-329] (#8310)
by @yuhan
use DisplayableEvent in dagit log viewer (#8323)
by @gibsondan
uniform prefix parsing (#8332)
by @OwenKephart
docs: fix link from Kubernetes example (#8335)
by @rexledesma
[dagster-dbt] group names on dbt assets (#8303)
by @OwenKephart
Attempt to speed up query for existing run keys for a given sensor (#8329)
by @gibsondan
[docs] - Getting Started/quick start updates [CON-39] (#8187)
by @erinkcochran87
in load_assets_from_... functions, make key_prefix docstring consistent with group (#8333)
by @sryza
reorder concept super-sections in left nav (#8315)
by @sryza
docs: improve search 4/ house cleaning - remove unused config/cmd (#8273)
by @yuhan
[dagit] Repair font-sizes on Safari (#8351)
by @hellendag
[assets] fix issues with job selection (#8340)
by @OwenKephart
AssetsDefinition.asset_keys -> keys and similar (#8325)
by @sryza
require get_event_records to have filter arg (#8284)
by @prha
Revert "Revert "KVS storage methods (#8249)"" (#8296)
by @johannkm
Allow number type for id in ButtonGroup (#8352)
by @salazarm
[dagit] Resolve redundant tag buttons on Launchpad (#8353)
by @hellendag
test(graphql): ensure type names do not leak graphene (#8345)
by @rexledesma
docs(graphql): ensure descriptions for all mutation fields (#8346)
by @rexledesma
docs(graphql): ensure descriptions for all query fields (#8347)
by @rexledesma
docs(graphql): ensure descriptions for all subscription fields (#8348)
by @rexledesma
docs(graphql): ensure descriptions for all types with opt-in enforcement (#8349)
by @rexledesma
fix 0.14.20 versioned_navigation entry (#8360)
by @yuhan
Event log methods for event log consumer (#8253)
by @johannkm
[docs] - Clarify explanation of graph-backed assets (#8328)
by @sryza
AssetOut (#8359)
by @sryza
[docs] - Update IO Manager docs to contain Asset IO management (#8337)
by @clairelin135
Auto run reexecution daemon for oss (#8254)
by @johannkm
Toggle to enable auto run reexecution daemon (#8277)
by @johannkm
[with_resources changes 1/n] with_resources docstring, config argument (#8322)
by @dpeng817
Update k8s docs to reflect new includeConfigInLaunchedRuns default (#8361)
by @gibsondan
Simplify execute_in_process result (#8365)
by @gibsondan
[docs] - Graph-backed asset examples (#8339)
by @clairelin135
Run retries helm config (#8369)
by @johannkm
[with-resources changes 2/n] If resources collide when using with_resources, error. (#8330)
by @dpeng817
AssetsDefinition property name changes (#8317)
by @sryza
pass on partitions page for assets (#8355)
by @sryza
Type annotations for IOManager (#8308)
by @smackesey
materialize_in_process method (#8364)
by @dpeng817
[assets] assorted bugfixes (#8372)
by @OwenKephart
[docs] - Update repository concept doc with asset info (#8373)
by @smackesey
asset apiref improvements (#8374)
by @sryza
add custom k8s labels to dagster k8s jobs, not just dagster k8s pods (#8381)
by @gibsondan
asset apiref improvements (#8374)
by @sryza
Merge branch 'master' of https://github.com/dagster-io/dagster into release-0.15.0
by @clairelin135
[dagit] Update the linking between asset groups + jobs (#8377)
by @bengotow
[docs] - Asset grouping [CON-295] (#8375)
by @erinkcochran87
[docs] - New Jobs & Graphs structure [CON-289] (#8035)
by @erinkcochran87
fix docs lint (#8387)
by @gibsondan
Patch op definition resolution for assets in GQL (#8384)
by @smackesey
Run retries docs (#8367)
by @johannkm
Make asset invocation error if resources conflict (#8390)
by @dpeng817
materialize_in_process -> materialize_to_memory (#8391)
by @dpeng817
remove old asset lineage from docs (#8382)
by @sryza
Fix problems from "remove old asset lineage from docs (#8382)" (#8389)
by @sryza
apidoc for AssetOut and AssetIn (#8388)
by @sryza
0.15.0
by @elementl-devtools