public class SpeculativeScheduler extends AdaptiveBatchScheduler implements SlowTaskDetectorListener
executionDeployer, executionSlotAllocator, log
executionVertexVersioner, inputsLocationsRetriever, jobInfo, jobManagerJobMetricGroup, operatorCoordinatorHandler, stateLocationRetriever
Constructor and Description |
---|
SpeculativeScheduler(org.slf4j.Logger log,
JobGraph jobGraph,
Executor ioExecutor,
Configuration jobMasterConfiguration,
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,
Collection<FailureEnricher> failureEnrichers,
ExecutionGraphFactory executionGraphFactory,
ShuffleMaster<?> shuffleMaster,
Time rpcTimeout,
VertexParallelismAndInputInfosDecider vertexParallelismAndInputInfosDecider,
int defaultMaxParallelism,
BlocklistOperations blocklistOperations,
JobManagerOptions.HybridPartitionDataConsumeConstraint hybridPartitionDataConsumeConstraint,
Map<JobVertexID,ForwardGroup> forwardGroupsByJobVertexId) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Void> |
closeAsync()
Trigger the closing of the resource and return the corresponding close future.
|
SpeculativeExecutionVertex |
getExecutionVertex(ExecutionVertexID executionVertexId) |
protected void |
handleTaskFailure(Execution failedExecution,
Throwable error) |
void |
notifySlowTasks(Map<ExecutionVertexID,Collection<ExecutionAttemptID>> slowTasks)
Notify detected slow tasks.
|
protected void |
onTaskFailed(Execution execution) |
protected void |
onTaskFinished(Execution execution,
IOMetrics ioMetrics) |
protected void |
resetForNewExecution(ExecutionVertexID executionVertexId) |
protected void |
startSchedulingInternal() |
allocateSlotsAndDeploy, computeDynamicSourceParallelism, computeVertexParallelismStoreForDynamicGraph, getMarkPartitionFinishedStrategy, initializeVerticesIfPossible
cancelAllPendingSlotRequestsForVertex, cancelAllPendingSlotRequestsInternal, cancelExecution, createFailureHandlingResultSnapshot, getNumberOfRestarts, handleGlobalFailure, recordTaskFailure
acknowledgeCheckpoint, archiveFromFailureHandlingResult, archiveGlobalFailure, cancel, computeVertexParallelismStore, computeVertexParallelismStore, computeVertexParallelismStore, computeVertexParallelismStore, declineCheckpoint, deliverCoordinationRequestToCoordinator, deliverOperatorEventToCoordinator, failJob, getDefaultMaxParallelism, getExceptionHistory, getExecutionGraph, getExecutionJobVertex, getJobGraph, getJobTerminationFuture, getMainThreadExecutor, getResultPartitionAvailabilityChecker, getSchedulingTopology, notifyEndOfData, notifyKvStateRegistered, notifyKvStateUnregistered, registerJobMetrics, reportCheckpointMetrics, reportInitializationMetrics, requestCheckpointStats, requestJob, requestJobStatus, requestKvStateLocation, requestNextInputSplit, requestPartitionState, 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
requestJobResourceRequirements, updateJobResourceRequirements, updateTaskExecutionState
close
public SpeculativeScheduler(org.slf4j.Logger log, JobGraph jobGraph, Executor ioExecutor, Configuration jobMasterConfiguration, 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, Collection<FailureEnricher> failureEnrichers, ExecutionGraphFactory executionGraphFactory, ShuffleMaster<?> shuffleMaster, Time rpcTimeout, VertexParallelismAndInputInfosDecider vertexParallelismAndInputInfosDecider, int defaultMaxParallelism, BlocklistOperations blocklistOperations, JobManagerOptions.HybridPartitionDataConsumeConstraint hybridPartitionDataConsumeConstraint, Map<JobVertexID,ForwardGroup> forwardGroupsByJobVertexId) throws Exception
Exception
protected void startSchedulingInternal()
startSchedulingInternal
in class AdaptiveBatchScheduler
public CompletableFuture<Void> closeAsync()
AutoCloseableAsync
closeAsync
in interface AutoCloseableAsync
closeAsync
in class SchedulerBase
public SpeculativeExecutionVertex getExecutionVertex(ExecutionVertexID executionVertexId)
getExecutionVertex
in class SchedulerBase
protected void onTaskFinished(Execution execution, IOMetrics ioMetrics)
onTaskFinished
in class AdaptiveBatchScheduler
protected void onTaskFailed(Execution execution)
onTaskFailed
in class DefaultScheduler
protected void handleTaskFailure(Execution failedExecution, @Nullable Throwable error)
handleTaskFailure
in class DefaultScheduler
protected void resetForNewExecution(ExecutionVertexID executionVertexId)
resetForNewExecution
in class AdaptiveBatchScheduler
public void notifySlowTasks(Map<ExecutionVertexID,Collection<ExecutionAttemptID>> slowTasks)
SlowTaskDetectorListener
notifySlowTasks
in interface SlowTaskDetectorListener
slowTasks
- the map of execution vertices and their execution attempts which are
detected as slow.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.