public class DefaultScheduler extends SchedulerBase implements SchedulerOperations
executionVertexVersioner
构造器和说明 |
---|
DefaultScheduler(org.slf4j.Logger log,
JobGraph jobGraph,
BackPressureStatsTracker backPressureStatsTracker,
Executor ioExecutor,
org.apache.flink.configuration.Configuration jobMasterConfiguration,
SlotProvider slotProvider,
ScheduledExecutorService futureExecutor,
ScheduledExecutor delayExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
org.apache.flink.api.common.time.Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
org.apache.flink.api.common.time.Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
SchedulingStrategyFactory schedulingStrategyFactory,
FailoverStrategy.Factory failoverStrategyFactory,
RestartBackoffTimeStrategy restartBackoffTimeStrategy,
org.apache.flink.runtime.scheduler.ExecutionVertexOperations executionVertexOperations,
ExecutionVertexVersioner executionVertexVersioner,
ExecutionSlotAllocatorFactory executionSlotAllocatorFactory) |
限定符和类型 | 方法和说明 |
---|---|
void |
allocateSlotsAndDeploy(List<ExecutionVertexDeploymentOption> executionVertexDeploymentOptions)
Allocate slots and deploy the vertex when slots are returned.
|
protected long |
getNumberOfRestarts() |
void |
handleGlobalFailure(Throwable error) |
protected void |
scheduleOrUpdateConsumersInternal(ExecutionVertexID producerVertexId,
ResultPartitionID partitionId) |
protected void |
startSchedulingInternal() |
protected void |
updateTaskExecutionStateInternal(ExecutionVertexID executionVertexId,
TaskExecutionState taskExecutionState) |
acknowledgeCheckpoint, cancel, declineCheckpoint, failJob, getExecutionGraph, getExecutionVertex, getExecutionVertexId, getExecutionVertexIdOrThrow, getFailoverTopology, getInputsLocationsRetriever, getJobGraph, getMainThreadExecutor, getResultPartitionAvailabilityChecker, getSchedulingTopology, getTerminationFuture, notifyKvStateRegistered, notifyKvStateUnregistered, prepareExecutionGraphForNgScheduling, registerJobStatusListener, requestJob, requestJobDetails, requestJobStatus, requestKvStateLocation, requestNextInputSplit, requestOperatorBackPressureStats, requestPartitionState, resetForNewExecutions, restoreState, scheduleOrUpdateConsumers, setGlobalFailureCause, setMainThreadExecutor, startScheduling, stopWithSavepoint, suspend, transitionExecutionGraphState, transitionToScheduled, triggerSavepoint, updateAccumulators, updateTaskExecutionState
public DefaultScheduler(org.slf4j.Logger log, JobGraph jobGraph, BackPressureStatsTracker backPressureStatsTracker, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, SlotProvider slotProvider, ScheduledExecutorService futureExecutor, ScheduledExecutor delayExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, org.apache.flink.api.common.time.Time rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, org.apache.flink.api.common.time.Time slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, SchedulingStrategyFactory schedulingStrategyFactory, FailoverStrategy.Factory failoverStrategyFactory, RestartBackoffTimeStrategy restartBackoffTimeStrategy, org.apache.flink.runtime.scheduler.ExecutionVertexOperations executionVertexOperations, ExecutionVertexVersioner executionVertexVersioner, ExecutionSlotAllocatorFactory executionSlotAllocatorFactory) throws Exception
Exception
protected long getNumberOfRestarts()
getNumberOfRestarts
在类中 SchedulerBase
protected void startSchedulingInternal()
startSchedulingInternal
在类中 SchedulerBase
protected void updateTaskExecutionStateInternal(ExecutionVertexID executionVertexId, TaskExecutionState taskExecutionState)
public void handleGlobalFailure(Throwable error)
handleGlobalFailure
在接口中 SchedulerNG
protected void scheduleOrUpdateConsumersInternal(ExecutionVertexID producerVertexId, ResultPartitionID partitionId)
public void allocateSlotsAndDeploy(List<ExecutionVertexDeploymentOption> executionVertexDeploymentOptions)
SchedulerOperations
allocateSlotsAndDeploy
在接口中 SchedulerOperations
executionVertexDeploymentOptions
- The deployment options of tasks to be deployedCopyright © 2014–2021 The Apache Software Foundation. All rights reserved.