public class LegacyScheduler extends SchedulerBase
ExecutionGraph
.executionVertexVersioner
构造器和说明 |
---|
LegacyScheduler(org.slf4j.Logger log,
JobGraph jobGraph,
BackPressureStatsTracker backPressureStatsTracker,
Executor ioExecutor,
org.apache.flink.configuration.Configuration jobMasterConfiguration,
SlotProvider slotProvider,
ScheduledExecutorService futureExecutor,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
org.apache.flink.api.common.time.Time rpcTimeout,
RestartStrategyFactory restartStrategyFactory,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
org.apache.flink.api.common.time.Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker) |
限定符和类型 | 方法和说明 |
---|---|
protected long |
getNumberOfRestarts() |
void |
handleGlobalFailure(Throwable cause) |
protected void |
startSchedulingInternal() |
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, scheduleOrUpdateConsumersInternal, setGlobalFailureCause, setMainThreadExecutor, startScheduling, stopWithSavepoint, suspend, transitionExecutionGraphState, transitionToScheduled, triggerSavepoint, updateAccumulators, updateTaskExecutionState, updateTaskExecutionStateInternal
public LegacyScheduler(org.slf4j.Logger log, JobGraph jobGraph, BackPressureStatsTracker backPressureStatsTracker, Executor ioExecutor, org.apache.flink.configuration.Configuration jobMasterConfiguration, SlotProvider slotProvider, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, org.apache.flink.api.common.time.Time rpcTimeout, RestartStrategyFactory restartStrategyFactory, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, org.apache.flink.api.common.time.Time slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker) throws Exception
Exception
protected long getNumberOfRestarts()
getNumberOfRestarts
在类中 SchedulerBase
protected void startSchedulingInternal()
startSchedulingInternal
在类中 SchedulerBase
public void handleGlobalFailure(Throwable cause)
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.