Class ExecutionOptions


  • @PublicEvolving
    public class ExecutionOptions
    extends Object
    ConfigOptions specific for a single execution of a user program.
    • Field Detail

      • DISABLED_NETWORK_BUFFER_TIMEOUT

        public static final long DISABLED_NETWORK_BUFFER_TIMEOUT
        A special marker value for disabling buffer timeout.
        See Also:
        Constant Field Values
      • FLUSH_AFTER_EVERY_RECORD

        public static final long FLUSH_AFTER_EVERY_RECORD
        A special marker value for flushing network buffers after each record.
        See Also:
        Constant Field Values
      • RUNTIME_MODE

        public static final ConfigOption<org.apache.flink.api.common.RuntimeExecutionMode> RUNTIME_MODE
      • SNAPSHOT_COMPRESSION

        public static final ConfigOption<Boolean> SNAPSHOT_COMPRESSION
        Should be moved to CheckpointingOptions along with ExecutionConfig#useSnapshotCompression, which should be put into CheckpointConfig.
      • SORT_PARTITION_MEMORY

        public static final ConfigOption<org.apache.flink.configuration.MemorySize> SORT_PARTITION_MEMORY
      • SORT_KEYED_PARTITION_MEMORY

        public static final ConfigOption<org.apache.flink.configuration.MemorySize> SORT_KEYED_PARTITION_MEMORY
      • SORTED_INPUTS_MEMORY

        public static final ConfigOption<org.apache.flink.configuration.MemorySize> SORTED_INPUTS_MEMORY
      • ASYNC_STATE_TOTAL_BUFFER_SIZE

        @Experimental
        public static final ConfigOption<Integer> ASYNC_STATE_TOTAL_BUFFER_SIZE
        The max limit of in-flight records number in async state execution, 'in-flight' refers to the records that have entered the operator but have not yet been processed and emitted to the downstream. If the in-flight records number exceeds the limit, the newly records entering will be blocked until the in-flight records number drops below the limit.
      • ASYNC_STATE_ACTIVE_BUFFER_SIZE

        @Experimental
        public static final ConfigOption<Integer> ASYNC_STATE_ACTIVE_BUFFER_SIZE
        The size of buffer under async state execution. Async state execution provides a buffer mechanism to reduce state access. When the number of state requests in the buffer exceeds the batch size, a batched state execution would be triggered. Larger batch sizes will bring higher end-to-end latency, this option works with ASYNC_STATE_ACTIVE_BUFFER_TIMEOUT to control the frequency of triggering.
      • ASYNC_STATE_ACTIVE_BUFFER_TIMEOUT

        @Experimental
        public static final ConfigOption<Long> ASYNC_STATE_ACTIVE_BUFFER_TIMEOUT
        The timeout of buffer triggering in milliseconds. If the buffer has not reached the ASYNC_STATE_ACTIVE_BUFFER_SIZE within 'buffer-timeout' milliseconds, a trigger will perform actively.
    • Constructor Detail

      • ExecutionOptions

        public ExecutionOptions()