Modifier and Type | Method and Description |
---|---|
void |
PendingCheckpoint.abort(CheckpointFailureReason reason,
Throwable cause,
CheckpointsCleaner checkpointsCleaner,
Runnable postCleanup,
Executor executor,
CheckpointStatsTracker statsTracker)
Aborts a checkpoint with reason and cause.
|
CompletedCheckpoint |
EmbeddedCompletedCheckpointStore.addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint,
CheckpointsCleaner checkpointsCleaner,
Runnable postCleanup) |
CompletedCheckpoint |
DeactivatedCheckpointCompletedCheckpointStore.addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint,
CheckpointsCleaner checkpointsCleaner,
Runnable postCleanup) |
CompletedCheckpoint |
StandaloneCompletedCheckpointStore.addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint,
CheckpointsCleaner checkpointsCleaner,
Runnable postCleanup) |
CompletedCheckpoint |
DefaultCompletedCheckpointStore.addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint,
CheckpointsCleaner checkpointsCleaner,
Runnable postCleanup)
Synchronously writes the new checkpoints to state handle store and asynchronously removes
older ones.
|
CompletedCheckpoint |
CompletedCheckpointStore.addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint,
CheckpointsCleaner checkpointsCleaner,
Runnable postCleanup)
Adds a
CompletedCheckpoint instance to the list of completed checkpoints. |
CompletedCheckpoint |
PendingCheckpoint.finalizeCheckpoint(CheckpointsCleaner checkpointsCleaner,
Runnable postCleanup,
Executor executor) |
void |
EmbeddedCompletedCheckpointStore.shutdown(JobStatus jobStatus,
CheckpointsCleaner checkpointsCleaner) |
void |
DeactivatedCheckpointCompletedCheckpointStore.shutdown(JobStatus jobStatus,
CheckpointsCleaner checkpointsCleaner) |
void |
StandaloneCompletedCheckpointStore.shutdown(JobStatus jobStatus,
CheckpointsCleaner checkpointsCleaner) |
void |
DefaultCompletedCheckpointStore.shutdown(JobStatus jobStatus,
CheckpointsCleaner checkpointsCleaner) |
void |
AbstractCompleteCheckpointStore.shutdown(JobStatus jobStatus,
CheckpointsCleaner checkpointsCleaner) |
void |
CompletedCheckpointStore.shutdown(JobStatus jobStatus,
CheckpointsCleaner checkpointsCleaner)
Shuts down the store.
|
Modifier and Type | Method and Description |
---|---|
static DefaultExecutionGraph |
DefaultExecutionGraphBuilder.buildGraph(JobGraph jobGraph,
Configuration jobManagerConfig,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
ClassLoader classLoader,
CompletedCheckpointStore completedCheckpointStore,
CheckpointsCleaner checkpointsCleaner,
CheckpointIDCounter checkpointIdCounter,
Time rpcTimeout,
BlobWriter blobWriter,
org.slf4j.Logger log,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint,
ExecutionDeploymentListener executionDeploymentListener,
ExecutionStateUpdateListener executionStateUpdateListener,
long initializationTimestamp,
VertexAttemptNumberStore vertexAttemptNumberStore,
VertexParallelismStore vertexParallelismStore,
java.util.function.Supplier<CheckpointStatsTracker> checkpointStatsTrackerFactory,
boolean isDynamicGraph) |
void |
DefaultExecutionGraph.enableCheckpointing(CheckpointCoordinatorConfiguration chkConfig,
List<MasterTriggerRestoreHook<?>> masterHooks,
CheckpointIDCounter checkpointIDCounter,
CompletedCheckpointStore checkpointStore,
StateBackend checkpointStateBackend,
CheckpointStorage checkpointStorage,
CheckpointStatsTracker statsTracker,
CheckpointsCleaner checkpointsCleaner) |
void |
ExecutionGraph.enableCheckpointing(CheckpointCoordinatorConfiguration chkConfig,
List<MasterTriggerRestoreHook<?>> masterHooks,
CheckpointIDCounter checkpointIDCounter,
CompletedCheckpointStore checkpointStore,
StateBackend checkpointStateBackend,
CheckpointStorage checkpointStorage,
CheckpointStatsTracker statsTracker,
CheckpointsCleaner checkpointsCleaner) |
Modifier and Type | Method and Description |
---|---|
ExecutionGraph |
DefaultExecutionGraphFactory.createAndRestoreExecutionGraph(JobGraph jobGraph,
CompletedCheckpointStore completedCheckpointStore,
CheckpointsCleaner checkpointsCleaner,
CheckpointIDCounter checkpointIdCounter,
TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint,
long initializationTimestamp,
VertexAttemptNumberStore vertexAttemptNumberStore,
VertexParallelismStore vertexParallelismStore,
ExecutionStateUpdateListener executionStateUpdateListener,
org.slf4j.Logger log) |
ExecutionGraph |
ExecutionGraphFactory.createAndRestoreExecutionGraph(JobGraph jobGraph,
CompletedCheckpointStore completedCheckpointStore,
CheckpointsCleaner checkpointsCleaner,
CheckpointIDCounter checkpointIdCounter,
TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionLocationConstraint,
long initializationTimestamp,
VertexAttemptNumberStore vertexAttemptNumberStore,
VertexParallelismStore vertexParallelismStore,
ExecutionStateUpdateListener executionStateUpdateListener,
org.slf4j.Logger log)
Create and restore
ExecutionGraph from the given JobGraph and services. |
Constructor and Description |
---|
DefaultScheduler(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration jobMasterConfiguration,
java.util.function.Consumer<ComponentMainThreadExecutor> startUpAction,
ScheduledExecutor delayExecutor,
ClassLoader userCodeLoader,
CheckpointsCleaner checkpointsCleaner,
CheckpointRecoveryFactory checkpointRecoveryFactory,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
SchedulingStrategyFactory schedulingStrategyFactory,
FailoverStrategy.Factory failoverStrategyFactory,
RestartBackoffTimeStrategy restartBackoffTimeStrategy,
ExecutionVertexOperations executionVertexOperations,
ExecutionVertexVersioner executionVertexVersioner,
ExecutionSlotAllocatorFactory executionSlotAllocatorFactory,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
JobStatusListener jobStatusListener,
ExecutionGraphFactory executionGraphFactory,
ShuffleMaster<?> shuffleMaster,
Time rpcTimeout,
VertexParallelismStore vertexParallelismStore) |
SchedulerBase(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration jobMasterConfiguration,
CheckpointsCleaner checkpointsCleaner,
CheckpointRecoveryFactory checkpointRecoveryFactory,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
ExecutionVertexVersioner executionVertexVersioner,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
JobStatusListener jobStatusListener,
ExecutionGraphFactory executionGraphFactory,
VertexParallelismStore vertexParallelismStore) |
Constructor and Description |
---|
AdaptiveScheduler(JobGraph jobGraph,
Configuration configuration,
DeclarativeSlotPool declarativeSlotPool,
SlotAllocator slotAllocator,
Executor ioExecutor,
ClassLoader userCodeClassLoader,
CheckpointsCleaner checkpointsCleaner,
CheckpointRecoveryFactory checkpointRecoveryFactory,
java.time.Duration initialResourceAllocationTimeout,
java.time.Duration resourceStabilizationTimeout,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
RestartBackoffTimeStrategy restartBackoffTimeStrategy,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
FatalErrorHandler fatalErrorHandler,
JobStatusListener jobStatusListener,
ExecutionGraphFactory executionGraphFactory) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.