Class JobManagerOptions


  • @PublicEvolving
    public class JobManagerOptions
    extends Object
    Configuration options for the JobManager.
    • Field Detail

      • MIN_JVM_HEAP_SIZE

        public static final MemorySize MIN_JVM_HEAP_SIZE
      • ADDRESS

        public static final ConfigOption<String> ADDRESS
        The config parameter defining the network address to connect to for communication with the job manager.

        This value is only interpreted in setups where a single JobManager with static name or address exists (simple standalone setups, or container setups with dynamic service name resolution). It is not used in many high-availability setups, when a leader-election service (like ZooKeeper) is used to elect and discover the JobManager leader from potentially multiple standby JobManagers.

      • BIND_HOST

        public static final ConfigOption<String> BIND_HOST
        The local address of the network interface that the job manager binds to.
      • PORT

        public static final ConfigOption<Integer> PORT
        The config parameter defining the network port to connect to for communication with the job manager.

        Like ADDRESS, this value is only interpreted in setups where a single JobManager with static name/address and port exists (simple standalone setups, or container setups with dynamic service name resolution). This config option is not used in many high-availability setups, when a leader-election service (like ZooKeeper) is used to elect and discover the JobManager leader from potentially multiple standby JobManagers.

      • RPC_BIND_PORT

        public static final ConfigOption<Integer> RPC_BIND_PORT
        The local port that the job manager binds to.
      • TOTAL_PROCESS_MEMORY

        public static final ConfigOption<MemorySize> TOTAL_PROCESS_MEMORY
        Total Process Memory size for the JobManager.
      • TOTAL_FLINK_MEMORY

        public static final ConfigOption<MemorySize> TOTAL_FLINK_MEMORY
        Total Flink Memory size for the JobManager.
      • JVM_HEAP_MEMORY

        public static final ConfigOption<MemorySize> JVM_HEAP_MEMORY
        JVM Heap Memory size for the JobManager.
      • OFF_HEAP_MEMORY

        public static final ConfigOption<MemorySize> OFF_HEAP_MEMORY
        Off-heap Memory size for the JobManager.
      • JVM_DIRECT_MEMORY_LIMIT_ENABLED

        public static final ConfigOption<Boolean> JVM_DIRECT_MEMORY_LIMIT_ENABLED
        Off-heap Memory size for the JobManager.
      • JVM_METASPACE

        public static final ConfigOption<MemorySize> JVM_METASPACE
        JVM Metaspace Size for the JobManager.
      • JVM_OVERHEAD_MIN

        public static final ConfigOption<MemorySize> JVM_OVERHEAD_MIN
        Min JVM Overhead size for the JobManager.
      • JVM_OVERHEAD_MAX

        public static final ConfigOption<MemorySize> JVM_OVERHEAD_MAX
        Max JVM Overhead size for the TaskExecutors.
      • JVM_OVERHEAD_FRACTION

        public static final ConfigOption<Float> JVM_OVERHEAD_FRACTION
        Fraction of Total Process Memory to be reserved for JVM Overhead.
      • MAX_ATTEMPTS_HISTORY_SIZE

        public static final ConfigOption<Integer> MAX_ATTEMPTS_HISTORY_SIZE
        The maximum number of historical execution attempts kept in history.
      • FAILURE_ENRICHERS_LIST

        public static final ConfigOption<String> FAILURE_ENRICHERS_LIST
        Flag indicating whether JobManager should load available Failure Enricher plugins at startup. An optional list of Failure Enricher names. If empty, NO enrichers will be started. If configured, only enrichers whose name (as returned by class.getName()) matches any of the names in the list will be started.

        Example:

        
         jobmanager.failure-enrichers = org.apache.flink.test.plugin.jar.failure.TypeFailureEnricher, org.apache.flink.runtime.failure.FailureEnricherUtilsTest$TestEnricher
        
         
      • EXECUTION_FAILOVER_STRATEGY

        public static final ConfigOption<String> EXECUTION_FAILOVER_STRATEGY
        This option specifies the failover strategy, i.e. how the job computation recovers from task failures.
      • ARCHIVE_DIR

        public static final ConfigOption<String> ARCHIVE_DIR
        The location where the JobManager stores the archives of completed jobs.
      • JOB_STORE_CACHE_SIZE

        public static final ConfigOption<Long> JOB_STORE_CACHE_SIZE
        The job store cache size in bytes which is used to keep completed jobs in memory.
      • JOB_STORE_EXPIRATION_TIME

        public static final ConfigOption<Long> JOB_STORE_EXPIRATION_TIME
        The time in seconds after which a completed job expires and is purged from the job store.
      • JOB_STORE_MAX_CAPACITY

        public static final ConfigOption<Integer> JOB_STORE_MAX_CAPACITY
        The max number of completed jobs that can be kept in the job store.
      • RETRIEVE_TASK_MANAGER_HOSTNAME

        public static final ConfigOption<Boolean> RETRIEVE_TASK_MANAGER_HOSTNAME
        Flag indicating whether JobManager would retrieve canonical host name of TaskManager during registration.
      • JOB_MANAGER_FUTURE_POOL_SIZE

        public static final ConfigOption<Integer> JOB_MANAGER_FUTURE_POOL_SIZE
      • SLOT_REQUEST_TIMEOUT

        public static final ConfigOption<Duration> SLOT_REQUEST_TIMEOUT
        The timeout in milliseconds for requesting a slot from Slot Pool.
      • SLOT_IDLE_TIMEOUT

        public static final ConfigOption<Duration> SLOT_IDLE_TIMEOUT
        The timeout in milliseconds for a idle slot in Slot Pool.
      • SCHEDULER_EXECUTING_COOLDOWN_AFTER_RESCALING

        public static final ConfigOption<Duration> SCHEDULER_EXECUTING_COOLDOWN_AFTER_RESCALING
      • SCHEDULER_EXECUTING_RESOURCE_STABILIZATION_TIMEOUT

        public static final ConfigOption<Duration> SCHEDULER_EXECUTING_RESOURCE_STABILIZATION_TIMEOUT
      • SCHEDULER_SUBMISSION_RESOURCE_WAIT_TIMEOUT

        public static final ConfigOption<Duration> SCHEDULER_SUBMISSION_RESOURCE_WAIT_TIMEOUT
      • SCHEDULER_RESCALE_TRIGGER_MAX_CHECKPOINT_FAILURES

        public static final ConfigOption<Integer> SCHEDULER_RESCALE_TRIGGER_MAX_CHECKPOINT_FAILURES
      • SCHEDULER_RESCALE_TRIGGER_MAX_DELAY

        public static final ConfigOption<Duration> SCHEDULER_RESCALE_TRIGGER_MAX_DELAY
      • SCHEDULER_SUBMISSION_RESOURCE_STABILIZATION_TIMEOUT

        public static final ConfigOption<Duration> SCHEDULER_SUBMISSION_RESOURCE_STABILIZATION_TIMEOUT
      • PARTITION_RELEASE_DURING_JOB_EXECUTION

        public static final ConfigOption<Boolean> PARTITION_RELEASE_DURING_JOB_EXECUTION
        Config parameter controlling whether partitions should already be released during the job execution.
      • JOB_MANAGER_RESOURCE_ID

        public static final ConfigOption<String> JOB_MANAGER_RESOURCE_ID
        The JobManager's ResourceID. If not configured, the ResourceID will be generated randomly.