From 2320f1049db96461fd2ab42809ca48b04463fab1 Mon Sep 17 00:00:00 2001 From: Owen Kephart Date: Wed, 17 Jan 2024 15:15:56 -0800 Subject: [PATCH] generate types --- .../types/GetEvaluationsQuery.types.ts | 16 +- .../src/graphql/possibleTypes.generated.json | 704 +----------------- 2 files changed, 9 insertions(+), 711 deletions(-) diff --git a/js_modules/dagster-ui/packages/ui-core/src/assets/AutoMaterializePolicyPage/types/GetEvaluationsQuery.types.ts b/js_modules/dagster-ui/packages/ui-core/src/assets/AutoMaterializePolicyPage/types/GetEvaluationsQuery.types.ts index df9d08243ce4c..5338ec52624d5 100644 --- a/js_modules/dagster-ui/packages/ui-core/src/assets/AutoMaterializePolicyPage/types/GetEvaluationsQuery.types.ts +++ b/js_modules/dagster-ui/packages/ui-core/src/assets/AutoMaterializePolicyPage/types/GetEvaluationsQuery.types.ts @@ -258,8 +258,8 @@ export type PartitionedAssetConditionEvaluationNodeFragment = { startTimestamp: number | null; endTimestamp: number | null; numTrue: number; - numFalse: number; - numSkipped: number; + numFalse: number | null; + numSkipped: number | null; uniqueId: string; childUniqueIds: Array; trueSubset: { @@ -310,8 +310,8 @@ export type AssetConditionEvaluationRecordFragment = { startTimestamp: number | null; endTimestamp: number | null; numTrue: number; - numFalse: number; - numSkipped: number; + numFalse: number | null; + numSkipped: number | null; uniqueId: string; childUniqueIds: Array; trueSubset: { @@ -670,8 +670,8 @@ export type GetEvaluationsQuery = { startTimestamp: number | null; endTimestamp: number | null; numTrue: number; - numFalse: number; - numSkipped: number; + numFalse: number | null; + numSkipped: number | null; uniqueId: string; childUniqueIds: Array; trueSubset: { @@ -1017,8 +1017,8 @@ export type GetEvaluationsSpecificPartitionQuery = { startTimestamp: number | null; endTimestamp: number | null; numTrue: number; - numFalse: number; - numSkipped: number; + numFalse: number | null; + numSkipped: number | null; uniqueId: string; childUniqueIds: Array; trueSubset: { diff --git a/js_modules/dagster-ui/packages/ui-core/src/graphql/possibleTypes.generated.json b/js_modules/dagster-ui/packages/ui-core/src/graphql/possibleTypes.generated.json index c6e4989f4908c..4d529a469d3a4 100644 --- a/js_modules/dagster-ui/packages/ui-core/src/graphql/possibleTypes.generated.json +++ b/js_modules/dagster-ui/packages/ui-core/src/graphql/possibleTypes.generated.json @@ -1,703 +1 @@ -<<<<<<< HEAD -<<<<<<< HEAD -{"DisplayableEvent":["EngineEvent","ExecutionStepOutputEvent","ExpectationResult","FailureMetadata","HandledOutputEvent","LoadedInputEvent","ObjectStoreOperationResult","ResourceInitFailureEvent","ResourceInitStartedEvent","ResourceInitSuccessEvent","StepWorkerStartedEvent","StepWorkerStartingEvent","MaterializationEvent","ObservationEvent","TypeCheck"],"MarkerEvent":["EngineEvent","ResourceInitFailureEvent","ResourceInitStartedEvent","ResourceInitSuccessEvent","StepWorkerStartedEvent","StepWorkerStartingEvent"],"ErrorEvent":["EngineEvent","ExecutionStepFailureEvent","ExecutionStepUpForRetryEvent","HookErroredEvent","RunFailureEvent","ResourceInitFailureEvent"],"MessageEvent":["EngineEvent","ExecutionStepFailureEvent","ExecutionStepInputEvent","ExecutionStepOutputEvent","ExecutionStepRestartEvent","ExecutionStepSkippedEvent","ExecutionStepStartEvent","ExecutionStepSuccessEvent","ExecutionStepUpForRetryEvent","HandledOutputEvent","HookCompletedEvent","HookErroredEvent","HookSkippedEvent","LoadedInputEvent","LogMessageEvent","ObjectStoreOperationEvent","RunCanceledEvent","RunCancelingEvent","RunDequeuedEvent","RunEnqueuedEvent","RunFailureEvent","ResourceInitFailureEvent","ResourceInitStartedEvent","ResourceInitSuccessEvent","RunStartEvent","RunStartingEvent","RunSuccessEvent","StepExpectationResultEvent","StepWorkerStartedEvent","StepWorkerStartingEvent","MaterializationEvent","ObservationEvent","AssetMaterializationPlannedEvent","LogsCapturedEvent","AlertStartEvent","AlertSuccessEvent","AlertFailureEvent","AssetCheckEvaluationPlannedEvent","AssetCheckEvaluationEvent"],"RunEvent":["RunCanceledEvent","RunCancelingEvent","RunDequeuedEvent","RunEnqueuedEvent","RunFailureEvent","RunStartEvent","RunStartingEvent","RunSuccessEvent","AssetMaterializationPlannedEvent","AlertStartEvent","AlertSuccessEvent","AlertFailureEvent"],"PipelineRunStepStats":["RunStepStats"],"StepEvent":["EngineEvent","ExecutionStepFailureEvent","ExecutionStepInputEvent","ExecutionStepOutputEvent","ExecutionStepRestartEvent","ExecutionStepSkippedEvent","ExecutionStepStartEvent","ExecutionStepSuccessEvent","ExecutionStepUpForRetryEvent","HandledOutputEvent","HookCompletedEvent","HookErroredEvent","HookSkippedEvent","LoadedInputEvent","ObjectStoreOperationEvent","ResourceInitFailureEvent","ResourceInitStartedEvent","ResourceInitSuccessEvent","StepExpectationResultEvent","StepWorkerStartedEvent","StepWorkerStartingEvent","MaterializationEvent","ObservationEvent","AssetCheckEvaluationPlannedEvent","AssetCheckEvaluationEvent"],"AssetPartitionStatuses":["DefaultPartitionStatuses","MultiPartitionStatuses","TimePartitionStatuses"],"PartitionStatus1D":["TimePartitionStatuses","DefaultPartitionStatuses"],"AssetChecksOrError":["AssetChecks","AssetCheckNeedsMigrationError","AssetCheckNeedsUserCodeUpgrade","AssetCheckNeedsAgentUpgradeError"],"Instigator":["Schedule","Sensor"],"EvaluationStackEntry":["EvaluationStackListItemEntry","EvaluationStackPathEntry","EvaluationStackMapKeyEntry","EvaluationStackMapValueEntry"],"IPipelineSnapshot":["Pipeline","PipelineSnapshot","Job"],"PipelineConfigValidationError":["FieldNotDefinedConfigError","FieldsNotDefinedConfigError","MissingFieldConfigError","MissingFieldsConfigError","RuntimeMismatchConfigError","SelectorTypeConfigError"],"PipelineConfigValidationInvalid":["RunConfigValidationInvalid"],"PipelineConfigValidationResult":["InvalidSubsetError","PipelineConfigValidationValid","RunConfigValidationInvalid","PipelineNotFoundError","PythonError"],"PipelineReference":["PipelineSnapshot","UnknownPipeline"],"PipelineRun":["Run"],"DagsterRunEvent":["ExecutionStepFailureEvent","ExecutionStepInputEvent","ExecutionStepOutputEvent","ExecutionStepSkippedEvent","ExecutionStepStartEvent","ExecutionStepSuccessEvent","ExecutionStepUpForRetryEvent","ExecutionStepRestartEvent","LogMessageEvent","ResourceInitFailureEvent","ResourceInitStartedEvent","ResourceInitSuccessEvent","RunFailureEvent","RunStartEvent","RunEnqueuedEvent","RunDequeuedEvent","RunStartingEvent","RunCancelingEvent","RunCanceledEvent","RunSuccessEvent","StepWorkerStartedEvent","StepWorkerStartingEvent","HandledOutputEvent","LoadedInputEvent","LogsCapturedEvent","ObjectStoreOperationEvent","StepExpectationResultEvent","MaterializationEvent","ObservationEvent","EngineEvent","HookCompletedEvent","HookSkippedEvent","HookErroredEvent","AlertStartEvent","AlertSuccessEvent","AlertFailureEvent","AssetMaterializationPlannedEvent","AssetCheckEvaluationPlannedEvent","AssetCheckEvaluationEvent"],"PipelineRunLogsSubscriptionPayload":["PipelineRunLogsSubscriptionSuccess","PipelineRunLogsSubscriptionFailure"],"RunOrError":["Run","RunNotFoundError","PythonError"],"PipelineRunStatsSnapshot":["RunStatsSnapshot"],"RunStatsSnapshotOrError":["RunStatsSnapshot","PythonError"],"PipelineSnapshotOrError":["PipelineNotFoundError","PipelineSnapshot","PipelineSnapshotNotFoundError","PythonError"],"AssetOrError":["Asset","AssetNotFoundError"],"AssetsOrError":["AssetConnection","PythonError"],"DeletePipelineRunResult":["DeletePipelineRunSuccess","UnauthorizedError","PythonError","RunNotFoundError"],"ExecutionPlanOrError":["ExecutionPlan","RunConfigValidationInvalid","PipelineNotFoundError","InvalidSubsetError","PythonError"],"PipelineOrError":["Pipeline","PipelineNotFoundError","InvalidSubsetError","PythonError"],"ReloadRepositoryLocationMutationResult":["WorkspaceLocationEntry","ReloadNotSupported","RepositoryLocationNotFound","UnauthorizedError","PythonError"],"RepositoryLocationOrLoadError":["RepositoryLocation","PythonError"],"ReloadWorkspaceMutationResult":["Workspace","UnauthorizedError","PythonError"],"ShutdownRepositoryLocationMutationResult":["ShutdownRepositoryLocationSuccess","RepositoryLocationNotFound","UnauthorizedError","PythonError"],"TerminatePipelineExecutionFailure":["TerminateRunFailure"],"TerminatePipelineExecutionSuccess":["TerminateRunSuccess"],"TerminateRunResult":["TerminateRunSuccess","TerminateRunFailure","RunNotFoundError","UnauthorizedError","PythonError"],"ScheduleMutationResult":["PythonError","UnauthorizedError","ScheduleStateResult"],"ScheduleOrError":["Schedule","ScheduleNotFoundError","PythonError"],"SchedulerOrError":["Scheduler","SchedulerNotDefinedError","PythonError"],"SchedulesOrError":["Schedules","RepositoryNotFoundError","PythonError"],"ScheduleTickSpecificData":["ScheduleTickSuccessData","ScheduleTickFailureData"],"LaunchBackfillResult":["LaunchBackfillSuccess","PartitionSetNotFoundError","InvalidStepError","InvalidOutputError","RunConfigValidationInvalid","PipelineNotFoundError","RunConflict","UnauthorizedError","PythonError","InvalidSubsetError","PresetNotFoundError","ConflictingExecutionParamsError","NoModeProvidedError"],"ConfigTypeOrError":["EnumConfigType","CompositeConfigType","RegularConfigType","PipelineNotFoundError","ConfigTypeNotFoundError","PythonError"],"ConfigType":["ArrayConfigType","CompositeConfigType","EnumConfigType","NullableConfigType","RegularConfigType","ScalarUnionConfigType","MapConfigType"],"WrappingConfigType":["ArrayConfigType","NullableConfigType"],"DagsterType":["ListDagsterType","NullableDagsterType","RegularDagsterType"],"DagsterTypeOrError":["RegularDagsterType","PipelineNotFoundError","DagsterTypeNotFoundError","PythonError"],"WrappingDagsterType":["ListDagsterType","NullableDagsterType"],"Error":["AssetCheckNeedsMigrationError","AssetCheckNeedsUserCodeUpgrade","AssetCheckNeedsAgentUpgradeError","AssetNotFoundError","ConflictingExecutionParamsError","ConfigTypeNotFoundError","DagsterTypeNotFoundError","InvalidPipelineRunsFilterError","InvalidSubsetError","ModeNotFoundError","NoModeProvidedError","PartitionSetNotFoundError","PipelineNotFoundError","RunConflict","PipelineSnapshotNotFoundError","PresetNotFoundError","PythonError","ErrorChainLink","UnauthorizedError","ReloadNotSupported","RepositoryLocationNotFound","RepositoryNotFoundError","ResourceNotFoundError","RunGroupNotFoundError","RunNotFoundError","ScheduleNotFoundError","SchedulerNotDefinedError","SensorNotFoundError","DuplicateDynamicPartitionError","InstigationStateNotFoundError","SolidStepStatusUnavailableError","GraphNotFoundError","BackfillNotFoundError","PartitionSubsetDeserializationError","AutoMaterializeAssetEvaluationNeedsMigrationError"],"PipelineRunConflict":["RunConflict"],"PipelineRunNotFoundError":["RunNotFoundError"],"RepositoriesOrError":["RepositoryConnection","RepositoryNotFoundError","PythonError"],"RepositoryOrError":["PythonError","Repository","RepositoryNotFoundError"],"InstigationTypeSpecificData":["SensorData","ScheduleData"],"InstigationStateOrError":["InstigationState","InstigationStateNotFoundError","PythonError"],"InstigationStatesOrError":["InstigationStates","PythonError"],"MetadataEntry":["TableSchemaMetadataEntry","TableMetadataEntry","FloatMetadataEntry","IntMetadataEntry","JsonMetadataEntry","BoolMetadataEntry","MarkdownMetadataEntry","PathMetadataEntry","NotebookMetadataEntry","PythonArtifactMetadataEntry","TextMetadataEntry","UrlMetadataEntry","PipelineRunMetadataEntry","AssetMetadataEntry","JobMetadataEntry","NullMetadataEntry"],"PartitionRunConfigOrError":["PartitionRunConfig","PythonError"],"AssetBackfillStatus":["AssetPartitionsStatusCounts","UnpartitionedAssetStatus"],"PartitionSetOrError":["PartitionSet","PartitionSetNotFoundError","PythonError"],"PartitionSetsOrError":["PartitionSets","PipelineNotFoundError","PythonError"],"PartitionsOrError":["Partitions","PythonError"],"PartitionStatusesOrError":["PartitionStatuses","PythonError"],"PartitionTagsOrError":["PartitionTags","PythonError"],"RunConfigSchemaOrError":["RunConfigSchema","PipelineNotFoundError","InvalidSubsetError","ModeNotFoundError","PythonError"],"LaunchRunResult":["LaunchRunSuccess","InvalidStepError","InvalidOutputError","RunConfigValidationInvalid","PipelineNotFoundError","RunConflict","UnauthorizedError","PythonError","InvalidSubsetError","PresetNotFoundError","ConflictingExecutionParamsError","NoModeProvidedError"],"LaunchRunReexecutionResult":["LaunchRunSuccess","InvalidStepError","InvalidOutputError","RunConfigValidationInvalid","PipelineNotFoundError","RunConflict","UnauthorizedError","PythonError","InvalidSubsetError","PresetNotFoundError","ConflictingExecutionParamsError","NoModeProvidedError"],"LaunchPipelineRunSuccess":["LaunchRunSuccess"],"RunsOrError":["Runs","InvalidPipelineRunsFilterError","PythonError"],"PipelineRuns":["Runs"],"RunGroupOrError":["RunGroup","RunGroupNotFoundError","PythonError"],"SensorOrError":["Sensor","SensorNotFoundError","UnauthorizedError","PythonError"],"SensorsOrError":["Sensors","RepositoryNotFoundError","PythonError"],"StopSensorMutationResultOrError":["StopSensorMutationResult","UnauthorizedError","PythonError"],"ISolidDefinition":["CompositeSolidDefinition","SolidDefinition"],"SolidContainer":["Pipeline","PipelineSnapshot","Job","CompositeSolidDefinition","Graph"],"SolidStepStatsOrError":["SolidStepStatsConnection","SolidStepStatusUnavailableError"],"WorkspaceOrError":["Workspace","PythonError"],"WorkspaceLocationStatusEntriesOrError":["WorkspaceLocationStatusEntries","PythonError"],"GraphOrError":["Graph","GraphNotFoundError","PythonError"],"ResourceDetailsOrError":["ResourceDetails","ResourceNotFoundError","PythonError"],"ResourcesOrError":["ResourceDetailsList","RepositoryNotFoundError","PythonError"],"EnvVarWithConsumersOrError":["EnvVarWithConsumersList","PythonError"],"RunTagKeysOrError":["PythonError","RunTagKeys"],"RunTagsOrError":["PythonError","RunTags"],"RunIdsOrError":["RunIds","InvalidPipelineRunsFilterError","PythonError"],"AssetNodeOrError":["AssetNode","AssetNotFoundError"],"PartitionBackfillOrError":["PartitionBackfill","BackfillNotFoundError","PythonError"],"PartitionBackfillsOrError":["PartitionBackfills","PythonError"],"EventConnectionOrError":["EventConnection","RunNotFoundError","PythonError"],"AutoMaterializeAssetEvaluationRecordsOrError":["AutoMaterializeAssetEvaluationRecords","AutoMaterializeAssetEvaluationNeedsMigrationError"],"PartitionKeysOrError":["PartitionKeys","PartitionSubsetDeserializationError"],"AutoMaterializeRuleEvaluationData":["TextRuleEvaluationData","ParentMaterializedRuleEvaluationData","WaitingOnKeysRuleEvaluationData"],"AssetConditionEvaluationNode":["UnpartitionedAssetConditionEvaluationNode","PartitionedAssetConditionEvaluationNode","SpecificPartitionAssetConditionEvaluationNode"],"AssetConditionEvaluationRecordsOrError":["AssetConditionEvaluationRecords","AutoMaterializeAssetEvaluationNeedsMigrationError"],"SensorDryRunResult":["PythonError","SensorNotFoundError","DryRunInstigationTick"],"ScheduleDryRunResult":["DryRunInstigationTick","PythonError","ScheduleNotFoundError"],"TerminateRunsResultOrError":["TerminateRunsResult","PythonError"],"AssetWipeMutationResult":["AssetNotFoundError","UnauthorizedError","PythonError","AssetWipeSuccess"],"ReportRunlessAssetEventsResult":["UnauthorizedError","PythonError","ReportRunlessAssetEventsSuccess"],"ResumeBackfillResult":["ResumeBackfillSuccess","UnauthorizedError","PythonError"],"CancelBackfillResult":["CancelBackfillSuccess","UnauthorizedError","PythonError"],"LogTelemetryMutationResult":["LogTelemetrySuccess","PythonError"],"AddDynamicPartitionResult":["AddDynamicPartitionSuccess","UnauthorizedError","PythonError","DuplicateDynamicPartitionError"]} -======= -{ - "DisplayableEvent": [ - "EngineEvent", - "ExecutionStepOutputEvent", - "ExpectationResult", - "FailureMetadata", - "HandledOutputEvent", - "LoadedInputEvent", - "ObjectStoreOperationResult", - "ResourceInitFailureEvent", - "ResourceInitStartedEvent", - "ResourceInitSuccessEvent", - "StepWorkerStartedEvent", - "StepWorkerStartingEvent", - "MaterializationEvent", - "ObservationEvent", - "TypeCheck" - ], - "MarkerEvent": [ - "EngineEvent", - "ResourceInitFailureEvent", - "ResourceInitStartedEvent", - "ResourceInitSuccessEvent", - "StepWorkerStartedEvent", - "StepWorkerStartingEvent" - ], - "ErrorEvent": [ - "EngineEvent", - "ExecutionStepFailureEvent", - "ExecutionStepUpForRetryEvent", - "HookErroredEvent", - "RunFailureEvent", - "ResourceInitFailureEvent" - ], - "MessageEvent": [ - "EngineEvent", - "ExecutionStepFailureEvent", - "ExecutionStepInputEvent", - "ExecutionStepOutputEvent", - "ExecutionStepRestartEvent", - "ExecutionStepSkippedEvent", - "ExecutionStepStartEvent", - "ExecutionStepSuccessEvent", - "ExecutionStepUpForRetryEvent", - "HandledOutputEvent", - "HookCompletedEvent", - "HookErroredEvent", - "HookSkippedEvent", - "LoadedInputEvent", - "LogMessageEvent", - "ObjectStoreOperationEvent", - "RunCanceledEvent", - "RunCancelingEvent", - "RunDequeuedEvent", - "RunEnqueuedEvent", - "RunFailureEvent", - "ResourceInitFailureEvent", - "ResourceInitStartedEvent", - "ResourceInitSuccessEvent", - "RunStartEvent", - "RunStartingEvent", - "RunSuccessEvent", - "StepExpectationResultEvent", - "StepWorkerStartedEvent", - "StepWorkerStartingEvent", - "MaterializationEvent", - "ObservationEvent", - "AssetMaterializationPlannedEvent", - "LogsCapturedEvent", - "AlertStartEvent", - "AlertSuccessEvent", - "AlertFailureEvent", - "AssetCheckEvaluationPlannedEvent", - "AssetCheckEvaluationEvent" - ], - "RunEvent": [ - "RunCanceledEvent", - "RunCancelingEvent", - "RunDequeuedEvent", - "RunEnqueuedEvent", - "RunFailureEvent", - "RunStartEvent", - "RunStartingEvent", - "RunSuccessEvent", - "AssetMaterializationPlannedEvent", - "AlertStartEvent", - "AlertSuccessEvent", - "AlertFailureEvent" - ], - "PipelineRunStepStats": [ - "RunStepStats" - ], - "StepEvent": [ - "EngineEvent", - "ExecutionStepFailureEvent", - "ExecutionStepInputEvent", - "ExecutionStepOutputEvent", - "ExecutionStepRestartEvent", - "ExecutionStepSkippedEvent", - "ExecutionStepStartEvent", - "ExecutionStepSuccessEvent", - "ExecutionStepUpForRetryEvent", - "HandledOutputEvent", - "HookCompletedEvent", - "HookErroredEvent", - "HookSkippedEvent", - "LoadedInputEvent", - "ObjectStoreOperationEvent", - "ResourceInitFailureEvent", - "ResourceInitStartedEvent", - "ResourceInitSuccessEvent", - "StepExpectationResultEvent", - "StepWorkerStartedEvent", - "StepWorkerStartingEvent", - "MaterializationEvent", - "ObservationEvent", - "AssetCheckEvaluationPlannedEvent", - "AssetCheckEvaluationEvent" - ], - "AssetPartitionStatuses": [ - "DefaultPartitionStatuses", - "MultiPartitionStatuses", - "TimePartitionStatuses" - ], - "PartitionStatus1D": [ - "TimePartitionStatuses", - "DefaultPartitionStatuses" - ], - "AssetChecksOrError": [ - "AssetChecks", - "AssetCheckNeedsMigrationError", - "AssetCheckNeedsUserCodeUpgrade", - "AssetCheckNeedsAgentUpgradeError" - ], - "Instigator": [ - "Schedule", - "Sensor" - ], - "EvaluationStackEntry": [ - "EvaluationStackListItemEntry", - "EvaluationStackPathEntry", - "EvaluationStackMapKeyEntry", - "EvaluationStackMapValueEntry" - ], - "IPipelineSnapshot": [ - "Pipeline", - "PipelineSnapshot", - "Job" - ], - "PipelineConfigValidationError": [ - "FieldNotDefinedConfigError", - "FieldsNotDefinedConfigError", - "MissingFieldConfigError", - "MissingFieldsConfigError", - "RuntimeMismatchConfigError", - "SelectorTypeConfigError" - ], - "PipelineConfigValidationInvalid": [ - "RunConfigValidationInvalid" - ], - "PipelineConfigValidationResult": [ - "InvalidSubsetError", - "PipelineConfigValidationValid", - "RunConfigValidationInvalid", - "PipelineNotFoundError", - "PythonError" - ], - "PipelineReference": [ - "PipelineSnapshot", - "UnknownPipeline" - ], - "PipelineRun": [ - "Run" - ], - "DagsterRunEvent": [ - "ExecutionStepFailureEvent", - "ExecutionStepInputEvent", - "ExecutionStepOutputEvent", - "ExecutionStepSkippedEvent", - "ExecutionStepStartEvent", - "ExecutionStepSuccessEvent", - "ExecutionStepUpForRetryEvent", - "ExecutionStepRestartEvent", - "LogMessageEvent", - "ResourceInitFailureEvent", - "ResourceInitStartedEvent", - "ResourceInitSuccessEvent", - "RunFailureEvent", - "RunStartEvent", - "RunEnqueuedEvent", - "RunDequeuedEvent", - "RunStartingEvent", - "RunCancelingEvent", - "RunCanceledEvent", - "RunSuccessEvent", - "StepWorkerStartedEvent", - "StepWorkerStartingEvent", - "HandledOutputEvent", - "LoadedInputEvent", - "LogsCapturedEvent", - "ObjectStoreOperationEvent", - "StepExpectationResultEvent", - "MaterializationEvent", - "ObservationEvent", - "EngineEvent", - "HookCompletedEvent", - "HookSkippedEvent", - "HookErroredEvent", - "AlertStartEvent", - "AlertSuccessEvent", - "AlertFailureEvent", - "AssetMaterializationPlannedEvent", - "AssetCheckEvaluationPlannedEvent", - "AssetCheckEvaluationEvent" - ], - "PipelineRunLogsSubscriptionPayload": [ - "PipelineRunLogsSubscriptionSuccess", - "PipelineRunLogsSubscriptionFailure" - ], - "RunOrError": [ - "Run", - "RunNotFoundError", - "PythonError" - ], - "PipelineRunStatsSnapshot": [ - "RunStatsSnapshot" - ], - "RunStatsSnapshotOrError": [ - "RunStatsSnapshot", - "PythonError" - ], - "PipelineSnapshotOrError": [ - "PipelineNotFoundError", - "PipelineSnapshot", - "PipelineSnapshotNotFoundError", - "PythonError" - ], - "AssetOrError": [ - "Asset", - "AssetNotFoundError" - ], - "AssetsOrError": [ - "AssetConnection", - "PythonError" - ], - "DeletePipelineRunResult": [ - "DeletePipelineRunSuccess", - "UnauthorizedError", - "PythonError", - "RunNotFoundError" - ], - "ExecutionPlanOrError": [ - "ExecutionPlan", - "RunConfigValidationInvalid", - "PipelineNotFoundError", - "InvalidSubsetError", - "PythonError" - ], - "PipelineOrError": [ - "Pipeline", - "PipelineNotFoundError", - "InvalidSubsetError", - "PythonError" - ], - "ReloadRepositoryLocationMutationResult": [ - "WorkspaceLocationEntry", - "ReloadNotSupported", - "RepositoryLocationNotFound", - "UnauthorizedError", - "PythonError" - ], - "RepositoryLocationOrLoadError": [ - "RepositoryLocation", - "PythonError" - ], - "ReloadWorkspaceMutationResult": [ - "Workspace", - "UnauthorizedError", - "PythonError" - ], - "ShutdownRepositoryLocationMutationResult": [ - "ShutdownRepositoryLocationSuccess", - "RepositoryLocationNotFound", - "UnauthorizedError", - "PythonError" - ], - "TerminatePipelineExecutionFailure": [ - "TerminateRunFailure" - ], - "TerminatePipelineExecutionSuccess": [ - "TerminateRunSuccess" - ], - "TerminateRunResult": [ - "TerminateRunSuccess", - "TerminateRunFailure", - "RunNotFoundError", - "UnauthorizedError", - "PythonError" - ], - "ScheduleMutationResult": [ - "PythonError", - "UnauthorizedError", - "ScheduleStateResult" - ], - "ScheduleOrError": [ - "Schedule", - "ScheduleNotFoundError", - "PythonError" - ], - "SchedulerOrError": [ - "Scheduler", - "SchedulerNotDefinedError", - "PythonError" - ], - "SchedulesOrError": [ - "Schedules", - "RepositoryNotFoundError", - "PythonError" - ], - "ScheduleTickSpecificData": [ - "ScheduleTickSuccessData", - "ScheduleTickFailureData" - ], - "LaunchBackfillResult": [ - "LaunchBackfillSuccess", - "PartitionSetNotFoundError", - "InvalidStepError", - "InvalidOutputError", - "RunConfigValidationInvalid", - "PipelineNotFoundError", - "RunConflict", - "UnauthorizedError", - "PythonError", - "InvalidSubsetError", - "PresetNotFoundError", - "ConflictingExecutionParamsError", - "NoModeProvidedError" - ], - "ConfigTypeOrError": [ - "EnumConfigType", - "CompositeConfigType", - "RegularConfigType", - "PipelineNotFoundError", - "ConfigTypeNotFoundError", - "PythonError" - ], - "ConfigType": [ - "ArrayConfigType", - "CompositeConfigType", - "EnumConfigType", - "NullableConfigType", - "RegularConfigType", - "ScalarUnionConfigType", - "MapConfigType" - ], - "WrappingConfigType": [ - "ArrayConfigType", - "NullableConfigType" - ], - "DagsterType": [ - "ListDagsterType", - "NullableDagsterType", - "RegularDagsterType" - ], - "DagsterTypeOrError": [ - "RegularDagsterType", - "PipelineNotFoundError", - "DagsterTypeNotFoundError", - "PythonError" - ], - "WrappingDagsterType": [ - "ListDagsterType", - "NullableDagsterType" - ], - "Error": [ - "AssetCheckNeedsMigrationError", - "AssetCheckNeedsUserCodeUpgrade", - "AssetCheckNeedsAgentUpgradeError", - "AssetNotFoundError", - "ConflictingExecutionParamsError", - "ConfigTypeNotFoundError", - "DagsterTypeNotFoundError", - "InvalidPipelineRunsFilterError", - "InvalidSubsetError", - "ModeNotFoundError", - "NoModeProvidedError", - "PartitionSetNotFoundError", - "PipelineNotFoundError", - "RunConflict", - "PipelineSnapshotNotFoundError", - "PresetNotFoundError", - "PythonError", - "ErrorChainLink", - "UnauthorizedError", - "ReloadNotSupported", - "RepositoryLocationNotFound", - "RepositoryNotFoundError", - "ResourceNotFoundError", - "RunGroupNotFoundError", - "RunNotFoundError", - "ScheduleNotFoundError", - "SchedulerNotDefinedError", - "SensorNotFoundError", - "DuplicateDynamicPartitionError", - "InstigationStateNotFoundError", - "SolidStepStatusUnavailableError", - "GraphNotFoundError", - "BackfillNotFoundError", - "PartitionSubsetDeserializationError", - "AutoMaterializeAssetEvaluationNeedsMigrationError" - ], - "PipelineRunConflict": [ - "RunConflict" - ], - "PipelineRunNotFoundError": [ - "RunNotFoundError" - ], - "RepositoriesOrError": [ - "RepositoryConnection", - "PythonError" - ], - "RepositoryOrError": [ - "PythonError", - "Repository", - "RepositoryNotFoundError" - ], - "InstigationTypeSpecificData": [ - "SensorData", - "ScheduleData" - ], - "InstigationStateOrError": [ - "InstigationState", - "InstigationStateNotFoundError", - "PythonError" - ], - "InstigationStatesOrError": [ - "InstigationStates", - "PythonError" - ], - "MetadataEntry": [ - "TableSchemaMetadataEntry", - "TableMetadataEntry", - "FloatMetadataEntry", - "IntMetadataEntry", - "JsonMetadataEntry", - "BoolMetadataEntry", - "MarkdownMetadataEntry", - "PathMetadataEntry", - "NotebookMetadataEntry", - "PythonArtifactMetadataEntry", - "TextMetadataEntry", - "UrlMetadataEntry", - "PipelineRunMetadataEntry", - "AssetMetadataEntry", - "JobMetadataEntry", - "NullMetadataEntry" - ], - "PartitionRunConfigOrError": [ - "PartitionRunConfig", - "PythonError" - ], - "AssetBackfillStatus": [ - "AssetPartitionsStatusCounts", - "UnpartitionedAssetStatus" - ], - "PartitionSetOrError": [ - "PartitionSet", - "PartitionSetNotFoundError", - "PythonError" - ], - "PartitionSetsOrError": [ - "PartitionSets", - "PipelineNotFoundError", - "PythonError" - ], - "PartitionsOrError": [ - "Partitions", - "PythonError" - ], - "PartitionStatusesOrError": [ - "PartitionStatuses", - "PythonError" - ], - "PartitionTagsOrError": [ - "PartitionTags", - "PythonError" - ], - "RunConfigSchemaOrError": [ - "RunConfigSchema", - "PipelineNotFoundError", - "InvalidSubsetError", - "ModeNotFoundError", - "PythonError" - ], - "LaunchRunResult": [ - "LaunchRunSuccess", - "InvalidStepError", - "InvalidOutputError", - "RunConfigValidationInvalid", - "PipelineNotFoundError", - "RunConflict", - "UnauthorizedError", - "PythonError", - "InvalidSubsetError", - "PresetNotFoundError", - "ConflictingExecutionParamsError", - "NoModeProvidedError" - ], - "LaunchRunReexecutionResult": [ - "LaunchRunSuccess", - "InvalidStepError", - "InvalidOutputError", - "RunConfigValidationInvalid", - "PipelineNotFoundError", - "RunConflict", - "UnauthorizedError", - "PythonError", - "InvalidSubsetError", - "PresetNotFoundError", - "ConflictingExecutionParamsError", - "NoModeProvidedError" - ], - "LaunchPipelineRunSuccess": [ - "LaunchRunSuccess" - ], - "RunsOrError": [ - "Runs", - "InvalidPipelineRunsFilterError", - "PythonError" - ], - "PipelineRuns": [ - "Runs" - ], - "RunGroupOrError": [ - "RunGroup", - "RunGroupNotFoundError", - "PythonError" - ], - "SensorOrError": [ - "Sensor", - "SensorNotFoundError", - "UnauthorizedError", - "PythonError" - ], - "SensorsOrError": [ - "Sensors", - "RepositoryNotFoundError", - "PythonError" - ], - "StopSensorMutationResultOrError": [ - "StopSensorMutationResult", - "UnauthorizedError", - "PythonError" - ], - "ISolidDefinition": [ - "CompositeSolidDefinition", - "SolidDefinition" - ], - "SolidContainer": [ - "Pipeline", - "PipelineSnapshot", - "Job", - "CompositeSolidDefinition", - "Graph" - ], - "SolidStepStatsOrError": [ - "SolidStepStatsConnection", - "SolidStepStatusUnavailableError" - ], - "WorkspaceOrError": [ - "Workspace", - "PythonError" - ], - "WorkspaceLocationStatusEntriesOrError": [ - "WorkspaceLocationStatusEntries", - "PythonError" - ], - "GraphOrError": [ - "Graph", - "GraphNotFoundError", - "PythonError" - ], - "ResourceDetailsOrError": [ - "ResourceDetails", - "ResourceNotFoundError", - "PythonError" - ], - "ResourcesOrError": [ - "ResourceDetailsList", - "RepositoryNotFoundError", - "PythonError" - ], - "EnvVarWithConsumersOrError": [ - "EnvVarWithConsumersList", - "PythonError" - ], - "RunTagKeysOrError": [ - "PythonError", - "RunTagKeys" - ], - "RunTagsOrError": [ - "PythonError", - "RunTags" - ], - "RunIdsOrError": [ - "RunIds", - "InvalidPipelineRunsFilterError", - "PythonError" - ], - "AssetNodeOrError": [ - "AssetNode", - "AssetNotFoundError" - ], - "PartitionBackfillOrError": [ - "PartitionBackfill", - "BackfillNotFoundError", - "PythonError" - ], - "PartitionBackfillsOrError": [ - "PartitionBackfills", - "PythonError" - ], - "EventConnectionOrError": [ - "EventConnection", - "RunNotFoundError", - "PythonError" - ], - "AutoMaterializeAssetEvaluationRecordsOrError": [ - "AutoMaterializeAssetEvaluationRecords", - "AutoMaterializeAssetEvaluationNeedsMigrationError" - ], - "PartitionKeysOrError": [ - "PartitionKeys", - "PartitionSubsetDeserializationError" - ], - "AutoMaterializeRuleEvaluationData": [ - "TextRuleEvaluationData", - "ParentMaterializedRuleEvaluationData", - "WaitingOnKeysRuleEvaluationData" - ], - "AssetConditionEvaluationNode": [ - "UnpartitionedAssetConditionEvaluationNode", - "PartitionedAssetConditionEvaluationNode", - "SpecificPartitionAssetConditionEvaluationNode" - ], - "AssetConditionEvaluationRecordsOrError": [ - "AssetConditionEvaluationRecords", - "AutoMaterializeAssetEvaluationNeedsMigrationError" - ], - "SensorDryRunResult": [ - "PythonError", - "SensorNotFoundError", - "DryRunInstigationTick" - ], - "ScheduleDryRunResult": [ - "DryRunInstigationTick", - "PythonError", - "ScheduleNotFoundError" - ], - "TerminateRunsResultOrError": [ - "TerminateRunsResult", - "PythonError" - ], - "AssetWipeMutationResult": [ - "AssetNotFoundError", - "UnauthorizedError", - "PythonError", - "AssetWipeSuccess" - ], - "ReportRunlessAssetEventsResult": [ - "UnauthorizedError", - "PythonError", - "ReportRunlessAssetEventsSuccess" - ], - "ResumeBackfillResult": [ - "ResumeBackfillSuccess", - "UnauthorizedError", - "PythonError" - ], - "CancelBackfillResult": [ - "CancelBackfillSuccess", - "UnauthorizedError", - "PythonError" - ], - "LogTelemetryMutationResult": [ - "LogTelemetrySuccess", - "PythonError" - ], - "AddDynamicPartitionResult": [ - "AddDynamicPartitionSuccess", - "UnauthorizedError", - "PythonError", - "DuplicateDynamicPartitionError" - ] -} ->>>>>>> 7049e7d26b (??) -======= -{"DisplayableEvent":["EngineEvent","ExecutionStepOutputEvent","ExpectationResult","FailureMetadata","HandledOutputEvent","LoadedInputEvent","ObjectStoreOperationResult","ResourceInitFailureEvent","ResourceInitStartedEvent","ResourceInitSuccessEvent","StepWorkerStartedEvent","StepWorkerStartingEvent","MaterializationEvent","ObservationEvent","TypeCheck"],"MarkerEvent":["EngineEvent","ResourceInitFailureEvent","ResourceInitStartedEvent","ResourceInitSuccessEvent","StepWorkerStartedEvent","StepWorkerStartingEvent"],"ErrorEvent":["EngineEvent","ExecutionStepFailureEvent","ExecutionStepUpForRetryEvent","HookErroredEvent","RunFailureEvent","ResourceInitFailureEvent"],"MessageEvent":["EngineEvent","ExecutionStepFailureEvent","ExecutionStepInputEvent","ExecutionStepOutputEvent","ExecutionStepRestartEvent","ExecutionStepSkippedEvent","ExecutionStepStartEvent","ExecutionStepSuccessEvent","ExecutionStepUpForRetryEvent","HandledOutputEvent","HookCompletedEvent","HookErroredEvent","HookSkippedEvent","LoadedInputEvent","LogMessageEvent","ObjectStoreOperationEvent","RunCanceledEvent","RunCancelingEvent","RunDequeuedEvent","RunEnqueuedEvent","RunFailureEvent","ResourceInitFailureEvent","ResourceInitStartedEvent","ResourceInitSuccessEvent","RunStartEvent","RunStartingEvent","RunSuccessEvent","StepExpectationResultEvent","StepWorkerStartedEvent","StepWorkerStartingEvent","MaterializationEvent","ObservationEvent","AssetMaterializationPlannedEvent","LogsCapturedEvent","AlertStartEvent","AlertSuccessEvent","AlertFailureEvent","AssetCheckEvaluationPlannedEvent","AssetCheckEvaluationEvent"],"RunEvent":["RunCanceledEvent","RunCancelingEvent","RunDequeuedEvent","RunEnqueuedEvent","RunFailureEvent","RunStartEvent","RunStartingEvent","RunSuccessEvent","AssetMaterializationPlannedEvent","AlertStartEvent","AlertSuccessEvent","AlertFailureEvent"],"PipelineRunStepStats":["RunStepStats"],"StepEvent":["EngineEvent","ExecutionStepFailureEvent","ExecutionStepInputEvent","ExecutionStepOutputEvent","ExecutionStepRestartEvent","ExecutionStepSkippedEvent","ExecutionStepStartEvent","ExecutionStepSuccessEvent","ExecutionStepUpForRetryEvent","HandledOutputEvent","HookCompletedEvent","HookErroredEvent","HookSkippedEvent","LoadedInputEvent","ObjectStoreOperationEvent","ResourceInitFailureEvent","ResourceInitStartedEvent","ResourceInitSuccessEvent","StepExpectationResultEvent","StepWorkerStartedEvent","StepWorkerStartingEvent","MaterializationEvent","ObservationEvent","AssetCheckEvaluationPlannedEvent","AssetCheckEvaluationEvent"],"AssetPartitionStatuses":["DefaultPartitionStatuses","MultiPartitionStatuses","TimePartitionStatuses"],"PartitionStatus1D":["TimePartitionStatuses","DefaultPartitionStatuses"],"AssetChecksOrError":["AssetChecks","AssetCheckNeedsMigrationError","AssetCheckNeedsUserCodeUpgrade","AssetCheckNeedsAgentUpgradeError"],"Instigator":["Schedule","Sensor"],"EvaluationStackEntry":["EvaluationStackListItemEntry","EvaluationStackPathEntry","EvaluationStackMapKeyEntry","EvaluationStackMapValueEntry"],"IPipelineSnapshot":["Pipeline","PipelineSnapshot","Job"],"PipelineConfigValidationError":["FieldNotDefinedConfigError","FieldsNotDefinedConfigError","MissingFieldConfigError","MissingFieldsConfigError","RuntimeMismatchConfigError","SelectorTypeConfigError"],"PipelineConfigValidationInvalid":["RunConfigValidationInvalid"],"PipelineConfigValidationResult":["InvalidSubsetError","PipelineConfigValidationValid","RunConfigValidationInvalid","PipelineNotFoundError","PythonError"],"PipelineReference":["PipelineSnapshot","UnknownPipeline"],"PipelineRun":["Run"],"DagsterRunEvent":["ExecutionStepFailureEvent","ExecutionStepInputEvent","ExecutionStepOutputEvent","ExecutionStepSkippedEvent","ExecutionStepStartEvent","ExecutionStepSuccessEvent","ExecutionStepUpForRetryEvent","ExecutionStepRestartEvent","LogMessageEvent","ResourceInitFailureEvent","ResourceInitStartedEvent","ResourceInitSuccessEvent","RunFailureEvent","RunStartEvent","RunEnqueuedEvent","RunDequeuedEvent","RunStartingEvent","RunCancelingEvent","RunCanceledEvent","RunSuccessEvent","StepWorkerStartedEvent","StepWorkerStartingEvent","HandledOutputEvent","LoadedInputEvent","LogsCapturedEvent","ObjectStoreOperationEvent","StepExpectationResultEvent","MaterializationEvent","ObservationEvent","EngineEvent","HookCompletedEvent","HookSkippedEvent","HookErroredEvent","AlertStartEvent","AlertSuccessEvent","AlertFailureEvent","AssetMaterializationPlannedEvent","AssetCheckEvaluationPlannedEvent","AssetCheckEvaluationEvent"],"PipelineRunLogsSubscriptionPayload":["PipelineRunLogsSubscriptionSuccess","PipelineRunLogsSubscriptionFailure"],"RunOrError":["Run","RunNotFoundError","PythonError"],"PipelineRunStatsSnapshot":["RunStatsSnapshot"],"RunStatsSnapshotOrError":["RunStatsSnapshot","PythonError"],"PipelineSnapshotOrError":["PipelineNotFoundError","PipelineSnapshot","PipelineSnapshotNotFoundError","PythonError"],"AssetOrError":["Asset","AssetNotFoundError"],"AssetsOrError":["AssetConnection","PythonError"],"DeletePipelineRunResult":["DeletePipelineRunSuccess","UnauthorizedError","PythonError","RunNotFoundError"],"ExecutionPlanOrError":["ExecutionPlan","RunConfigValidationInvalid","PipelineNotFoundError","InvalidSubsetError","PythonError"],"PipelineOrError":["Pipeline","PipelineNotFoundError","InvalidSubsetError","PythonError"],"ReloadRepositoryLocationMutationResult":["WorkspaceLocationEntry","ReloadNotSupported","RepositoryLocationNotFound","UnauthorizedError","PythonError"],"RepositoryLocationOrLoadError":["RepositoryLocation","PythonError"],"ReloadWorkspaceMutationResult":["Workspace","UnauthorizedError","PythonError"],"ShutdownRepositoryLocationMutationResult":["ShutdownRepositoryLocationSuccess","RepositoryLocationNotFound","UnauthorizedError","PythonError"],"TerminatePipelineExecutionFailure":["TerminateRunFailure"],"TerminatePipelineExecutionSuccess":["TerminateRunSuccess"],"TerminateRunResult":["TerminateRunSuccess","TerminateRunFailure","RunNotFoundError","UnauthorizedError","PythonError"],"ScheduleMutationResult":["PythonError","UnauthorizedError","ScheduleStateResult"],"ScheduleOrError":["Schedule","ScheduleNotFoundError","PythonError"],"SchedulerOrError":["Scheduler","SchedulerNotDefinedError","PythonError"],"SchedulesOrError":["Schedules","RepositoryNotFoundError","PythonError"],"ScheduleTickSpecificData":["ScheduleTickSuccessData","ScheduleTickFailureData"],"LaunchBackfillResult":["LaunchBackfillSuccess","PartitionSetNotFoundError","InvalidStepError","InvalidOutputError","RunConfigValidationInvalid","PipelineNotFoundError","RunConflict","UnauthorizedError","PythonError","InvalidSubsetError","PresetNotFoundError","ConflictingExecutionParamsError","NoModeProvidedError"],"ConfigTypeOrError":["EnumConfigType","CompositeConfigType","RegularConfigType","PipelineNotFoundError","ConfigTypeNotFoundError","PythonError"],"ConfigType":["ArrayConfigType","CompositeConfigType","EnumConfigType","NullableConfigType","RegularConfigType","ScalarUnionConfigType","MapConfigType"],"WrappingConfigType":["ArrayConfigType","NullableConfigType"],"DagsterType":["ListDagsterType","NullableDagsterType","RegularDagsterType"],"DagsterTypeOrError":["RegularDagsterType","PipelineNotFoundError","DagsterTypeNotFoundError","PythonError"],"WrappingDagsterType":["ListDagsterType","NullableDagsterType"],"Error":["AssetCheckNeedsMigrationError","AssetCheckNeedsUserCodeUpgrade","AssetCheckNeedsAgentUpgradeError","AssetNotFoundError","ConflictingExecutionParamsError","ConfigTypeNotFoundError","DagsterTypeNotFoundError","InvalidPipelineRunsFilterError","InvalidSubsetError","ModeNotFoundError","NoModeProvidedError","PartitionSetNotFoundError","PipelineNotFoundError","RunConflict","PipelineSnapshotNotFoundError","PresetNotFoundError","PythonError","ErrorChainLink","UnauthorizedError","ReloadNotSupported","RepositoryLocationNotFound","RepositoryNotFoundError","ResourceNotFoundError","RunGroupNotFoundError","RunNotFoundError","ScheduleNotFoundError","SchedulerNotDefinedError","SensorNotFoundError","DuplicateDynamicPartitionError","InstigationStateNotFoundError","SolidStepStatusUnavailableError","GraphNotFoundError","BackfillNotFoundError","PartitionSubsetDeserializationError","AutoMaterializeAssetEvaluationNeedsMigrationError"],"PipelineRunConflict":["RunConflict"],"PipelineRunNotFoundError":["RunNotFoundError"],"RepositoriesOrError":["RepositoryConnection","PythonError"],"RepositoryOrError":["PythonError","Repository","RepositoryNotFoundError"],"InstigationTypeSpecificData":["SensorData","ScheduleData"],"InstigationStateOrError":["InstigationState","InstigationStateNotFoundError","PythonError"],"InstigationStatesOrError":["InstigationStates","PythonError"],"MetadataEntry":["TableSchemaMetadataEntry","TableMetadataEntry","FloatMetadataEntry","IntMetadataEntry","JsonMetadataEntry","BoolMetadataEntry","MarkdownMetadataEntry","PathMetadataEntry","NotebookMetadataEntry","PythonArtifactMetadataEntry","TextMetadataEntry","UrlMetadataEntry","PipelineRunMetadataEntry","AssetMetadataEntry","JobMetadataEntry","NullMetadataEntry"],"PartitionRunConfigOrError":["PartitionRunConfig","PythonError"],"AssetBackfillStatus":["AssetPartitionsStatusCounts","UnpartitionedAssetStatus"],"PartitionSetOrError":["PartitionSet","PartitionSetNotFoundError","PythonError"],"PartitionSetsOrError":["PartitionSets","PipelineNotFoundError","PythonError"],"PartitionsOrError":["Partitions","PythonError"],"PartitionStatusesOrError":["PartitionStatuses","PythonError"],"PartitionTagsOrError":["PartitionTags","PythonError"],"RunConfigSchemaOrError":["RunConfigSchema","PipelineNotFoundError","InvalidSubsetError","ModeNotFoundError","PythonError"],"LaunchRunResult":["LaunchRunSuccess","InvalidStepError","InvalidOutputError","RunConfigValidationInvalid","PipelineNotFoundError","RunConflict","UnauthorizedError","PythonError","InvalidSubsetError","PresetNotFoundError","ConflictingExecutionParamsError","NoModeProvidedError"],"LaunchRunReexecutionResult":["LaunchRunSuccess","InvalidStepError","InvalidOutputError","RunConfigValidationInvalid","PipelineNotFoundError","RunConflict","UnauthorizedError","PythonError","InvalidSubsetError","PresetNotFoundError","ConflictingExecutionParamsError","NoModeProvidedError"],"LaunchPipelineRunSuccess":["LaunchRunSuccess"],"RunsOrError":["Runs","InvalidPipelineRunsFilterError","PythonError"],"PipelineRuns":["Runs"],"RunGroupOrError":["RunGroup","RunGroupNotFoundError","PythonError"],"SensorOrError":["Sensor","SensorNotFoundError","UnauthorizedError","PythonError"],"SensorsOrError":["Sensors","RepositoryNotFoundError","PythonError"],"StopSensorMutationResultOrError":["StopSensorMutationResult","UnauthorizedError","PythonError"],"ISolidDefinition":["CompositeSolidDefinition","SolidDefinition"],"SolidContainer":["Pipeline","PipelineSnapshot","Job","CompositeSolidDefinition","Graph"],"SolidStepStatsOrError":["SolidStepStatsConnection","SolidStepStatusUnavailableError"],"WorkspaceOrError":["Workspace","PythonError"],"WorkspaceLocationStatusEntriesOrError":["WorkspaceLocationStatusEntries","PythonError"],"GraphOrError":["Graph","GraphNotFoundError","PythonError"],"ResourceDetailsOrError":["ResourceDetails","ResourceNotFoundError","PythonError"],"ResourcesOrError":["ResourceDetailsList","RepositoryNotFoundError","PythonError"],"EnvVarWithConsumersOrError":["EnvVarWithConsumersList","PythonError"],"RunTagKeysOrError":["PythonError","RunTagKeys"],"RunTagsOrError":["PythonError","RunTags"],"RunIdsOrError":["RunIds","InvalidPipelineRunsFilterError","PythonError"],"AssetNodeOrError":["AssetNode","AssetNotFoundError"],"PartitionBackfillOrError":["PartitionBackfill","BackfillNotFoundError","PythonError"],"PartitionBackfillsOrError":["PartitionBackfills","PythonError"],"EventConnectionOrError":["EventConnection","RunNotFoundError","PythonError"],"AutoMaterializeAssetEvaluationRecordsOrError":["AutoMaterializeAssetEvaluationRecords","AutoMaterializeAssetEvaluationNeedsMigrationError"],"PartitionKeysOrError":["PartitionKeys","PartitionSubsetDeserializationError"],"AutoMaterializeRuleEvaluationData":["TextRuleEvaluationData","ParentMaterializedRuleEvaluationData","WaitingOnKeysRuleEvaluationData"],"AssetConditionEvaluationNode":["UnpartitionedAssetConditionEvaluationNode","PartitionedAssetConditionEvaluationNode","SpecificPartitionAssetConditionEvaluationNode"],"AssetConditionEvaluationRecordsOrError":["AssetConditionEvaluationRecords","AutoMaterializeAssetEvaluationNeedsMigrationError"],"SensorDryRunResult":["PythonError","SensorNotFoundError","DryRunInstigationTick"],"ScheduleDryRunResult":["DryRunInstigationTick","PythonError","ScheduleNotFoundError"],"TerminateRunsResultOrError":["TerminateRunsResult","PythonError"],"AssetWipeMutationResult":["AssetNotFoundError","UnauthorizedError","PythonError","AssetWipeSuccess"],"ReportRunlessAssetEventsResult":["UnauthorizedError","PythonError","ReportRunlessAssetEventsSuccess"],"ResumeBackfillResult":["ResumeBackfillSuccess","UnauthorizedError","PythonError"],"CancelBackfillResult":["CancelBackfillSuccess","UnauthorizedError","PythonError"],"LogTelemetryMutationResult":["LogTelemetrySuccess","PythonError"],"AddDynamicPartitionResult":["AddDynamicPartitionSuccess","UnauthorizedError","PythonError","DuplicateDynamicPartitionError"]} ->>>>>>> 6f08cc6d66 (...) +{"DisplayableEvent":["EngineEvent","ExecutionStepOutputEvent","ExpectationResult","FailureMetadata","HandledOutputEvent","LoadedInputEvent","ObjectStoreOperationResult","ResourceInitFailureEvent","ResourceInitStartedEvent","ResourceInitSuccessEvent","StepWorkerStartedEvent","StepWorkerStartingEvent","MaterializationEvent","ObservationEvent","TypeCheck"],"MarkerEvent":["EngineEvent","ResourceInitFailureEvent","ResourceInitStartedEvent","ResourceInitSuccessEvent","StepWorkerStartedEvent","StepWorkerStartingEvent"],"ErrorEvent":["EngineEvent","ExecutionStepFailureEvent","ExecutionStepUpForRetryEvent","HookErroredEvent","RunFailureEvent","ResourceInitFailureEvent"],"MessageEvent":["EngineEvent","ExecutionStepFailureEvent","ExecutionStepInputEvent","ExecutionStepOutputEvent","ExecutionStepRestartEvent","ExecutionStepSkippedEvent","ExecutionStepStartEvent","ExecutionStepSuccessEvent","ExecutionStepUpForRetryEvent","HandledOutputEvent","HookCompletedEvent","HookErroredEvent","HookSkippedEvent","LoadedInputEvent","LogMessageEvent","ObjectStoreOperationEvent","RunCanceledEvent","RunCancelingEvent","RunDequeuedEvent","RunEnqueuedEvent","RunFailureEvent","ResourceInitFailureEvent","ResourceInitStartedEvent","ResourceInitSuccessEvent","RunStartEvent","RunStartingEvent","RunSuccessEvent","StepExpectationResultEvent","StepWorkerStartedEvent","StepWorkerStartingEvent","MaterializationEvent","ObservationEvent","AssetMaterializationPlannedEvent","LogsCapturedEvent","AlertStartEvent","AlertSuccessEvent","AlertFailureEvent","AssetCheckEvaluationPlannedEvent","AssetCheckEvaluationEvent"],"RunEvent":["RunCanceledEvent","RunCancelingEvent","RunDequeuedEvent","RunEnqueuedEvent","RunFailureEvent","RunStartEvent","RunStartingEvent","RunSuccessEvent","AssetMaterializationPlannedEvent","AlertStartEvent","AlertSuccessEvent","AlertFailureEvent"],"PipelineRunStepStats":["RunStepStats"],"StepEvent":["EngineEvent","ExecutionStepFailureEvent","ExecutionStepInputEvent","ExecutionStepOutputEvent","ExecutionStepRestartEvent","ExecutionStepSkippedEvent","ExecutionStepStartEvent","ExecutionStepSuccessEvent","ExecutionStepUpForRetryEvent","HandledOutputEvent","HookCompletedEvent","HookErroredEvent","HookSkippedEvent","LoadedInputEvent","ObjectStoreOperationEvent","ResourceInitFailureEvent","ResourceInitStartedEvent","ResourceInitSuccessEvent","StepExpectationResultEvent","StepWorkerStartedEvent","StepWorkerStartingEvent","MaterializationEvent","ObservationEvent","AssetCheckEvaluationPlannedEvent","AssetCheckEvaluationEvent"],"AssetPartitionStatuses":["DefaultPartitionStatuses","MultiPartitionStatuses","TimePartitionStatuses"],"PartitionStatus1D":["TimePartitionStatuses","DefaultPartitionStatuses"],"AssetChecksOrError":["AssetChecks","AssetCheckNeedsMigrationError","AssetCheckNeedsUserCodeUpgrade","AssetCheckNeedsAgentUpgradeError"],"Instigator":["Schedule","Sensor"],"EvaluationStackEntry":["EvaluationStackListItemEntry","EvaluationStackPathEntry","EvaluationStackMapKeyEntry","EvaluationStackMapValueEntry"],"IPipelineSnapshot":["Pipeline","PipelineSnapshot","Job"],"PipelineConfigValidationError":["FieldNotDefinedConfigError","FieldsNotDefinedConfigError","MissingFieldConfigError","MissingFieldsConfigError","RuntimeMismatchConfigError","SelectorTypeConfigError"],"PipelineConfigValidationInvalid":["RunConfigValidationInvalid"],"PipelineConfigValidationResult":["InvalidSubsetError","PipelineConfigValidationValid","RunConfigValidationInvalid","PipelineNotFoundError","PythonError"],"PipelineReference":["PipelineSnapshot","UnknownPipeline"],"PipelineRun":["Run"],"DagsterRunEvent":["ExecutionStepFailureEvent","ExecutionStepInputEvent","ExecutionStepOutputEvent","ExecutionStepSkippedEvent","ExecutionStepStartEvent","ExecutionStepSuccessEvent","ExecutionStepUpForRetryEvent","ExecutionStepRestartEvent","LogMessageEvent","ResourceInitFailureEvent","ResourceInitStartedEvent","ResourceInitSuccessEvent","RunFailureEvent","RunStartEvent","RunEnqueuedEvent","RunDequeuedEvent","RunStartingEvent","RunCancelingEvent","RunCanceledEvent","RunSuccessEvent","StepWorkerStartedEvent","StepWorkerStartingEvent","HandledOutputEvent","LoadedInputEvent","LogsCapturedEvent","ObjectStoreOperationEvent","StepExpectationResultEvent","MaterializationEvent","ObservationEvent","EngineEvent","HookCompletedEvent","HookSkippedEvent","HookErroredEvent","AlertStartEvent","AlertSuccessEvent","AlertFailureEvent","AssetMaterializationPlannedEvent","AssetCheckEvaluationPlannedEvent","AssetCheckEvaluationEvent"],"PipelineRunLogsSubscriptionPayload":["PipelineRunLogsSubscriptionSuccess","PipelineRunLogsSubscriptionFailure"],"RunOrError":["Run","RunNotFoundError","PythonError"],"PipelineRunStatsSnapshot":["RunStatsSnapshot"],"RunStatsSnapshotOrError":["RunStatsSnapshot","PythonError"],"PipelineSnapshotOrError":["PipelineNotFoundError","PipelineSnapshot","PipelineSnapshotNotFoundError","PythonError"],"AssetOrError":["Asset","AssetNotFoundError"],"AssetsOrError":["AssetConnection","PythonError"],"DeletePipelineRunResult":["DeletePipelineRunSuccess","UnauthorizedError","PythonError","RunNotFoundError"],"ExecutionPlanOrError":["ExecutionPlan","RunConfigValidationInvalid","PipelineNotFoundError","InvalidSubsetError","PythonError"],"PipelineOrError":["Pipeline","PipelineNotFoundError","InvalidSubsetError","PythonError"],"ReloadRepositoryLocationMutationResult":["WorkspaceLocationEntry","ReloadNotSupported","RepositoryLocationNotFound","UnauthorizedError","PythonError"],"RepositoryLocationOrLoadError":["RepositoryLocation","PythonError"],"ReloadWorkspaceMutationResult":["Workspace","UnauthorizedError","PythonError"],"ShutdownRepositoryLocationMutationResult":["ShutdownRepositoryLocationSuccess","RepositoryLocationNotFound","UnauthorizedError","PythonError"],"TerminatePipelineExecutionFailure":["TerminateRunFailure"],"TerminatePipelineExecutionSuccess":["TerminateRunSuccess"],"TerminateRunResult":["TerminateRunSuccess","TerminateRunFailure","RunNotFoundError","UnauthorizedError","PythonError"],"ScheduleMutationResult":["PythonError","UnauthorizedError","ScheduleStateResult"],"ScheduleOrError":["Schedule","ScheduleNotFoundError","PythonError"],"SchedulerOrError":["Scheduler","SchedulerNotDefinedError","PythonError"],"SchedulesOrError":["Schedules","RepositoryNotFoundError","PythonError"],"ScheduleTickSpecificData":["ScheduleTickSuccessData","ScheduleTickFailureData"],"LaunchBackfillResult":["LaunchBackfillSuccess","PartitionSetNotFoundError","InvalidStepError","InvalidOutputError","RunConfigValidationInvalid","PipelineNotFoundError","RunConflict","UnauthorizedError","PythonError","InvalidSubsetError","PresetNotFoundError","ConflictingExecutionParamsError","NoModeProvidedError"],"ConfigTypeOrError":["EnumConfigType","CompositeConfigType","RegularConfigType","PipelineNotFoundError","ConfigTypeNotFoundError","PythonError"],"ConfigType":["ArrayConfigType","CompositeConfigType","EnumConfigType","NullableConfigType","RegularConfigType","ScalarUnionConfigType","MapConfigType"],"WrappingConfigType":["ArrayConfigType","NullableConfigType"],"DagsterType":["ListDagsterType","NullableDagsterType","RegularDagsterType"],"DagsterTypeOrError":["RegularDagsterType","PipelineNotFoundError","DagsterTypeNotFoundError","PythonError"],"WrappingDagsterType":["ListDagsterType","NullableDagsterType"],"Error":["AssetCheckNeedsMigrationError","AssetCheckNeedsUserCodeUpgrade","AssetCheckNeedsAgentUpgradeError","AssetNotFoundError","ConflictingExecutionParamsError","ConfigTypeNotFoundError","DagsterTypeNotFoundError","InvalidPipelineRunsFilterError","InvalidSubsetError","ModeNotFoundError","NoModeProvidedError","PartitionSetNotFoundError","PipelineNotFoundError","RunConflict","PipelineSnapshotNotFoundError","PresetNotFoundError","PythonError","ErrorChainLink","UnauthorizedError","ReloadNotSupported","RepositoryLocationNotFound","RepositoryNotFoundError","ResourceNotFoundError","RunGroupNotFoundError","RunNotFoundError","ScheduleNotFoundError","SchedulerNotDefinedError","SensorNotFoundError","DuplicateDynamicPartitionError","InstigationStateNotFoundError","SolidStepStatusUnavailableError","GraphNotFoundError","BackfillNotFoundError","PartitionSubsetDeserializationError","AutoMaterializeAssetEvaluationNeedsMigrationError"],"PipelineRunConflict":["RunConflict"],"PipelineRunNotFoundError":["RunNotFoundError"],"RepositoriesOrError":["RepositoryConnection","RepositoryNotFoundError","PythonError"],"RepositoryOrError":["PythonError","Repository","RepositoryNotFoundError"],"InstigationTypeSpecificData":["SensorData","ScheduleData"],"InstigationStateOrError":["InstigationState","InstigationStateNotFoundError","PythonError"],"InstigationStatesOrError":["InstigationStates","PythonError"],"MetadataEntry":["TableSchemaMetadataEntry","TableMetadataEntry","FloatMetadataEntry","IntMetadataEntry","JsonMetadataEntry","BoolMetadataEntry","MarkdownMetadataEntry","PathMetadataEntry","NotebookMetadataEntry","PythonArtifactMetadataEntry","TextMetadataEntry","UrlMetadataEntry","PipelineRunMetadataEntry","AssetMetadataEntry","JobMetadataEntry","NullMetadataEntry"],"PartitionRunConfigOrError":["PartitionRunConfig","PythonError"],"AssetBackfillStatus":["AssetPartitionsStatusCounts","UnpartitionedAssetStatus"],"PartitionSetOrError":["PartitionSet","PartitionSetNotFoundError","PythonError"],"PartitionSetsOrError":["PartitionSets","PipelineNotFoundError","PythonError"],"PartitionsOrError":["Partitions","PythonError"],"PartitionStatusesOrError":["PartitionStatuses","PythonError"],"PartitionTagsOrError":["PartitionTags","PythonError"],"RunConfigSchemaOrError":["RunConfigSchema","PipelineNotFoundError","InvalidSubsetError","ModeNotFoundError","PythonError"],"LaunchRunResult":["LaunchRunSuccess","InvalidStepError","InvalidOutputError","RunConfigValidationInvalid","PipelineNotFoundError","RunConflict","UnauthorizedError","PythonError","InvalidSubsetError","PresetNotFoundError","ConflictingExecutionParamsError","NoModeProvidedError"],"LaunchRunReexecutionResult":["LaunchRunSuccess","InvalidStepError","InvalidOutputError","RunConfigValidationInvalid","PipelineNotFoundError","RunConflict","UnauthorizedError","PythonError","InvalidSubsetError","PresetNotFoundError","ConflictingExecutionParamsError","NoModeProvidedError"],"LaunchPipelineRunSuccess":["LaunchRunSuccess"],"RunsOrError":["Runs","InvalidPipelineRunsFilterError","PythonError"],"PipelineRuns":["Runs"],"RunGroupOrError":["RunGroup","RunGroupNotFoundError","PythonError"],"SensorOrError":["Sensor","SensorNotFoundError","UnauthorizedError","PythonError"],"SensorsOrError":["Sensors","RepositoryNotFoundError","PythonError"],"StopSensorMutationResultOrError":["StopSensorMutationResult","UnauthorizedError","PythonError"],"ISolidDefinition":["CompositeSolidDefinition","SolidDefinition"],"SolidContainer":["Pipeline","PipelineSnapshot","Job","CompositeSolidDefinition","Graph"],"SolidStepStatsOrError":["SolidStepStatsConnection","SolidStepStatusUnavailableError"],"WorkspaceOrError":["Workspace","PythonError"],"WorkspaceLocationStatusEntriesOrError":["WorkspaceLocationStatusEntries","PythonError"],"GraphOrError":["Graph","GraphNotFoundError","PythonError"],"ResourceDetailsOrError":["ResourceDetails","ResourceNotFoundError","PythonError"],"ResourcesOrError":["ResourceDetailsList","RepositoryNotFoundError","PythonError"],"EnvVarWithConsumersOrError":["EnvVarWithConsumersList","PythonError"],"RunTagKeysOrError":["PythonError","RunTagKeys"],"RunTagsOrError":["PythonError","RunTags"],"RunIdsOrError":["RunIds","InvalidPipelineRunsFilterError","PythonError"],"AssetNodeOrError":["AssetNode","AssetNotFoundError"],"PartitionBackfillOrError":["PartitionBackfill","BackfillNotFoundError","PythonError"],"PartitionBackfillsOrError":["PartitionBackfills","PythonError"],"EventConnectionOrError":["EventConnection","RunNotFoundError","PythonError"],"AutoMaterializeAssetEvaluationRecordsOrError":["AutoMaterializeAssetEvaluationRecords","AutoMaterializeAssetEvaluationNeedsMigrationError"],"PartitionKeysOrError":["PartitionKeys","PartitionSubsetDeserializationError"],"AutoMaterializeRuleEvaluationData":["TextRuleEvaluationData","ParentMaterializedRuleEvaluationData","WaitingOnKeysRuleEvaluationData"],"AssetConditionEvaluationNode":["UnpartitionedAssetConditionEvaluationNode","PartitionedAssetConditionEvaluationNode","SpecificPartitionAssetConditionEvaluationNode"],"AssetConditionEvaluationRecordsOrError":["AssetConditionEvaluationRecords","AutoMaterializeAssetEvaluationNeedsMigrationError"],"SensorDryRunResult":["PythonError","SensorNotFoundError","DryRunInstigationTick"],"ScheduleDryRunResult":["DryRunInstigationTick","PythonError","ScheduleNotFoundError"],"TerminateRunsResultOrError":["TerminateRunsResult","PythonError"],"AssetWipeMutationResult":["AssetNotFoundError","UnauthorizedError","PythonError","AssetWipeSuccess"],"ReportRunlessAssetEventsResult":["UnauthorizedError","PythonError","ReportRunlessAssetEventsSuccess"],"ResumeBackfillResult":["ResumeBackfillSuccess","UnauthorizedError","PythonError"],"CancelBackfillResult":["CancelBackfillSuccess","UnauthorizedError","PythonError"],"LogTelemetryMutationResult":["LogTelemetrySuccess","PythonError"],"AddDynamicPartitionResult":["AddDynamicPartitionSuccess","UnauthorizedError","PythonError","DuplicateDynamicPartitionError"]} \ No newline at end of file