public interface SlotPoolServiceSchedulerFactory
SlotPoolService
and SchedulerNG
.Modifier and Type | Method and Description |
---|---|
SchedulerNG |
createScheduler(org.slf4j.Logger log,
JobGraph jobGraph,
ScheduledExecutorService scheduledExecutorService,
org.apache.flink.configuration.Configuration configuration,
SlotPoolService slotPoolService,
ScheduledExecutorService executorService,
ClassLoader userCodeLoader,
CheckpointRecoveryFactory checkpointRecoveryFactory,
org.apache.flink.api.common.time.Time rpcTimeout,
BlobWriter blobWriter,
JobManagerJobMetricGroup jobManagerJobMetricGroup,
org.apache.flink.api.common.time.Time slotRequestTimeout,
ShuffleMaster<?> shuffleMaster,
JobMasterPartitionTracker partitionTracker,
ExecutionDeploymentTracker executionDeploymentTracker,
long initializationTimestamp,
ComponentMainThreadExecutor mainThreadExecutor,
FatalErrorHandler fatalErrorHandler,
JobStatusListener jobStatusListener)
Creates a
SchedulerNG . |
SlotPoolService |
createSlotPoolService(org.apache.flink.api.common.JobID jid)
Creates a
SlotPoolService . |
org.apache.flink.configuration.JobManagerOptions.SchedulerType |
getSchedulerType()
Returns the scheduler type this factory is creating.
|
SlotPoolService createSlotPoolService(org.apache.flink.api.common.JobID jid)
SlotPoolService
.jid
- jid is the JobID to pass to the serviceorg.apache.flink.configuration.JobManagerOptions.SchedulerType getSchedulerType()
SchedulerNG createScheduler(org.slf4j.Logger log, JobGraph jobGraph, ScheduledExecutorService scheduledExecutorService, org.apache.flink.configuration.Configuration configuration, SlotPoolService slotPoolService, ScheduledExecutorService executorService, ClassLoader userCodeLoader, CheckpointRecoveryFactory checkpointRecoveryFactory, org.apache.flink.api.common.time.Time rpcTimeout, BlobWriter blobWriter, JobManagerJobMetricGroup jobManagerJobMetricGroup, org.apache.flink.api.common.time.Time slotRequestTimeout, ShuffleMaster<?> shuffleMaster, JobMasterPartitionTracker partitionTracker, ExecutionDeploymentTracker executionDeploymentTracker, long initializationTimestamp, ComponentMainThreadExecutor mainThreadExecutor, FatalErrorHandler fatalErrorHandler, JobStatusListener jobStatusListener) throws Exception
SchedulerNG
.Exception
- if the scheduler creation failsCopyright © 2014–2021 The Apache Software Foundation. All rights reserved.