public class DefaultScheduler extends SchedulerBase implements SchedulerOperations
Modifier and Type | Field and Description |
---|---|
protected ExecutionDeployer |
executionDeployer |
protected ExecutionSlotAllocator |
executionSlotAllocator |
protected org.slf4j.Logger |
log |
executionVertexVersioner, inputsLocationsRetriever, jobManagerJobMetricGroup, operatorCoordinatorHandler, stateLocationRetriever
Modifier | Constructor and Description |
---|---|
protected |
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,
ExecutionOperations executionOperations,
ExecutionVertexVersioner executionVertexVersioner,
ExecutionSlotAllocatorFactory executionSlotAllocatorFactory,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
JobStatusListener jobStatusListener,
ExecutionGraphFactory executionGraphFactory,
ShuffleMaster<?> shuffleMaster,
Time rpcTimeout,
VertexParallelismStore vertexParallelismStore,
ExecutionDeployer.Factory executionDeployerFactory) |
Modifier and Type | Method and Description |
---|---|
void |
allocateSlotsAndDeploy(List<ExecutionVertexID> verticesToDeploy)
Allocate slots and deploy the vertex when slots are returned.
|
protected void |
cancelAllPendingSlotRequestsForVertex(ExecutionVertexID executionVertexId) |
protected void |
cancelAllPendingSlotRequestsInternal() |
protected CompletableFuture<?> |
cancelExecution(Execution execution) |
protected FailureHandlingResultSnapshot |
createFailureHandlingResultSnapshot(FailureHandlingResult failureHandlingResult) |
protected long |
getNumberOfRestarts() |
void |
handleGlobalFailure(Throwable error)
Handles a global failure.
|
protected void |
handleTaskFailure(Execution failedExecution,
Throwable error) |
protected void |
onTaskFailed(Execution execution) |
protected void |
onTaskFinished(Execution execution,
IOMetrics ioMetrics) |
protected FailureHandlingResult |
recordTaskFailure(Execution failedExecution,
Throwable error) |
protected void |
startSchedulingInternal() |
acknowledgeCheckpoint, archiveFromFailureHandlingResult, archiveGlobalFailure, cancel, closeAsync, computeVertexParallelismStore, computeVertexParallelismStore, computeVertexParallelismStore, computeVertexParallelismStore, declineCheckpoint, deliverCoordinationRequestToCoordinator, deliverOperatorEventToCoordinator, failJob, getDefaultMaxParallelism, getExceptionHistory, getExecutionGraph, getExecutionJobVertex, getExecutionVertex, getJobGraph, getJobTerminationFuture, getMainThreadExecutor, getMarkPartitionFinishedStrategy, getResultPartitionAvailabilityChecker, getSchedulingTopology, notifyKvStateRegistered, notifyKvStateUnregistered, registerJobMetrics, reportCheckpointMetrics, requestJob, requestJobDetails, requestJobStatus, requestKvStateLocation, requestNextInputSplit, requestPartitionState, resetForNewExecution, resetForNewExecutions, restoreState, setGlobalFailureCause, startCheckpointScheduler, startScheduling, stopCheckpointScheduler, stopWithSavepoint, transitionExecutionGraphState, transitionToRunning, transitionToScheduled, triggerCheckpoint, triggerSavepoint, updateAccumulators, updateTaskExecutionState
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
updateTaskExecutionState
close
protected final org.slf4j.Logger log
protected final ExecutionSlotAllocator executionSlotAllocator
protected final ExecutionDeployer executionDeployer
protected 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, ExecutionOperations executionOperations, ExecutionVertexVersioner executionVertexVersioner, ExecutionSlotAllocatorFactory executionSlotAllocatorFactory, long initializationTimestamp, ComponentMainThreadExecutor mainThreadExecutor, JobStatusListener jobStatusListener, ExecutionGraphFactory executionGraphFactory, ShuffleMaster<?> shuffleMaster, Time rpcTimeout, VertexParallelismStore vertexParallelismStore, ExecutionDeployer.Factory executionDeployerFactory) throws Exception
Exception
protected long getNumberOfRestarts()
getNumberOfRestarts
in class SchedulerBase
protected void cancelAllPendingSlotRequestsInternal()
cancelAllPendingSlotRequestsInternal
in class SchedulerBase
protected void startSchedulingInternal()
startSchedulingInternal
in class SchedulerBase
protected void onTaskFinished(Execution execution, IOMetrics ioMetrics)
onTaskFinished
in class SchedulerBase
protected void onTaskFailed(Execution execution)
onTaskFailed
in class SchedulerBase
protected void handleTaskFailure(Execution failedExecution, @Nullable Throwable error)
protected FailureHandlingResult recordTaskFailure(Execution failedExecution, @Nullable Throwable error)
public void handleGlobalFailure(Throwable error)
GlobalFailureHandler
handleGlobalFailure
in interface GlobalFailureHandler
error
- A cause that describes the global failure.protected FailureHandlingResultSnapshot createFailureHandlingResultSnapshot(FailureHandlingResult failureHandlingResult)
protected CompletableFuture<?> cancelExecution(Execution execution)
protected void cancelAllPendingSlotRequestsForVertex(ExecutionVertexID executionVertexId)
public void allocateSlotsAndDeploy(List<ExecutionVertexID> verticesToDeploy)
SchedulerOperations
allocateSlotsAndDeploy
in interface SchedulerOperations
verticesToDeploy
- The execution vertices to deployCopyright © 2014–2024 The Apache Software Foundation. All rights reserved.