Interface SchedulerNGFactory
-
- All Known Implementing Classes:
AdaptiveBatchSchedulerFactory
,AdaptiveSchedulerFactory
,DefaultSchedulerFactory
public interface SchedulerNGFactory
Factory forSchedulerNG
.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description 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)
org.apache.flink.configuration.JobManagerOptions.SchedulerType
getSchedulerType()
-
-
-
Method Detail
-
createInstance
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
- Throws:
Exception
-
getSchedulerType
org.apache.flink.configuration.JobManagerOptions.SchedulerType getSchedulerType()
-
-