Interface SlotPoolServiceSchedulerFactory
-
- All Known Implementing Classes:
DefaultSlotPoolServiceSchedulerFactory
public interface SlotPoolServiceSchedulerFactory
Factory forSlotPoolService
andSchedulerNG
.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description SchedulerNG
createScheduler(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, Configuration configuration, 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)
Creates aSchedulerNG
.SlotPoolService
createSlotPoolService(JobID jid, DeclarativeSlotPoolFactory declarativeSlotPoolFactory, ComponentMainThreadExecutor componentMainThreadExecutor)
Creates aSlotPoolService
.JobManagerOptions.SchedulerType
getSchedulerType()
Returns the scheduler type this factory is creating.
-
-
-
Method Detail
-
createSlotPoolService
SlotPoolService createSlotPoolService(JobID jid, DeclarativeSlotPoolFactory declarativeSlotPoolFactory, @Nonnull ComponentMainThreadExecutor componentMainThreadExecutor)
Creates aSlotPoolService
.- Parameters:
jid
- jid is the JobID to pass to the servicedeclarativeSlotPoolFactory
- the declarative slot pool factorycomponentMainThreadExecutor
- component main thread executor.- Returns:
- created SlotPoolService
-
getSchedulerType
JobManagerOptions.SchedulerType getSchedulerType()
Returns the scheduler type this factory is creating.- Returns:
- the scheduler type this factory is creating.
-
createScheduler
SchedulerNG createScheduler(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, Configuration configuration, 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
Creates aSchedulerNG
.- Returns:
- created SchedulerNG
- Throws:
Exception
- if the scheduler creation fails
-
-