Class AdaptiveBatchSchedulerFactory
- java.lang.Object
-
- org.apache.flink.runtime.scheduler.adaptivebatch.AdaptiveBatchSchedulerFactory
-
- All Implemented Interfaces:
SchedulerNGFactory
public class AdaptiveBatchSchedulerFactory extends Object implements SchedulerNGFactory
Factory forAdaptiveBatchScheduler
.
-
-
Constructor Summary
Constructors Constructor Description AdaptiveBatchSchedulerFactory()
-
Method Summary
-
-
-
Method Detail
-
createInstance
public SchedulerNG createInstance(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Duration slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, ComponentMainThreadExecutor mainThreadExecutor, FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations) throws Exception
- Specified by:
createInstance
in interfaceSchedulerNGFactory
- Throws:
Exception
-
createScheduler
@VisibleForTesting public static AdaptiveBatchScheduler createScheduler(org.slf4j.Logger log, JobGraph jobGraph, ExecutionConfig executionConfig, Executor ioExecutor, Configuration jobMasterConfiguration, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Duration rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, ComponentMainThreadExecutor mainThreadExecutor, JobStatusListener jobStatusListener, Collection<FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations, ExecutionOperations executionOperations, ExecutionSlotAllocatorFactory allocatorFactory, RestartBackoffTimeStrategy restartBackoffTimeStrategy, ScheduledExecutor delayExecutor, VertexParallelismAndInputInfosDecider vertexParallelismAndInputInfosDecider, BatchJobRecoveryHandler jobRecoveryHandler) throws Exception
- Throws:
Exception
-
loadInputConsumableDeciderFactory
public static InputConsumableDecider.Factory loadInputConsumableDeciderFactory(JobManagerOptions.HybridPartitionDataConsumeConstraint hybridPartitionDataConsumeConstraint)
-
getOrDecideHybridPartitionDataConsumeConstraint
public static JobManagerOptions.HybridPartitionDataConsumeConstraint getOrDecideHybridPartitionDataConsumeConstraint(Configuration configuration, boolean enableSpeculativeExecution)
-
getSchedulerType
public JobManagerOptions.SchedulerType getSchedulerType()
- Specified by:
getSchedulerType
in interfaceSchedulerNGFactory
-
-