Interface SlotPoolServiceSchedulerFactory

    • Method Detail

      • createSlotPoolService

        SlotPoolService createSlotPoolService​(org.apache.flink.api.common.JobID jid,
                                              DeclarativeSlotPoolFactory declarativeSlotPoolFactory,
                                              @Nonnull
                                              org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor componentMainThreadExecutor)
        Creates a SlotPoolService.
        Parameters:
        jid - jid is the JobID to pass to the service
        declarativeSlotPoolFactory - the declarative slot pool factory
        componentMainThreadExecutor - component main thread executor.
        Returns:
        created SlotPoolService
      • getSchedulerType

        org.apache.flink.configuration.JobManagerOptions.SchedulerType getSchedulerType()
        Returns the scheduler type this factory is creating.
        Returns:
        the scheduler type this factory is creating.