Package | Description |
---|---|
org.apache.flink.configuration | |
org.apache.flink.contrib.streaming.state | |
org.apache.flink.kubernetes.configuration |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
RestOptions.ADDRESS
The address that should be used by clients to connect to the server.
|
static ConfigOption<String> |
JobManagerOptions.ADDRESS
The config parameter defining the network address to connect to for communication with the
job manager.
|
static ConfigOption<String> |
CoreOptions.ALLOWED_FALLBACK_FILESYSTEMS |
static ConfigOption<String> |
CoreOptions.ALWAYS_PARENT_FIRST_LOADER_PATTERNS
The namespace patterns for classes that are loaded with a preference from the parent
classloader, meaning the application class path, rather than any user code jar file.
|
static ConfigOption<String> |
CoreOptions.ALWAYS_PARENT_FIRST_LOADER_PATTERNS_ADDITIONAL |
static ConfigOption<String> |
JobManagerOptions.ARCHIVE_DIR
The location where the JobManager stores the archives of completed jobs.
|
static ConfigOption<Boolean> |
CheckpointingOptions.ASYNC_SNAPSHOTS
Option whether the state backend should use an asynchronous snapshot method where possible
and configurable.
|
static ConfigOption<Long> |
RestOptions.AWAIT_LEADER_TIMEOUT
The time in ms that the client waits for the leader address, e.g., Dispatcher or
WebMonitorEndpoint.
|
static ConfigOption<String> |
RestOptions.BIND_ADDRESS
The address that the server binds itself to.
|
static ConfigOption<String> |
RestOptions.BIND_PORT
The port range that the server could bind itself to.
|
static ConfigOption<Boolean> |
NettyShuffleEnvironmentOptions.BLOCKING_SHUFFLE_COMPRESSION_ENABLED
Boolean flag indicating whether the shuffle data will be compressed for blocking shuffle
mode.
|
static ConfigOption<Boolean> |
CoreOptions.CHECK_LEAKED_CLASSLOADER |
static ConfigOption<String> |
CheckpointingOptions.CHECKPOINTS_DIRECTORY
The default directory used for storing the data files and meta data of checkpoints in a Flink
supported filesystem.
|
static ConfigOption<String> |
CoreOptions.CLASSLOADER_RESOLVE_ORDER
Defines the class resolution strategy when loading classes from user code, meaning whether to
first check the user code jar (
"child-first" ) or the application classpath ("parent-first" ) |
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.CLIENT_CONNECT_TIMEOUT_SECONDS |
static ConfigOption<Integer> |
RestOptions.CLIENT_MAX_CONTENT_LENGTH
The maximum content length that the client will handle.
|
static ConfigOption<Integer> |
ClusterOptions.CLUSTER_IO_EXECUTOR_POOL_SIZE |
static ConfigOption<Long> |
ClusterOptions.CLUSTER_SERVICES_SHUTDOWN_TIMEOUT |
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.CONNECT_BACKLOG |
static ConfigOption<Long> |
RestOptions.CONNECTION_TIMEOUT
The maximum time in ms for the client to establish a TCP connection.
|
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.DATA_PORT
The default network port the task manager expects to receive transfer envelopes on.
|
static ConfigOption<Boolean> |
NettyShuffleEnvironmentOptions.DATA_SSL_ENABLED
Config parameter to override SSL support for taskmanager's data transport.
|
static ConfigOption<Boolean> |
TaskManagerOptions.DEBUG_MEMORY_LOG |
static ConfigOption<Long> |
TaskManagerOptions.DEBUG_MEMORY_USAGE_LOG_INTERVAL_MS |
static ConfigOption<String> |
CoreOptions.DEFAULT_FILESYSTEM_SCHEME
The default filesystem scheme, used for paths that do not declare a scheme explicitly.
|
static ConfigOption<Long> |
ClusterOptions.ERROR_REGISTRATION_DELAY |
static ConfigOption<Boolean> |
ClusterOptions.EVENLY_SPREAD_OUT_SLOTS_STRATEGY |
static ConfigOption<String> |
JobManagerOptions.EXECUTION_FAILOVER_STRATEGY
This option specifies the failover strategy, i.e.
|
static ConfigOption<Boolean> |
CoreOptions.FAIL_ON_USER_CLASS_LOADING_METASPACE_OOM |
static ConfigOption<Boolean> |
CoreOptions.FILESYSTEM_OUTPUT_ALWAYS_CREATE_DIRECTORY
Specifies whether the file systems should always create a directory for the output, even with
a parallelism of one.
|
static ConfigOption<Boolean> |
CoreOptions.FILESYTEM_DEFAULT_OVERRIDE
Specifies whether file output writers should overwrite existing files by default.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.FRAMEWORK_HEAP_MEMORY
Framework Heap Memory size for TaskExecutors.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.FRAMEWORK_OFF_HEAP_MEMORY
Framework Off-Heap Memory size for TaskExecutors.
|
static ConfigOption<MemorySize> |
CheckpointingOptions.FS_SMALL_FILE_THRESHOLD
The minimum size of state data files.
|
static ConfigOption<Integer> |
CheckpointingOptions.FS_WRITE_BUFFER_SIZE
The default size of the write buffer for the checkpoint streams that write to file systems.
|
static ConfigOption<String> |
HighAvailabilityOptions.HA_CLUSTER_ID
The ID of the Flink cluster, used to separate multiple Flink clusters Needs to be set for
standalone clusters, is automatically inferred in YARN and Mesos.
|
static ConfigOption<String> |
HighAvailabilityOptions.HA_JOB_MANAGER_PORT_RANGE
Optional port (range) used by the job manager in high-availability mode.
|
static ConfigOption<String> |
HighAvailabilityOptions.HA_MODE
Defines high-availability mode used for the cluster execution.
|
static ConfigOption<String> |
HighAvailabilityOptions.HA_STORAGE_PATH
File system path (URI) where Flink persists metadata in high-availability setups.
|
static ConfigOption<String> |
HighAvailabilityOptions.HA_ZOOKEEPER_CHECKPOINT_COUNTER_PATH
ZooKeeper root path (ZNode) for checkpoint counters.
|
static ConfigOption<String> |
HighAvailabilityOptions.HA_ZOOKEEPER_CHECKPOINTS_PATH
ZooKeeper root path (ZNode) for completed checkpoints.
|
static ConfigOption<String> |
HighAvailabilityOptions.HA_ZOOKEEPER_JOBGRAPHS_PATH
ZooKeeper root path (ZNode) for job graphs.
|
static ConfigOption<String> |
HighAvailabilityOptions.HA_ZOOKEEPER_LATCH_PATH |
static ConfigOption<String> |
HighAvailabilityOptions.HA_ZOOKEEPER_LEADER_PATH |
static ConfigOption<String> |
HighAvailabilityOptions.HA_ZOOKEEPER_MESOS_WORKERS_PATH
ZooKeeper root path (ZNode) for Mesos workers.
|
static ConfigOption<String> |
HighAvailabilityOptions.HA_ZOOKEEPER_QUORUM
The ZooKeeper quorum to use, when running Flink in a high-availability mode with ZooKeeper.
|
static ConfigOption<String> |
HighAvailabilityOptions.HA_ZOOKEEPER_ROOT
The root path under which Flink stores its entries in ZooKeeper.
|
static ConfigOption<Boolean> |
ClusterOptions.HALT_ON_FATAL_ERROR |
static ConfigOption<Long> |
HeartbeatManagerOptions.HEARTBEAT_INTERVAL
Time interval for requesting heartbeat from sender side.
|
static ConfigOption<Long> |
HeartbeatManagerOptions.HEARTBEAT_TIMEOUT
Timeout for requesting and receiving heartbeat for both sender and receiver sides.
|
static ConfigOption<String> |
TaskManagerOptions.HOST
The external address of the network interface where the TaskManager is exposed.
|
static ConfigOption<String> |
TaskManagerOptions.HOST_BIND_POLICY
The config parameter for automatically defining the TaskManager's binding address, if
TaskManagerOptions.HOST configuration option is not set. |
static ConfigOption<Long> |
RestOptions.IDLENESS_TIMEOUT
The maximum time in ms for a connection to stay idle before failing.
|
static ConfigOption<Boolean> |
CheckpointingOptions.INCREMENTAL_CHECKPOINTS
Option whether the state backend should create incremental checkpoints, if possible.
|
static ConfigOption<Long> |
ClusterOptions.INITIAL_REGISTRATION_TIMEOUT |
static ConfigOption<String> |
JMXServerOptions.JMX_SERVER_PORT
Port configured to enable JMX server for metrics and debugging.
|
static ConfigOption<MemorySize> |
JobManagerOptions.JOB_MANAGER_HEAP_MEMORY
Deprecated.
use
JobManagerOptions.TOTAL_FLINK_MEMORY for standalone setups and JobManagerOptions.TOTAL_PROCESS_MEMORY for containerized setups. |
static ConfigOption<Long> |
JobManagerOptions.JOB_STORE_CACHE_SIZE
The job store cache size in bytes which is used to keep completed jobs in memory.
|
static ConfigOption<Long> |
JobManagerOptions.JOB_STORE_EXPIRATION_TIME
The time in seconds after which a completed job expires and is purged from the job store.
|
static ConfigOption<Integer> |
JobManagerOptions.JOB_STORE_MAX_CAPACITY
The max number of completed jobs that can be kept in the job store.
|
static ConfigOption<Boolean> |
JobManagerOptions.JVM_DIRECT_MEMORY_LIMIT_ENABLED
Off-heap Memory size for the JobManager.
|
static ConfigOption<MemorySize> |
JobManagerOptions.JVM_HEAP_MEMORY
JVM Heap Memory size for the JobManager.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.JVM_METASPACE
JVM Metaspace Size for the TaskExecutors.
|
static ConfigOption<MemorySize> |
JobManagerOptions.JVM_METASPACE
JVM Metaspace Size for the JobManager.
|
static ConfigOption<Float> |
TaskManagerOptions.JVM_OVERHEAD_FRACTION
Fraction of Total Process Memory to be reserved for JVM Overhead.
|
static ConfigOption<Float> |
JobManagerOptions.JVM_OVERHEAD_FRACTION
Fraction of Total Process Memory to be reserved for JVM Overhead.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.JVM_OVERHEAD_MAX
Max JVM Overhead size for the TaskExecutors.
|
static ConfigOption<MemorySize> |
JobManagerOptions.JVM_OVERHEAD_MAX
Max JVM Overhead size for the TaskExecutors.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.JVM_OVERHEAD_MIN
Min JVM Overhead size for the TaskExecutors.
|
static ConfigOption<MemorySize> |
JobManagerOptions.JVM_OVERHEAD_MIN
Min JVM Overhead size for the JobManager.
|
static ConfigOption<String> |
SecurityOptions.KERBEROS_LOGIN_CONTEXTS |
static ConfigOption<String> |
SecurityOptions.KERBEROS_LOGIN_KEYTAB |
static ConfigOption<String> |
SecurityOptions.KERBEROS_LOGIN_PRINCIPAL |
static ConfigOption<Boolean> |
SecurityOptions.KERBEROS_LOGIN_USETICKETCACHE |
static ConfigOption<Boolean> |
TaskManagerOptions.KILL_ON_OUT_OF_MEMORY
Whether to kill the TaskManager when the task thread throws an OutOfMemoryError.
|
static ConfigOption<Boolean> |
CheckpointingOptions.LOCAL_RECOVERY
This option configures local recovery for this state backend.
|
static ConfigOption<String> |
CheckpointingOptions.LOCAL_RECOVERY_TASK_MANAGER_STATE_ROOT_DIRS
The config parameter defining the root directories for storing file-based state for local
recovery.
|
static ConfigOption<Map<String,String>> |
TaskManagerOptions.MANAGED_MEMORY_CONSUMER_WEIGHTS
Weights of managed memory consumers.
|
static ConfigOption<Float> |
TaskManagerOptions.MANAGED_MEMORY_FRACTION
Fraction of Total Flink Memory to be used as Managed Memory, if
TaskManagerOptions.MANAGED_MEMORY_SIZE
is not specified. |
static ConfigOption<MemorySize> |
TaskManagerOptions.MANAGED_MEMORY_SIZE
Managed Memory size for TaskExecutors.
|
static ConfigOption<Integer> |
JobManagerOptions.MAX_ATTEMPTS_HISTORY_SIZE
The maximum number of prior execution attempts kept in history.
|
static ConfigOption<Long> |
ClusterOptions.MAX_REGISTRATION_TIMEOUT |
static ConfigOption<Integer> |
CheckpointingOptions.MAX_RETAINED_CHECKPOINTS
The maximum number of completed checkpoints to retain.
|
static ConfigOption<Integer> |
ResourceManagerOptions.MAX_SLOT_NUM |
static ConfigOption<MemorySize> |
TaskManagerOptions.MEMORY_SEGMENT_SIZE
Size of memory buffers used by the network stack and the memory manager.
|
static ConfigOption<String> |
NettyShuffleEnvironmentOptions.NETWORK_BLOCKING_SHUFFLE_TYPE |
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.NETWORK_BUFFERS_PER_CHANNEL
Number of network buffers to use for each outgoing/incoming channel (subpartition/input
channel).
|
static ConfigOption<Boolean> |
NettyShuffleEnvironmentOptions.NETWORK_DETAILED_METRICS
Boolean flag to enable/disable more detailed metrics about inbound/outbound network queue
lengths.
|
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.NETWORK_EXTRA_BUFFERS_PER_GATE
Number of extra network buffers to use for each outgoing/incoming gate (result
partition/input gate).
|
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.NETWORK_MAX_BUFFERS_PER_CHANNEL
Number of max buffers can be used for each output subparition.
|
static ConfigOption<Float> |
TaskManagerOptions.NETWORK_MEMORY_FRACTION
Fraction of Total Flink Memory to be used as Network Memory.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.NETWORK_MEMORY_MAX
Max Network Memory size for TaskExecutors.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.NETWORK_MEMORY_MIN
Min Network Memory size for TaskExecutors.
|
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.NETWORK_REQUEST_BACKOFF_INITIAL
Minimum backoff for partition requests of input channels.
|
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.NETWORK_REQUEST_BACKOFF_MAX
Maximum backoff for partition requests of input channels.
|
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.NETWORK_RETRIES |
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.NETWORK_SORT_SHUFFLE_MIN_BUFFERS
Minimum number of network buffers required per sort-merge blocking result partition.
|
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.NETWORK_SORT_SHUFFLE_MIN_PARALLELISM
Parallelism threshold to switch between sort-merge based blocking shuffle and the default
hash-based blocking shuffle.
|
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.NUM_ARENAS |
static ConfigOption<Integer> |
TaskManagerOptions.NUM_TASK_SLOTS
The config parameter defining the number of task slots of a task manager.
|
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.NUM_THREADS_CLIENT |
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.NUM_THREADS_SERVER |
static ConfigOption<MemorySize> |
JobManagerOptions.OFF_HEAP_MEMORY
Off-heap Memory size for the JobManager.
|
static ConfigOption<Integer> |
RestOptions.PORT
The port that the REST client connects to and the REST server binds to if
RestOptions.BIND_PORT
has not been specified. |
static ConfigOption<Integer> |
JobManagerOptions.PORT
The config parameter defining the network port to connect to for communication with the job
manager.
|
static ConfigOption<String> |
MetricOptions.QUERY_SERVICE_PORT
The default network port range for Flink's internal metric query service.
|
static ConfigOption<Long> |
ClusterOptions.REFUSED_REGISTRATION_DELAY |
static ConfigOption<java.time.Duration> |
TaskManagerOptions.REGISTRATION_TIMEOUT
Defines the timeout it can take for the TaskManager registration.
|
static ConfigOption<Boolean> |
JobManagerOptions.RETRIEVE_TASK_MANAGER_HOSTNAME
Flag indicating whether JobManager would retrieve canonical host name of TaskManager during
registration.
|
static ConfigOption<Long> |
RestOptions.RETRY_DELAY
The time in ms that the client waits between retries.
|
static ConfigOption<Integer> |
RestOptions.RETRY_MAX_ATTEMPTS
The number of retries the client will attempt if a retryable operations fails.
|
static ConfigOption<String> |
TaskManagerOptions.RPC_PORT
The default network port range the task manager expects incoming IPC connections.
|
static ConfigOption<String> |
CheckpointingOptions.SAVEPOINT_DIRECTORY
The default directory for savepoints.
|
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.SEND_RECEIVE_BUFFER_SIZE |
static ConfigOption<Integer> |
RestOptions.SERVER_MAX_CONTENT_LENGTH
The maximum content length that the server will handle.
|
static ConfigOption<Integer> |
RestOptions.SERVER_NUM_THREADS |
static ConfigOption<Integer> |
RestOptions.SERVER_THREAD_PRIORITY |
static ConfigOption<Long> |
JobManagerOptions.SLOT_IDLE_TIMEOUT
The timeout in milliseconds for a idle slot in Slot Pool.
|
static ConfigOption<Long> |
JobManagerOptions.SLOT_REQUEST_TIMEOUT
The timeout in milliseconds for requesting a slot from Slot Pool.
|
static ConfigOption<String> |
SecurityOptions.SSL_ALGORITHMS
The standard SSL algorithms to be supported.
|
static ConfigOption<String> |
SecurityOptions.SSL_INTERNAL_CERT_FINGERPRINT
For internal SSL, the sha1 fingerprint of the internal certificate to verify the client.
|
static ConfigOption<Integer> |
SecurityOptions.SSL_INTERNAL_CLOSE_NOTIFY_FLUSH_TIMEOUT
SSL session timeout after flushing the close_notify message.
|
static ConfigOption<Boolean> |
SecurityOptions.SSL_INTERNAL_ENABLED
Enable SSL for internal communication (akka rpc, netty data transport, blob server).
|
static ConfigOption<Integer> |
SecurityOptions.SSL_INTERNAL_HANDSHAKE_TIMEOUT
SSL session timeout during handshakes.
|
static ConfigOption<String> |
SecurityOptions.SSL_INTERNAL_KEY_PASSWORD
For internal SSL, the password to decrypt the private key.
|
static ConfigOption<String> |
SecurityOptions.SSL_INTERNAL_KEYSTORE
For internal SSL, the Java keystore file containing the private key and certificate.
|
static ConfigOption<String> |
SecurityOptions.SSL_INTERNAL_KEYSTORE_PASSWORD
For internal SSL, the password to decrypt the keystore file containing the certificate.
|
static ConfigOption<Integer> |
SecurityOptions.SSL_INTERNAL_SESSION_CACHE_SIZE
SSL session cache size.
|
static ConfigOption<Integer> |
SecurityOptions.SSL_INTERNAL_SESSION_TIMEOUT
SSL session timeout.
|
static ConfigOption<String> |
SecurityOptions.SSL_INTERNAL_TRUSTSTORE
For internal SSL, the truststore file containing the public CA certificates to verify the ssl
peers.
|
static ConfigOption<String> |
SecurityOptions.SSL_INTERNAL_TRUSTSTORE_PASSWORD
For internal SSL, the secret to decrypt the truststore.
|
static ConfigOption<String> |
SecurityOptions.SSL_PROTOCOL
SSL protocol version to be supported.
|
static ConfigOption<String> |
SecurityOptions.SSL_PROVIDER
SSL engine provider.
|
static ConfigOption<Boolean> |
SecurityOptions.SSL_REST_AUTHENTICATION_ENABLED
Enable mututal SSL authentication for external REST endpoints.
|
static ConfigOption<String> |
SecurityOptions.SSL_REST_CERT_FINGERPRINT
For external (REST) SSL, the sha1 fingerprint of the rest client certificate to verify.
|
static ConfigOption<Boolean> |
SecurityOptions.SSL_REST_ENABLED
Enable SSL for external REST endpoints.
|
static ConfigOption<String> |
SecurityOptions.SSL_REST_KEY_PASSWORD
For external (REST) SSL, the password to decrypt the private key.
|
static ConfigOption<String> |
SecurityOptions.SSL_REST_KEYSTORE
For external (REST) SSL, the Java keystore file containing the private key and certificate.
|
static ConfigOption<String> |
SecurityOptions.SSL_REST_KEYSTORE_PASSWORD
For external (REST) SSL, the password to decrypt the keystore file containing the
certificate.
|
static ConfigOption<String> |
SecurityOptions.SSL_REST_TRUSTSTORE
For external (REST) SSL, the truststore file containing the public CA certificates to verify
the ssl peers.
|
static ConfigOption<String> |
SecurityOptions.SSL_REST_TRUSTSTORE_PASSWORD
For external (REST) SSL, the secret to decrypt the truststore.
|
static ConfigOption<Boolean> |
SecurityOptions.SSL_VERIFY_HOSTNAME
Flag to enable/disable hostname verification for the ssl connections.
|
static ConfigOption<String> |
CheckpointingOptions.STATE_BACKEND
The state backend to be used to store and checkpoint state.
|
static ConfigOption<Long> |
TaskManagerOptions.TASK_CANCELLATION_INTERVAL
Time interval in milliseconds between two successive task cancellation attempts.
|
static ConfigOption<Long> |
TaskManagerOptions.TASK_CANCELLATION_TIMEOUT
Timeout in milliseconds after which a task cancellation times out and leads to a fatal
TaskManager error.
|
static ConfigOption<Long> |
TaskManagerOptions.TASK_CANCELLATION_TIMEOUT_TIMERS
This configures how long we wait for the timers in milliseconds to finish all pending timer
threads when the stream task is cancelled.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.TASK_HEAP_MEMORY
Task Heap Memory size for TaskExecutors.
|
static ConfigOption<String> |
TaskManagerOptions.TASK_MANAGER_RESOURCE_ID
The TaskManager's ResourceID.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.TASK_OFF_HEAP_MEMORY
Task Off-Heap Memory size for TaskExecutors.
|
static ConfigOption<String> |
CoreOptions.TMP_DIRS
The config parameter defining the directories for temporary files, separated by ",", "|", or
the system's
File.pathSeparator . |
static ConfigOption<MemorySize> |
TaskManagerOptions.TOTAL_FLINK_MEMORY
Total Flink Memory size for the TaskExecutors.
|
static ConfigOption<MemorySize> |
JobManagerOptions.TOTAL_FLINK_MEMORY
Total Flink Memory size for the JobManager.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.TOTAL_PROCESS_MEMORY
Total Process Memory size for the TaskExecutors.
|
static ConfigOption<MemorySize> |
JobManagerOptions.TOTAL_PROCESS_MEMORY
Total Process Memory size for the JobManager.
|
static ConfigOption<String> |
NettyShuffleEnvironmentOptions.TRANSPORT_TYPE |
static ConfigOption<String> |
HighAvailabilityOptions.ZOOKEEPER_CLIENT_ACL |
static ConfigOption<Integer> |
HighAvailabilityOptions.ZOOKEEPER_CONNECTION_TIMEOUT |
static ConfigOption<Integer> |
HighAvailabilityOptions.ZOOKEEPER_MAX_RETRY_ATTEMPTS |
static ConfigOption<Integer> |
HighAvailabilityOptions.ZOOKEEPER_RETRY_WAIT |
static ConfigOption<String> |
HighAvailabilityOptions.ZOOKEEPER_RUNNING_JOB_REGISTRY_PATH |
static ConfigOption<Boolean> |
SecurityOptions.ZOOKEEPER_SASL_DISABLE |
static ConfigOption<String> |
SecurityOptions.ZOOKEEPER_SASL_LOGIN_CONTEXT_NAME |
static ConfigOption<String> |
SecurityOptions.ZOOKEEPER_SASL_SERVICE_NAME |
static ConfigOption<Integer> |
HighAvailabilityOptions.ZOOKEEPER_SESSION_TIMEOUT |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Integer> |
RocksDBOptions.CHECKPOINT_TRANSFER_THREAD_NUM
The number of threads used to transfer (download and upload) files in RocksDBStateBackend.
|
static ConfigOption<MemorySize> |
RocksDBOptions.FIX_PER_SLOT_MEMORY_SIZE |
static ConfigOption<Double> |
RocksDBOptions.HIGH_PRIORITY_POOL_RATIO |
static ConfigOption<String> |
RocksDBOptions.LOCAL_DIRECTORIES
The local directory (on the TaskManager) where RocksDB puts its files.
|
static ConfigOption<String> |
RocksDBOptions.OPTIONS_FACTORY
The options factory class for RocksDB to create DBOptions and ColumnFamilyOptions.
|
static ConfigOption<String> |
RocksDBOptions.PREDEFINED_OPTIONS
The predefined settings for RocksDB DBOptions and ColumnFamilyOptions by Flink community.
|
static ConfigOption<RocksDBStateBackend.PriorityQueueStateType> |
RocksDBOptions.TIMER_SERVICE_FACTORY
Choice of timer service implementation.
|
static ConfigOption<Boolean> |
RocksDBOptions.USE_MANAGED_MEMORY |
static ConfigOption<Double> |
RocksDBOptions.WRITE_BUFFER_RATIO |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<java.time.Duration> |
KubernetesHighAvailabilityOptions.KUBERNETES_LEASE_DURATION |
static ConfigOption<java.time.Duration> |
KubernetesHighAvailabilityOptions.KUBERNETES_RENEW_DEADLINE |
static ConfigOption<java.time.Duration> |
KubernetesHighAvailabilityOptions.KUBERNETES_RETRY_PERIOD |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.