Page Menu
Home
Elementl
Search
Configure Global Search
Log In
Queries
All Changesets
Search
Advanced Search
Differential
D6164
Diff 30546
All Changesets
All Changesets
Edit Query
Hide Query
Order By
Creation (Newest First)
Creation (Oldest First)
Search
Change
Path
Modified
js_modules/dagit/src/configeditor/types/ConfigEditorRunConfigSchemaFragment.ts
Modified
js_modules/dagit/src/configeditor/types/ConfigEditorValidationFragment.ts
Modified
js_modules/dagit/src/execute/types/ExecutionSessionContainerRunConfigSchemaFragment.ts
Modified
js_modules/dagit/src/execute/types/PipelineExecutionConfigSchemaQuery.ts
Modified
js_modules/dagit/src/execute/types/SolidSelectorQuery.ts
Modified
js_modules/dagit/src/graph/types/PipelineGraphSolidFragment.ts
Modified
js_modules/dagit/src/graph/types/SolidNodeDefinitionFragment.ts
Modified
js_modules/dagit/src/graphql/possibleTypes.generated.json
Modified
js_modules/dagit/src/graphql/schema.graphql
Modified
js_modules/dagit/src/partitions/types/LaunchPartitionBackfill.ts
Modified
js_modules/dagit/src/partitions/types/PartitionRunMatrixPipelineQuery.ts
Modified
js_modules/dagit/src/partitions/types/PartitionsBackfillSelectorQuery.ts
Modified
js_modules/dagit/src/pipelines/types/PipelineExplorerRootQuery.ts
Modified
js_modules/dagit/src/pipelines/types/PipelineExplorerSolidHandleFragment.ts
Modified
js_modules/dagit/src/pipelines/types/PipelineOverviewQuery.ts
Modified
js_modules/dagit/src/runs/types/LaunchPipelineExecution.ts
Modified
js_modules/dagit/src/runs/types/LaunchPipelineReexecution.ts
Modified
js_modules/dagit/src/snapshots/types/SnapshotQuery.ts
Modified
js_modules/dagit/src/solids/types/SolidCardSolidDefinitionFragment.ts
Modified
python_modules/dagit/dagit/schema/__init__.py
Modified
python_modules/dagster-graphql/dagster_graphql/__init__.py
Deleted
python_modules/dagster-graphql/dagster_graphql/dauphin_registry.py
Modified
python_modules/dagster-graphql/dagster_graphql/implementation/context.py
Added
python_modules/dagster-graphql/dagster_graphql/implementation/events.py
Modified
python_modules/dagster-graphql/dagster_graphql/implementation/execution/__init__.py
Modified
python_modules/dagster-graphql/dagster_graphql/implementation/execution/backfill.py
Modified
python_modules/dagster-graphql/dagster_graphql/implementation/execution/launch_execution.py
Modified
python_modules/dagster-graphql/dagster_graphql/implementation/external.py
Modified
python_modules/dagster-graphql/dagster_graphql/implementation/fetch_assets.py
Modified
python_modules/dagster-graphql/dagster_graphql/implementation/fetch_jobs.py
Modified
python_modules/dagster-graphql/dagster_graphql/implementation/fetch_partition_sets.py
Modified
python_modules/dagster-graphql/dagster_graphql/implementation/fetch_pipelines.py
Modified
python_modules/dagster-graphql/dagster_graphql/implementation/fetch_runs.py
Modified
python_modules/dagster-graphql/dagster_graphql/implementation/fetch_schedules.py
Modified
python_modules/dagster-graphql/dagster_graphql/implementation/fetch_sensors.py
Modified
python_modules/dagster-graphql/dagster_graphql/implementation/fetch_solids.py
Modified
python_modules/dagster-graphql/dagster_graphql/implementation/run_config_schema.py
Modified
python_modules/dagster-graphql/dagster_graphql/implementation/utils.py
Modified
python_modules/dagster-graphql/dagster_graphql/schema/__init__.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/asset_key.py
Deleted
python_modules/dagster-graphql/dagster_graphql/schema/assets.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/backfill.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/config_type_or_error.py
Modified
python_modules/dagster-graphql/dagster_graphql/schema/config_types.py
Modified
python_modules/dagster-graphql/dagster_graphql/schema/dagster_types.py
Modified
python_modules/dagster-graphql/dagster_graphql/schema/errors.py
Modified
python_modules/dagster-graphql/dagster_graphql/schema/execution.py
Modified
python_modules/dagster-graphql/dagster_graphql/schema/external.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/inputs.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/instance.py
Modified
python_modules/dagster-graphql/dagster_graphql/schema/jobs.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/logs/__init__.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/logs/compute_logs.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/logs/events.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/logs/log_level.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/metadata.py
Modified
python_modules/dagster-graphql/dagster_graphql/schema/paging.py
Modified
python_modules/dagster-graphql/dagster_graphql/schema/partition_sets.py
Deleted
python_modules/dagster-graphql/dagster_graphql/schema/pipelines.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/pipelines/__init__.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/pipelines/config.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/pipelines/config_result.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/pipelines/logger.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/pipelines/mode.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/pipelines/pipeline.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/pipelines/pipeline_errors.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/pipelines/pipeline_ref.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/pipelines/pipeline_run_stats.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/pipelines/resource.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/pipelines/snapshot.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/pipelines/status.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/pipelines/subscription.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/repository_origin.py
Deleted
python_modules/dagster-graphql/dagster_graphql/schema/roots.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/roots/__init__.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/roots/assets.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/roots/execution_plan.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/roots/mutation.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/roots/pipeline.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/roots/query.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/roots/subscription.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/run_config.py
Modified
python_modules/dagster-graphql/dagster_graphql/schema/runs.py
Modified
python_modules/dagster-graphql/dagster_graphql/schema/schedules/__init__.py
Modified
python_modules/dagster-graphql/dagster_graphql/schema/schedules/schedules.py
Modified
python_modules/dagster-graphql/dagster_graphql/schema/schedules/ticks.py
Modified
python_modules/dagster-graphql/dagster_graphql/schema/sensors.py
Modified
python_modules/dagster-graphql/dagster_graphql/schema/solids.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/tags.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/used_solid.py
Added
python_modules/dagster-graphql/dagster_graphql/schema/util.py
Modified
python_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_assets.py
Modified
python_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_composites.py
Modified
python_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_environment_schema.py
Modified
python_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_expectations.py
Modified
python_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_materializations.py
Modified
python_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_partition_sets.py
Modified
python_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_presets.py
Modified
python_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_reexecution.py
Modified
python_modules/dagster-graphql/dagster_graphql_tests/graphql/snapshots/snap_test_retry_execution.py
Next