Class AdaptiveSchedulerFactory
- java.lang.Object
-
- org.apache.flink.runtime.scheduler.adaptive.AdaptiveSchedulerFactory
-
- All Implemented Interfaces:
SchedulerNGFactory
public class AdaptiveSchedulerFactory extends Object implements SchedulerNGFactory
Factory for the adaptive scheduler.
-
-
Constructor Summary
Constructors Constructor Description AdaptiveSchedulerFactory()
-
Method Summary
All Methods Static Methods Instance Methods Concrete Methods Modifier and Type Method Description SchedulerNGcreateInstance(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, org.apache.flink.configuration.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, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations)static SlotSharingSlotAllocatorcreateSlotSharingSlotAllocator(DeclarativeSlotPool declarativeSlotPool, boolean localRecoveryEnabled, String executionTarget, boolean minimalTaskManagerPreferred)org.apache.flink.configuration.JobManagerOptions.SchedulerTypegetSchedulerType()
-
-
-
Method Detail
-
createInstance
public SchedulerNG createInstance(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, org.apache.flink.configuration.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, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, org.apache.flink.runtime.rpc.FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, BlocklistOperations blocklistOperations) throws Exception
- Specified by:
createInstancein interfaceSchedulerNGFactory- Throws:
Exception
-
getSchedulerType
public org.apache.flink.configuration.JobManagerOptions.SchedulerType getSchedulerType()
- Specified by:
getSchedulerTypein interfaceSchedulerNGFactory
-
createSlotSharingSlotAllocator
public static SlotSharingSlotAllocator createSlotSharingSlotAllocator(DeclarativeSlotPool declarativeSlotPool, boolean localRecoveryEnabled, @Nullable String executionTarget, boolean minimalTaskManagerPreferred)
-
-