Class DefaultSlotPoolServiceSchedulerFactory
- java.lang.Object
-
- org.apache.flink.runtime.jobmaster.DefaultSlotPoolServiceSchedulerFactory
-
- All Implemented Interfaces:
SlotPoolServiceSchedulerFactory
public final class DefaultSlotPoolServiceSchedulerFactory extends Object implements SlotPoolServiceSchedulerFactory
DefaultSlotPoolServiceSchedulerFactoryimplementation.
-
-
Method Summary
All Methods Static Methods Instance Methods Concrete Methods Modifier and Type Method Description static DefaultSlotPoolServiceSchedulerFactorycreate(SlotPoolServiceFactory slotPoolServiceFactory, SchedulerNGFactory schedulerNGFactory)SchedulerNGcreateScheduler(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, org.apache.flink.configuration.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, 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)Creates aSchedulerNG.SlotPoolServicecreateSlotPoolService(org.apache.flink.api.common.JobID jid, DeclarativeSlotPoolFactory declarativeSlotPoolFactory, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor componentMainThreadExecutor)Creates aSlotPoolService.static DefaultSlotPoolServiceSchedulerFactoryfromConfiguration(org.apache.flink.configuration.Configuration configuration, JobType jobType, boolean isDynamicGraph)org.apache.flink.configuration.JobManagerOptions.SchedulerTypegetSchedulerType()Returns the scheduler type this factory is creating.
-
-
-
Method Detail
-
createSlotPoolService
public SlotPoolService createSlotPoolService(org.apache.flink.api.common.JobID jid, DeclarativeSlotPoolFactory declarativeSlotPoolFactory, @Nonnull org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor componentMainThreadExecutor)
Description copied from interface:SlotPoolServiceSchedulerFactoryCreates aSlotPoolService.- Specified by:
createSlotPoolServicein interfaceSlotPoolServiceSchedulerFactory- Parameters:
jid- jid is the JobID to pass to the servicedeclarativeSlotPoolFactory- the declarative slot pool factorycomponentMainThreadExecutor- component main thread executor.- Returns:
- created SlotPoolService
-
getSchedulerType
public org.apache.flink.configuration.JobManagerOptions.SchedulerType getSchedulerType()
Description copied from interface:SlotPoolServiceSchedulerFactoryReturns the scheduler type this factory is creating.- Specified by:
getSchedulerTypein interfaceSlotPoolServiceSchedulerFactory- Returns:
- the scheduler type this factory is creating.
-
createScheduler
public SchedulerNG createScheduler(org.slf4j.Logger log, ExecutionPlan executionPlan, Executor ioExecutor, org.apache.flink.configuration.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, 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
Description copied from interface:SlotPoolServiceSchedulerFactoryCreates aSchedulerNG.- Specified by:
createSchedulerin interfaceSlotPoolServiceSchedulerFactory- Returns:
- created SchedulerNG
- Throws:
Exception- if the scheduler creation fails
-
create
public static DefaultSlotPoolServiceSchedulerFactory create(SlotPoolServiceFactory slotPoolServiceFactory, SchedulerNGFactory schedulerNGFactory)
-
fromConfiguration
public static DefaultSlotPoolServiceSchedulerFactory fromConfiguration(org.apache.flink.configuration.Configuration configuration, JobType jobType, boolean isDynamicGraph)
-
-