Changeset View
Changeset View
Standalone View
Standalone View
js_modules/dagit/src/graphql/schema.graphql
Show First 20 Lines • Show All 675 Lines • ▼ Show 20 Lines | |||||
input PipelineSelector { | input PipelineSelector { | ||||
pipelineName: String! | pipelineName: String! | ||||
repositoryName: String! | repositoryName: String! | ||||
repositoryLocationName: String! | repositoryLocationName: String! | ||||
solidSelection: [String!] | solidSelection: [String!] | ||||
} | } | ||||
union PipelineSnapshotOrError = PipelineSnapshot | PipelineSnapshotNotFoundError | PipelineNotFoundError | PythonError | union PipelineSnapshotOrError = PipelineNotFoundError | PipelineSnapshot | PipelineSnapshotNotFoundError | PythonError | ||||
type PipelineSnapshot implements IPipelineSnapshot & PipelineReference { | type PipelineSnapshot implements IPipelineSnapshot & PipelineReference { | ||||
name: String! | name: String! | ||||
description: String | description: String | ||||
pipelineSnapshotId: String! | pipelineSnapshotId: String! | ||||
dagsterTypes: [DagsterType!]! | dagsterTypes: [DagsterType!]! | ||||
dagsterTypeOrError(dagsterTypeName: String!): DagsterTypeOrError! | dagsterTypeOrError(dagsterTypeName: String!): DagsterTypeOrError! | ||||
solids: [Solid!]! | solids: [Solid!]! | ||||
▲ Show 20 Lines • Show All 700 Lines • ▼ Show 20 Lines | |||||
enum LocationStateChangeEventType { | enum LocationStateChangeEventType { | ||||
LOCATION_UPDATED | LOCATION_UPDATED | ||||
LOCATION_DISCONNECTED | LOCATION_DISCONNECTED | ||||
LOCATION_RECONNECTED | LOCATION_RECONNECTED | ||||
LOCATION_ERROR | LOCATION_ERROR | ||||
} | } | ||||
type RegularConfigType implements ConfigType { | type EventFloatMetadataEntry implements EventMetadataEntry { | ||||
key: String! | label: String! | ||||
description: String | description: String | ||||
recursiveConfigTypes: [ConfigType!]! | floatValue: Float! | ||||
typeParamKeys: [String!]! | |||||
isSelector: Boolean! | |||||
givenName: String! | |||||
} | } | ||||
type ArrayConfigType implements ConfigType & WrappingConfigType { | type EventIntMetadataEntry implements EventMetadataEntry { | ||||
key: String! | label: String! | ||||
description: String | description: String | ||||
recursiveConfigTypes: [ConfigType!]! | intValue: Int! | ||||
typeParamKeys: [String!]! | |||||
isSelector: Boolean! | |||||
ofType: ConfigType! | |||||
} | } | ||||
interface WrappingConfigType { | type EventJsonMetadataEntry implements EventMetadataEntry { | ||||
ofType: ConfigType! | label: String! | ||||
description: String | |||||
jsonString: String! | |||||
} | } | ||||
type ScalarUnionConfigType implements ConfigType { | type EventMarkdownMetadataEntry implements EventMetadataEntry { | ||||
key: String! | label: String! | ||||
description: String | description: String | ||||
recursiveConfigTypes: [ConfigType!]! | mdStr: String! | ||||
typeParamKeys: [String!]! | |||||
isSelector: Boolean! | |||||
scalarType: ConfigType! | |||||
nonScalarType: ConfigType! | |||||
scalarTypeKey: String! | |||||
nonScalarTypeKey: String! | |||||
} | } | ||||
type NullableConfigType implements ConfigType & WrappingConfigType { | type EventPathMetadataEntry implements EventMetadataEntry { | ||||
key: String! | label: String! | ||||
description: String | description: String | ||||
recursiveConfigTypes: [ConfigType!]! | path: String! | ||||
typeParamKeys: [String!]! | |||||
isSelector: Boolean! | |||||
ofType: ConfigType! | |||||
} | } | ||||
type EnumConfigType implements ConfigType { | type EventPythonArtifactMetadataEntry implements EventMetadataEntry { | ||||
key: String! | label: String! | ||||
description: String | description: String | ||||
recursiveConfigTypes: [ConfigType!]! | module: String! | ||||
typeParamKeys: [String!]! | name: String! | ||||
isSelector: Boolean! | |||||
values: [EnumConfigValue!]! | |||||
givenName: String! | |||||
} | } | ||||
type EnumConfigValue { | type EventTextMetadataEntry implements EventMetadataEntry { | ||||
value: String! | label: String! | ||||
description: String | description: String | ||||
text: String! | |||||
} | } | ||||
type CompositeConfigType implements ConfigType { | type EventUrlMetadataEntry implements EventMetadataEntry { | ||||
key: String! | label: String! | ||||
description: String | description: String | ||||
recursiveConfigTypes: [ConfigType!]! | url: String! | ||||
typeParamKeys: [String!]! | |||||
isSelector: Boolean! | |||||
fields: [ConfigTypeField!]! | |||||
} | } | ||||
type RuntimeMismatchConfigError implements PipelineConfigValidationError { | type MissingRunIdErrorEvent { | ||||
invalidRunId: String! | |||||
} | |||||
type ConfigTypeNotFoundError implements Error { | |||||
message: String! | |||||
pipeline: Pipeline! | |||||
configTypeName: String! | |||||
} | |||||
type FieldNotDefinedConfigError implements PipelineConfigValidationError { | |||||
message: String! | message: String! | ||||
path: [String!]! | path: [String!]! | ||||
stack: EvaluationStack! | stack: EvaluationStack! | ||||
reason: EvaluationErrorReason! | reason: EvaluationErrorReason! | ||||
valueRep: String | fieldName: String! | ||||
} | } | ||||
type MissingFieldConfigError implements PipelineConfigValidationError { | type FieldsNotDefinedConfigError implements PipelineConfigValidationError { | ||||
message: String! | message: String! | ||||
path: [String!]! | path: [String!]! | ||||
stack: EvaluationStack! | stack: EvaluationStack! | ||||
reason: EvaluationErrorReason! | reason: EvaluationErrorReason! | ||||
field: ConfigTypeField! | fieldNames: [String!]! | ||||
} | } | ||||
type MissingFieldsConfigError implements PipelineConfigValidationError { | type MissingFieldConfigError implements PipelineConfigValidationError { | ||||
message: String! | message: String! | ||||
path: [String!]! | path: [String!]! | ||||
stack: EvaluationStack! | stack: EvaluationStack! | ||||
reason: EvaluationErrorReason! | reason: EvaluationErrorReason! | ||||
fields: [ConfigTypeField!]! | field: ConfigTypeField! | ||||
} | } | ||||
type FieldNotDefinedConfigError implements PipelineConfigValidationError { | type MissingFieldsConfigError implements PipelineConfigValidationError { | ||||
message: String! | message: String! | ||||
path: [String!]! | path: [String!]! | ||||
stack: EvaluationStack! | stack: EvaluationStack! | ||||
reason: EvaluationErrorReason! | reason: EvaluationErrorReason! | ||||
fieldName: String! | fields: [ConfigTypeField!]! | ||||
} | } | ||||
type FieldsNotDefinedConfigError implements PipelineConfigValidationError { | type RuntimeMismatchConfigError implements PipelineConfigValidationError { | ||||
message: String! | message: String! | ||||
path: [String!]! | path: [String!]! | ||||
stack: EvaluationStack! | stack: EvaluationStack! | ||||
reason: EvaluationErrorReason! | reason: EvaluationErrorReason! | ||||
fieldNames: [String!]! | valueRep: String | ||||
} | } | ||||
type SelectorTypeConfigError implements PipelineConfigValidationError { | type SelectorTypeConfigError implements PipelineConfigValidationError { | ||||
message: String! | message: String! | ||||
path: [String!]! | path: [String!]! | ||||
stack: EvaluationStack! | stack: EvaluationStack! | ||||
reason: EvaluationErrorReason! | reason: EvaluationErrorReason! | ||||
incomingFields: [String!]! | incomingFields: [String!]! | ||||
} | } | ||||
type ConfigTypeNotFoundError implements Error { | type UnknownPipeline implements PipelineReference { | ||||
message: String! | name: String! | ||||
pipeline: Pipeline! | solidSelection: [String!] | ||||
configTypeName: String! | |||||
} | } | ||||
type JobNotFoundError implements Error { | type DeleteRunMutation { | ||||
message: String! | Output: DeletePipelineRunResult! | ||||
} | |||||
type LaunchPartitionBackfillMutation { | |||||
Output: PartitionBackfillResult! | |||||
} | |||||
type LaunchPipelineExecutionMutation { | |||||
Output: LaunchPipelineExecutionResult! | |||||
} | |||||
type LaunchPipelineReexecutionMutation { | |||||
Output: LaunchPipelineReexecutionResult! | |||||
} | |||||
type ReloadRepositoryLocationMutation { | |||||
Output: ReloadRepositoryLocationMutationResult! | |||||
} | |||||
type TerminatePipelineExecutionMutation { | |||||
Output: TerminatePipelineExecutionResult! | |||||
} | |||||
union ConfigTypeOrError = EnumConfigType | CompositeConfigType | RegularConfigType | PipelineNotFoundError | ConfigTypeNotFoundError | PythonError | |||||
type EnumConfigType implements ConfigType { | |||||
key: String! | |||||
description: String | |||||
recursiveConfigTypes: [ConfigType!]! | |||||
typeParamKeys: [String!]! | |||||
isSelector: Boolean! | |||||
values: [EnumConfigValue!]! | |||||
givenName: String! | |||||
} | |||||
type EnumConfigValue { | |||||
value: String! | |||||
description: String | |||||
} | |||||
type CompositeConfigType implements ConfigType { | |||||
key: String! | |||||
description: String | |||||
recursiveConfigTypes: [ConfigType!]! | |||||
typeParamKeys: [String!]! | |||||
isSelector: Boolean! | |||||
fields: [ConfigTypeField!]! | |||||
} | |||||
type RegularConfigType implements ConfigType { | |||||
key: String! | |||||
description: String | |||||
recursiveConfigTypes: [ConfigType!]! | |||||
typeParamKeys: [String!]! | |||||
isSelector: Boolean! | |||||
givenName: String! | |||||
} | |||||
type ArrayConfigType implements ConfigType & WrappingConfigType { | |||||
key: String! | |||||
description: String | |||||
recursiveConfigTypes: [ConfigType!]! | |||||
typeParamKeys: [String!]! | |||||
isSelector: Boolean! | |||||
ofType: ConfigType! | |||||
} | |||||
interface WrappingConfigType { | |||||
ofType: ConfigType! | |||||
} | |||||
type NullableConfigType implements ConfigType & WrappingConfigType { | |||||
key: String! | |||||
description: String | |||||
recursiveConfigTypes: [ConfigType!]! | |||||
typeParamKeys: [String!]! | |||||
isSelector: Boolean! | |||||
ofType: ConfigType! | |||||
} | |||||
type ScalarUnionConfigType implements ConfigType { | |||||
key: String! | |||||
description: String | |||||
recursiveConfigTypes: [ConfigType!]! | |||||
typeParamKeys: [String!]! | |||||
isSelector: Boolean! | |||||
scalarType: ConfigType! | |||||
nonScalarType: ConfigType! | |||||
scalarTypeKey: String! | |||||
nonScalarTypeKey: String! | |||||
} | } | ||||
type ListDagsterType implements DagsterType & WrappingDagsterType { | type ListDagsterType implements DagsterType & WrappingDagsterType { | ||||
key: String! | key: String! | ||||
name: String | name: String | ||||
displayName: String! | displayName: String! | ||||
description: String | description: String | ||||
isNullable: Boolean! | isNullable: Boolean! | ||||
Show All 20 Lines | type NullableDagsterType implements DagsterType & WrappingDagsterType { | ||||
isBuiltin: Boolean! | isBuiltin: Boolean! | ||||
isNothing: Boolean! | isNothing: Boolean! | ||||
inputSchemaType: ConfigType | inputSchemaType: ConfigType | ||||
outputSchemaType: ConfigType | outputSchemaType: ConfigType | ||||
innerTypes: [DagsterType!]! | innerTypes: [DagsterType!]! | ||||
ofType: DagsterType! | ofType: DagsterType! | ||||
} | } | ||||
type CompositeSolidDefinition implements ISolidDefinition & SolidContainer { | input MarshalledInput { | ||||
name: String! | inputName: String! | ||||
description: String | key: String! | ||||
metadata: [MetadataItemDefinition!]! | |||||
inputDefinitions: [InputDefinition!]! | |||||
outputDefinitions: [OutputDefinition!]! | |||||
requiredResources: [ResourceRequirement!]! | |||||
solids: [Solid!]! | |||||
inputMappings: [InputMapping!]! | |||||
outputMappings: [OutputMapping!]! | |||||
} | |||||
type InputMapping { | |||||
mappedInput: Input! | |||||
definition: InputDefinition! | |||||
} | |||||
type OutputMapping { | |||||
mappedOutput: Output! | |||||
definition: OutputDefinition! | |||||
} | } | ||||
type UnknownPipeline implements PipelineReference { | input MarshalledOutput { | ||||
name: String! | outputName: String! | ||||
solidSelection: [String!] | key: String! | ||||
} | } | ||||
type MissingRunIdErrorEvent { | input Retries { | ||||
invalidRunId: String! | mode: String | ||||
retriesPreviousAttempts: [RetriesPreviousAttempts] | |||||
} | } | ||||
type EventPathMetadataEntry implements EventMetadataEntry { | input RetriesPreviousAttempts { | ||||
label: String! | key: String | ||||
description: String | count: Int | ||||
path: String! | |||||
} | } | ||||
type EventJsonMetadataEntry implements EventMetadataEntry { | input StepExecution { | ||||
label: String! | stepKey: String! | ||||
description: String | marshalledInputs: [MarshalledInput!] | ||||
jsonString: String! | marshalledOutputs: [MarshalledOutput!] | ||||
} | } | ||||
type EventTextMetadataEntry implements EventMetadataEntry { | input StepOutputHandle { | ||||
label: String! | stepKey: String! | ||||
description: String | outputName: String! | ||||
text: String! | |||||
} | } | ||||
type EventUrlMetadataEntry implements EventMetadataEntry { | type RunGroups { | ||||
label: String! | results: [RunGroup!]! | ||||
description: String | |||||
url: String! | |||||
} | } | ||||
type EventMarkdownMetadataEntry implements EventMetadataEntry { | type StopSensorMutation { | ||||
label: String! | Output: StopSensorMutationResultOrError! | ||||
description: String | |||||
mdStr: String! | |||||
} | } | ||||
type EventPythonArtifactMetadataEntry implements EventMetadataEntry { | type CompositeSolidDefinition implements ISolidDefinition & SolidContainer { | ||||
label: String! | |||||
description: String | |||||
module: String! | |||||
name: String! | name: String! | ||||
} | |||||
type EventFloatMetadataEntry implements EventMetadataEntry { | |||||
label: String! | |||||
description: String | description: String | ||||
floatValue: Float! | metadata: [MetadataItemDefinition!]! | ||||
} | inputDefinitions: [InputDefinition!]! | ||||
outputDefinitions: [OutputDefinition!]! | |||||
type EventIntMetadataEntry implements EventMetadataEntry { | requiredResources: [ResourceRequirement!]! | ||||
label: String! | solids: [Solid!]! | ||||
description: String | inputMappings: [InputMapping!]! | ||||
intValue: Int! | outputMappings: [OutputMapping!]! | ||||
} | |||||
type ScheduleTick { | |||||
tickId: String! | |||||
status: JobTickStatus! | |||||
timestamp: Float! | |||||
tickSpecificData: ScheduleTickSpecificData | |||||
} | |||||
union ScheduleTickSpecificData = ScheduleTickSuccessData | ScheduleTickFailureData | |||||
type ScheduleTickSuccessData { | |||||
run: PipelineRun | |||||
} | } | ||||
type ScheduleTickFailureData { | type InputMapping { | ||||
error: PythonError! | mappedInput: Input! | ||||
definition: InputDefinition! | |||||
} | } | ||||
type ScheduleTickStatsSnapshot { | type OutputMapping { | ||||
ticksStarted: Int! | mappedOutput: Output! | ||||
ticksSucceeded: Int! | definition: OutputDefinition! | ||||
ticksSkipped: Int! | |||||
ticksFailed: Int! | |||||
} | } |