public class AdaptiveBatchSchedulerFactory extends Object implements SchedulerNGFactory
AdaptiveBatchScheduler
.Constructor and Description |
---|
AdaptiveBatchSchedulerFactory() |
public SchedulerNG createInstance(org.slf4j.Logger log, JobGraph jobGraph, Executor ioExecutor, Configuration jobMasterConfiguration, SlotPoolService slotPoolService, ScheduledExecutorService futureExecutor, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, Time rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, Time slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, ComponentMainThreadExecutor mainThreadExecutor, FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations) throws Exception
createInstance
in interface SchedulerNGFactory
Exception
public static InputConsumableDecider.Factory loadInputConsumableDeciderFactory(JobManagerOptions.HybridPartitionDataConsumeConstraint hybridPartitionDataConsumeConstraint)
public static JobManagerOptions.HybridPartitionDataConsumeConstraint getOrDecideHybridPartitionDataConsumeConstraint(Configuration configuration, boolean enableSpeculativeExecution)
public JobManagerOptions.SchedulerType getSchedulerType()
getSchedulerType
in interface SchedulerNGFactory
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.