Package org.apache.flink.configuration
Class ExecutionOptions
- java.lang.Object
-
- org.apache.flink.configuration.ExecutionOptions
-
@PublicEvolving public class ExecutionOptions extends Object
ConfigOptions specific for a single execution of a user program.
-
-
Field Summary
Fields Modifier and Type Field Description static ConfigOption<Integer>ASYNC_INFLIGHT_RECORDS_LIMITThe 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.static ConfigOption<Integer>ASYNC_STATE_BUFFER_SIZEThe size of buffer under async state execution.static ConfigOption<Long>ASYNC_STATE_BUFFER_TIMEOUTThe timeout of buffer triggering in milliseconds.static ConfigOption<BatchShuffleMode>BATCH_SHUFFLE_MODEstatic ConfigOption<Duration>BUFFER_TIMEOUTstatic ConfigOption<Boolean>BUFFER_TIMEOUT_ENABLEDstatic longDISABLED_NETWORK_BUFFER_TIMEOUTA special marker value for disabling buffer timeout.static longFLUSH_AFTER_EVERY_RECORDA special marker value for flushing network buffers after each record.static ConfigOption<org.apache.flink.api.common.RuntimeExecutionMode>RUNTIME_MODEstatic ConfigOption<Boolean>SNAPSHOT_COMPRESSIONShould be moved toCheckpointingOptionsalong withExecutionConfig#useSnapshotCompression, which should be put intoCheckpointConfig.static ConfigOption<Boolean>SORT_INPUTSstatic ConfigOption<org.apache.flink.configuration.MemorySize>SORT_KEYED_PARTITION_MEMORYstatic ConfigOption<org.apache.flink.configuration.MemorySize>SORT_PARTITION_MEMORYstatic ConfigOption<org.apache.flink.configuration.MemorySize>SORTED_INPUTS_MEMORYstatic ConfigOption<Boolean>USE_BATCH_STATE_BACKEND
-
Constructor Summary
Constructors Constructor Description ExecutionOptions()
-
-
-
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
-
BATCH_SHUFFLE_MODE
public static final ConfigOption<BatchShuffleMode> BATCH_SHUFFLE_MODE
-
SNAPSHOT_COMPRESSION
public static final ConfigOption<Boolean> SNAPSHOT_COMPRESSION
Should be moved toCheckpointingOptionsalong withExecutionConfig#useSnapshotCompression, which should be put intoCheckpointConfig.
-
BUFFER_TIMEOUT_ENABLED
public static final ConfigOption<Boolean> BUFFER_TIMEOUT_ENABLED
-
BUFFER_TIMEOUT
public static final ConfigOption<Duration> BUFFER_TIMEOUT
-
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
-
SORT_INPUTS
public static final ConfigOption<Boolean> SORT_INPUTS
-
SORTED_INPUTS_MEMORY
public static final ConfigOption<org.apache.flink.configuration.MemorySize> SORTED_INPUTS_MEMORY
-
USE_BATCH_STATE_BACKEND
public static final ConfigOption<Boolean> USE_BATCH_STATE_BACKEND
-
ASYNC_INFLIGHT_RECORDS_LIMIT
@Experimental public static final ConfigOption<Integer> ASYNC_INFLIGHT_RECORDS_LIMIT
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_BUFFER_SIZE
@Experimental public static final ConfigOption<Integer> ASYNC_STATE_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 withASYNC_STATE_BUFFER_TIMEOUTto control the frequency of triggering.
-
ASYNC_STATE_BUFFER_TIMEOUT
@Experimental public static final ConfigOption<Long> ASYNC_STATE_BUFFER_TIMEOUT
The timeout of buffer triggering in milliseconds. If the buffer has not reached theASYNC_STATE_BUFFER_SIZEwithin 'buffer-timeout' milliseconds, a trigger will perform actively.
-
-