Page MenuHomeElementl

All Changesets

ChangePath
Modifiedjs_modules/dagit/src/configeditor/types/ConfigEditorRunConfigSchemaFragment.ts
Modifiedjs_modules/dagit/src/configeditor/types/ConfigEditorValidationFragment.ts
Modifiedjs_modules/dagit/src/execute/types/ExecutionSessionContainerRunConfigSchemaFragment.ts
Modifiedjs_modules/dagit/src/execute/types/PipelineExecutionConfigSchemaQuery.ts
Modifiedjs_modules/dagit/src/execute/types/SolidSelectorQuery.ts
Modifiedjs_modules/dagit/src/graph/types/PipelineGraphSolidFragment.ts
Modifiedjs_modules/dagit/src/graph/types/SolidNodeDefinitionFragment.ts
Modifiedjs_modules/dagit/src/graphql/possibleTypes.generated.json
Modifiedjs_modules/dagit/src/graphql/schema.graphql
Modifiedjs_modules/dagit/src/partitions/types/LaunchPartitionBackfill.ts
Modifiedjs_modules/dagit/src/partitions/types/PartitionRunMatrixPipelineQuery.ts
Modifiedjs_modules/dagit/src/partitions/types/PartitionsBackfillSelectorQuery.ts
Modifiedjs_modules/dagit/src/pipelines/types/PipelineExplorerRootQuery.ts
Modifiedjs_modules/dagit/src/pipelines/types/PipelineExplorerSolidHandleFragment.ts
Modifiedjs_modules/dagit/src/pipelines/types/PipelineOverviewQuery.ts
Modifiedjs_modules/dagit/src/runs/types/LaunchPipelineExecution.ts
Modifiedjs_modules/dagit/src/runs/types/LaunchPipelineReexecution.ts
Modifiedjs_modules/dagit/src/snapshots/types/SnapshotQuery.ts
Modifiedjs_modules/dagit/src/solids/types/SolidCardSolidDefinitionFragment.ts
Modifiedpython_modules/dagit/dagit/schema/__init__.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/__init__.py
Deletedpython_modules/dagster-graphql/dagster_graphql/dauphin_registry.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/implementation/context.py
Addedpython_modules/dagster-graphql/dagster_graphql/implementation/events.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/implementation/execution/__init__.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/implementation/execution/backfill.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/implementation/execution/launch_execution.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/implementation/external.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/implementation/fetch_assets.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/implementation/fetch_jobs.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/implementation/fetch_partition_sets.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/implementation/fetch_pipelines.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/implementation/fetch_runs.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/implementation/fetch_schedules.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/implementation/fetch_sensors.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/implementation/fetch_solids.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/implementation/run_config_schema.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/implementation/utils.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/schema/__init__.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/asset_key.py
Deletedpython_modules/dagster-graphql/dagster_graphql/schema/assets.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/backfill.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/config_type_or_error.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/schema/config_types.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/schema/dagster_types.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/schema/errors.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/schema/execution.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/schema/external.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/inputs.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/instance.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/schema/jobs.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/logs/__init__.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/logs/compute_logs.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/logs/events.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/logs/log_level.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/metadata.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/schema/paging.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/schema/partition_sets.py
Deletedpython_modules/dagster-graphql/dagster_graphql/schema/pipelines.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/pipelines/__init__.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/pipelines/config.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/pipelines/config_result.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/pipelines/logger.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/pipelines/mode.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/pipelines/pipeline.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/pipelines/pipeline_errors.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/pipelines/pipeline_ref.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/pipelines/pipeline_run_stats.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/pipelines/resource.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/pipelines/snapshot.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/pipelines/status.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/pipelines/subscription.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/repository_origin.py
Deletedpython_modules/dagster-graphql/dagster_graphql/schema/roots.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/roots/__init__.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/roots/assets.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/roots/execution_plan.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/roots/mutation.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/roots/pipeline.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/roots/query.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/roots/subscription.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/run_config.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/schema/runs.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/schema/schedules/__init__.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/schema/schedules/schedules.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/schema/schedules/ticks.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/schema/sensors.py
Modifiedpython_modules/dagster-graphql/dagster_graphql/schema/solids.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/tags.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/used_solid.py
Addedpython_modules/dagster-graphql/dagster_graphql/schema/util.py
Modifiedpython_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_assets.py
Modifiedpython_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_composites.py
Modifiedpython_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_environment_schema.py
Modifiedpython_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_expectations.py
Modifiedpython_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_materializations.py
Modifiedpython_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_partition_sets.py
Modifiedpython_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_presets.py
Modifiedpython_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_reexecution.py
Modifiedpython_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_retry_execution.py