Modifier and Type | Field and Description |
---|---|
static ConfigOption<java.time.Duration> |
CEPCacheOptions.CEP_CACHE_STATISTICS_INTERVAL |
static ConfigOption<Integer> |
CEPCacheOptions.CEP_SHARED_BUFFER_ENTRY_CACHE_SLOTS |
static ConfigOption<Integer> |
CEPCacheOptions.CEP_SHARED_BUFFER_EVENT_CACHE_SLOTS |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
FsStateChangelogOptions.BASE_PATH |
static ConfigOption<Boolean> |
FsStateChangelogOptions.COMPRESSION_ENABLED |
static ConfigOption<MemorySize> |
FsStateChangelogOptions.IN_FLIGHT_DATA_LIMIT |
static ConfigOption<Integer> |
FsStateChangelogOptions.NUM_UPLOAD_THREADS |
static ConfigOption<java.time.Duration> |
FsStateChangelogOptions.PERSIST_DELAY |
static ConfigOption<MemorySize> |
FsStateChangelogOptions.PERSIST_SIZE_THRESHOLD |
static ConfigOption<MemorySize> |
FsStateChangelogOptions.PREEMPTIVE_PERSIST_THRESHOLD |
static ConfigOption<java.time.Duration> |
FsStateChangelogOptions.RETRY_DELAY_AFTER_FAILURE |
static ConfigOption<Integer> |
FsStateChangelogOptions.RETRY_MAX_ATTEMPTS |
static ConfigOption<String> |
FsStateChangelogOptions.RETRY_POLICY |
static ConfigOption<MemorySize> |
FsStateChangelogOptions.UPLOAD_BUFFER_SIZE |
static ConfigOption<java.time.Duration> |
FsStateChangelogOptions.UPLOAD_TIMEOUT |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<java.time.Duration> |
ClientOptions.CLIENT_RETRY_PERIOD |
static ConfigOption<java.time.Duration> |
ClientOptions.CLIENT_TIMEOUT |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<List<String>> |
ApplicationConfiguration.APPLICATION_ARGS |
static ConfigOption<String> |
ApplicationConfiguration.APPLICATION_MAIN_CLASS |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
WebOptions.ACCESS_CONTROL_ALLOW_ORIGIN
The config parameter defining the Access-Control-Allow-Origin header for all responses from
the web-frontend.
|
static ConfigOption<MemorySize> |
JobManagerOptions.ADAPTIVE_BATCH_SCHEDULER_AVG_DATA_VOLUME_PER_TASK |
static ConfigOption<Integer> |
JobManagerOptions.ADAPTIVE_BATCH_SCHEDULER_DEFAULT_SOURCE_PARALLELISM |
static ConfigOption<Integer> |
JobManagerOptions.ADAPTIVE_BATCH_SCHEDULER_MAX_PARALLELISM |
static ConfigOption<Integer> |
JobManagerOptions.ADAPTIVE_BATCH_SCHEDULER_MIN_PARALLELISM |
static ConfigOption<String> |
JobManagerOptions.ADDRESS
The config parameter defining the network address to connect to for communication with the
job manager.
|
static ConfigOption<String> |
RestOptions.ADDRESS
The address that should be used by clients to connect to the server.
|
static ConfigOption<String> |
WebOptions.ADDRESS
Deprecated.
|
static ConfigOption<Boolean> |
DeploymentOptions.ALLOW_CLIENT_JOB_CONFIGURATIONS |
static ConfigOption<String> |
CoreOptions.ALLOWED_FALLBACK_FILESYSTEMS |
static ConfigOption<List<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<List<String>> |
CoreOptions.ALWAYS_PARENT_FIRST_LOADER_PATTERNS_ADDITIONAL |
static ConfigOption<Integer> |
WebOptions.ARCHIVE_COUNT
The config parameter defining the number of archived jobs for the JobManager.
|
static ConfigOption<String> |
JobManagerOptions.ARCHIVE_DIR
The location where the JobManager stores the archives of completed jobs.
|
static ConfigOption<String> |
AkkaOptions.ASK_TIMEOUT
Deprecated.
|
static ConfigOption<java.time.Duration> |
AkkaOptions.ASK_TIMEOUT_DURATION
Timeout for akka ask calls.
|
static ConfigOption<java.time.Duration> |
RestOptions.ASYNC_OPERATION_STORE_DURATION |
static ConfigOption<Boolean> |
CheckpointingOptions.ASYNC_SNAPSHOTS
Deprecated.
Checkpoints are always asynchronous.
|
static ConfigOption<Boolean> |
DeploymentOptions.ATTACHED |
static ConfigOption<Boolean> |
PipelineOptions.AUTO_GENERATE_UIDS |
static ConfigOption<Boolean> |
PipelineOptions.AUTO_TYPE_REGISTRATION |
static ConfigOption<java.time.Duration> |
PipelineOptions.AUTO_WATERMARK_INTERVAL |
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<Integer> |
WebOptions.BACKPRESSURE_CLEANUP_INTERVAL
Deprecated.
- no longer used.
|
static ConfigOption<Integer> |
WebOptions.BACKPRESSURE_DELAY
Deprecated.
- no longer used.
|
static ConfigOption<Integer> |
WebOptions.BACKPRESSURE_NUM_SAMPLES
Deprecated.
- no longer used.
|
static ConfigOption<Integer> |
WebOptions.BACKPRESSURE_REFRESH_INTERVAL
Deprecated.
- no longer used.
|
static ConfigOption<BatchShuffleMode> |
ExecutionOptions.BATCH_SHUFFLE_MODE |
static ConfigOption<String> |
RestOptions.BIND_ADDRESS
The address that the server binds itself to.
|
static ConfigOption<String> |
JobManagerOptions.BIND_HOST
The local address of the network interface that the job manager binds to.
|
static ConfigOption<String> |
TaskManagerOptions.BIND_HOST
The local address of the network interface that the task manager binds 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> |
TaskManagerOptions.BUFFER_DEBLOAT_ENABLED |
static ConfigOption<java.time.Duration> |
TaskManagerOptions.BUFFER_DEBLOAT_PERIOD
The period between recalculation the relevant size of the buffer.
|
static ConfigOption<Integer> |
TaskManagerOptions.BUFFER_DEBLOAT_SAMPLES
The number of samples requires for the buffer size adjustment.
|
static ConfigOption<java.time.Duration> |
TaskManagerOptions.BUFFER_DEBLOAT_TARGET
The total time for which automated adjusted buffers should be fully consumed.
|
static ConfigOption<Integer> |
TaskManagerOptions.BUFFER_DEBLOAT_THRESHOLD_PERCENTAGES
Difference between the new and the old buffer size for applying the new value(in percent).
|
static ConfigOption<java.time.Duration> |
ExecutionOptions.BUFFER_TIMEOUT |
static ConfigOption<List<String>> |
PipelineOptions.CACHED_FILES |
static ConfigOption<Boolean> |
WebOptions.CANCEL_ENABLE
Config parameter indicating whether jobs can be cancel from the web-frontend.
|
static ConfigOption<Boolean> |
AkkaOptions.CAPTURE_ASK_CALLSTACK
Flag whether to capture call stacks for RPC ask calls.
|
static ConfigOption<Boolean> |
CoreOptions.CHECK_LEAKED_CLASSLOADER |
static ConfigOption<String> |
CheckpointingOptions.CHECKPOINT_STORAGE
The checkpoint storage used to checkpoint state for recovery.
|
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<Integer> |
WebOptions.CHECKPOINTS_HISTORY_SIZE
Config parameter defining the number of checkpoints to remember for recent history.
|
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<List<String>> |
PipelineOptions.CLASSPATHS
A list of URLs that are added to the classpath of each user code classloader of the program.
|
static ConfigOption<Long> |
BlobServerOptions.CLEANUP_INTERVAL
Cleanup interval of the blob caches at the task managers (in seconds).
|
static ConfigOption<String> |
CleanupOptions.CLEANUP_STRATEGY |
static ConfigOption<java.time.Duration> |
CleanupOptions.CLEANUP_STRATEGY_EXPONENTIAL_DELAY_INITIAL_BACKOFF |
static ConfigOption<Integer> |
CleanupOptions.CLEANUP_STRATEGY_EXPONENTIAL_DELAY_MAX_ATTEMPTS |
static ConfigOption<java.time.Duration> |
CleanupOptions.CLEANUP_STRATEGY_EXPONENTIAL_DELAY_MAX_BACKOFF |
static ConfigOption<Integer> |
CleanupOptions.CLEANUP_STRATEGY_FIXED_DELAY_ATTEMPTS |
static ConfigOption<java.time.Duration> |
CleanupOptions.CLEANUP_STRATEGY_FIXED_DELAY_DELAY |
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> |
QueryableStateOptions.CLIENT_NETWORK_THREADS
Number of network (event loop) threads for the KvState client (0 => Use number of available
cores).
|
static ConfigOption<Double> |
AkkaOptions.CLIENT_SOCKET_WORKER_POOL_SIZE_FACTOR |
static ConfigOption<Integer> |
AkkaOptions.CLIENT_SOCKET_WORKER_POOL_SIZE_MAX |
static ConfigOption<Integer> |
AkkaOptions.CLIENT_SOCKET_WORKER_POOL_SIZE_MIN |
static ConfigOption<String> |
AkkaOptions.CLIENT_TIMEOUT
Deprecated.
Use the
ClientOptions.CLIENT_TIMEOUT instead. |
static ConfigOption<ExecutionConfig.ClosureCleanerLevel> |
PipelineOptions.CLOSURE_CLEANER_LEVEL |
static ConfigOption<Integer> |
ClusterOptions.CLUSTER_IO_EXECUTOR_POOL_SIZE |
static ConfigOption<Long> |
ClusterOptions.CLUSTER_SERVICES_SHUTDOWN_TIMEOUT |
static ConfigOption<String> |
DeploymentOptionsInternal.CONF_DIR |
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.CONNECT_BACKLOG |
static ConfigOption<Integer> |
BlobServerOptions.CONNECT_TIMEOUT
The connection timeout in milliseconds for the blob client.
|
static ConfigOption<Long> |
RestOptions.CONNECTION_TIMEOUT
The maximum time in ms for the client to establish a TCP connection.
|
static ConfigOption<Double> |
TaskManagerOptions.CPU_CORES
This config option describes number of cpu cores of task executors.
|
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.DATA_BIND_PORT
The local network port that the task manager listen at for data exchange.
|
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<String> |
ConfigConstants.DEFAULT_JOB_MANAGER_WEB_FRONTEND_ADDRESS
Deprecated.
use
WebOptions.ADDRESS instead |
static ConfigOption<Integer> |
CoreOptions.DEFAULT_PARALLELISM |
static ConfigOption<Integer> |
OptimizerOptions.DELIMITED_FORMAT_MAX_LINE_SAMPLES
The maximum number of line samples taken by the compiler for delimited inputs.
|
static ConfigOption<Integer> |
OptimizerOptions.DELIMITED_FORMAT_MAX_SAMPLE_LEN
The maximal length of a line sample that the compiler takes for delimited inputs.
|
static ConfigOption<Integer> |
OptimizerOptions.DELIMITED_FORMAT_MIN_LINE_SAMPLES
The minimum number of line samples taken by the compiler for delimited inputs.
|
static ConfigOption<Integer> |
AkkaOptions.DISPATCHER_THROUGHPUT
Maximum number of messages until another actor is executed by the same thread.
|
static ConfigOption<Boolean> |
ClusterOptions.ENABLE_FINE_GRAINED_RESOURCE_MANAGEMENT |
static ConfigOption<Boolean> |
RestOptions.ENABLE_FLAMEGRAPH
Enables the experimental flame graph feature.
|
static ConfigOption<Boolean> |
QueryableStateOptions.ENABLE_QUERYABLE_STATE_PROXY_SERVER
Option whether the queryable state proxy and server should be enabled where possible and
configurable.
|
static ConfigOption<Boolean> |
StateChangelogOptions.ENABLE_STATE_CHANGE_LOG
Whether to enable state change log.
|
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> |
TaskManagerOptions.EXIT_ON_FATAL_AKKA_ERROR
Deprecated.
|
static ConfigOption<Long> |
ExternalResourceOptions.EXTERNAL_RESOURCE_AMOUNT
The amount for the external resource specified by >resource_name< per TaskExecutor.
|
static ConfigOption<String> |
ExternalResourceOptions.EXTERNAL_RESOURCE_DRIVER_FACTORY_CLASS
Defines the factory class name for the external resource identified by >resource_name<.
|
static ConfigOption<String> |
ExternalResourceOptions.EXTERNAL_RESOURCE_DRIVER_PARAM
The naming pattern of custom config options for the external resource specified by
>resource_name<.
|
static ConfigOption<List<String>> |
ExternalResourceOptions.EXTERNAL_RESOURCE_LIST
List of the resource_name of all external resources with delimiter ";", e.g.
|
static ConfigOption<Boolean> |
CoreOptions.FAIL_ON_USER_CLASS_LOADING_METASPACE_OOM |
static ConfigOption<Integer> |
BlobServerOptions.FETCH_BACKLOG
The config parameter defining the backlog of BLOB fetches on the JobManager.
|
static ConfigOption<Integer> |
BlobServerOptions.FETCH_CONCURRENT
The config parameter defining the maximum number of concurrent BLOB fetches that the
JobManager serves.
|
static ConfigOption<Integer> |
BlobServerOptions.FETCH_RETRIES
The config parameter defining number of retires for failed BLOB fetches.
|
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<Boolean> |
ClusterOptions.FINE_GRAINED_SHUFFLE_MODE_ALL_BLOCKING |
static ConfigOption<java.time.Duration> |
RestOptions.FLAMEGRAPH_CLEANUP_INTERVAL
"Time after which cached stats are cleaned up if not accessed.
|
static ConfigOption<java.time.Duration> |
RestOptions.FLAMEGRAPH_DELAY
Delay between individual stack trace samples taken for building a FlameGraph.
|
static ConfigOption<Integer> |
RestOptions.FLAMEGRAPH_NUM_SAMPLES
Number of samples to take to build a FlameGraph.
|
static ConfigOption<java.time.Duration> |
RestOptions.FLAMEGRAPH_REFRESH_INTERVAL
Time after which available stats are deprecated and need to be refreshed (by resampling).
|
static ConfigOption<Integer> |
RestOptions.FLAMEGRAPH_STACK_TRACE_DEPTH
Maximum depth of stack traces used to create FlameGraphs.
|
static ConfigOption<String> |
CoreOptions.FLINK_CLI_JVM_OPTIONS |
static ConfigOption<String> |
CoreOptions.FLINK_HADOOP_CONF_DIR
This options is here only for documentation generation, it is only evaluated in the shell
scripts.
|
static ConfigOption<String> |
CoreOptions.FLINK_HBASE_CONF_DIR
This options is here only for documentation generation, it is only evaluated in the shell
scripts.
|
static ConfigOption<String> |
CoreOptions.FLINK_HS_JVM_OPTIONS |
static ConfigOption<String> |
CoreOptions.FLINK_JM_JVM_OPTIONS |
static ConfigOption<String> |
CoreOptions.FLINK_JVM_OPTIONS |
static ConfigOption<String> |
CoreOptions.FLINK_LOG_DIR
This options is here only for documentation generation, it is only evaluated in the shell
scripts.
|
static ConfigOption<Integer> |
CoreOptions.FLINK_LOG_MAX
This options is here only for documentation generation, it is only evaluated in the shell
scripts.
|
static ConfigOption<String> |
CoreOptions.FLINK_PID_DIR
The config parameter defining the directory for Flink PID file.
|
static ConfigOption<String> |
CoreOptions.FLINK_SSH_OPTIONS
This options is here only for documentation generation, it is only evaluated in the shell
scripts.
|
static ConfigOption<String> |
CoreOptions.FLINK_TM_JVM_OPTIONS |
static ConfigOption<String> |
CoreOptions.FLINK_YARN_CONF_DIR
This options is here only for documentation generation, it is only evaluated in the shell
scripts.
|
static ConfigOption<Boolean> |
PipelineOptions.FORCE_AVRO |
static ConfigOption<Boolean> |
PipelineOptions.FORCE_KRYO |
static ConfigOption<Double> |
AkkaOptions.FORK_JOIN_EXECUTOR_PARALLELISM_FACTOR |
static ConfigOption<Integer> |
AkkaOptions.FORK_JOIN_EXECUTOR_PARALLELISM_MAX |
static ConfigOption<Integer> |
AkkaOptions.FORK_JOIN_EXECUTOR_PARALLELISM_MIN |
static ConfigOption<String> |
AkkaOptions.FRAMESIZE
Maximum framesize of akka messages.
|
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<Boolean> |
PipelineOptions.GENERIC_TYPES |
static ConfigOption<Map<String,String>> |
PipelineOptions.GLOBAL_JOB_PARAMETERS |
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.
|
static ConfigOption<String> |
HighAvailabilityOptions.HA_JOB_DELAY
Deprecated.
Don't use this option anymore. It has no effect on Flink.
|
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_JOBGRAPHS_PATH
ZooKeeper root path (ZNode) for job graphs.
|
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<Boolean> |
AlgorithmOptions.HASH_JOIN_BLOOM_FILTERS |
static ConfigOption<Long> |
HeartbeatManagerOptions.HEARTBEAT_INTERVAL
Time interval for requesting heartbeat from sender side.
|
static ConfigOption<Integer> |
HeartbeatManagerOptions.HEARTBEAT_RPC_FAILURE_THRESHOLD |
static ConfigOption<Long> |
HeartbeatManagerOptions.HEARTBEAT_TIMEOUT
Timeout for requesting and receiving heartbeat for both sender and receiver sides.
|
static ConfigOption<String> |
HistoryServerOptions.HISTORY_SERVER_ARCHIVE_DIRS
Comma-separated list of directories which the HistoryServer polls for new archives.
|
static ConfigOption<Long> |
HistoryServerOptions.HISTORY_SERVER_ARCHIVE_REFRESH_INTERVAL
The interval at which the HistoryServer polls
HistoryServerOptions.HISTORY_SERVER_ARCHIVE_DIRS for new archives. |
static ConfigOption<Boolean> |
HistoryServerOptions.HISTORY_SERVER_CLEANUP_EXPIRED_JOBS
If this option is enabled then deleted job archives are also deleted from HistoryServer.
|
static ConfigOption<Integer> |
HistoryServerOptions.HISTORY_SERVER_RETAINED_JOBS |
static ConfigOption<String> |
HistoryServerOptions.HISTORY_SERVER_WEB_ADDRESS
The address under which the HistoryServer web-frontend is accessible.
|
static ConfigOption<String> |
HistoryServerOptions.HISTORY_SERVER_WEB_DIR
The local directory used by the HistoryServer web-frontend.
|
static ConfigOption<Integer> |
HistoryServerOptions.HISTORY_SERVER_WEB_PORT
The port under which the HistoryServer web-frontend is accessible.
|
static ConfigOption<Long> |
HistoryServerOptions.HISTORY_SERVER_WEB_REFRESH_INTERVAL
The refresh interval for the HistoryServer web-frontend in milliseconds.
|
static ConfigOption<Boolean> |
HistoryServerOptions.HISTORY_SERVER_WEB_SSL_ENABLED
Enables/Disables SSL support for the HistoryServer web-frontend.
|
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<java.time.Duration> |
TaskManagerOptions.INITIAL_REGISTRATION_BACKOFF
Deprecated.
use
ClusterOptions.INITIAL_REGISTRATION_TIMEOUT instead |
static ConfigOption<Long> |
ClusterOptions.INITIAL_REGISTRATION_TIMEOUT |
static ConfigOption<ClusterOptions.UserSystemExitMode> |
ClusterOptions.INTERCEPT_USER_SYSTEM_EXIT |
static ConfigOption<Integer> |
ResourceManagerOptions.IPC_PORT
Defines the network port to connect to for communication with the resource manager.
|
static ConfigOption<List<String>> |
PipelineOptions.JARS
A list of jar files that contain the user-defined function (UDF) classes and all classes used
from within the UDFs.
|
static ConfigOption<String> |
JMXServerOptions.JMX_SERVER_PORT
Port configured to enable JMX server for metrics and debugging.
|
static ConfigOption<List<String>> |
DeploymentOptions.JOB_LISTENERS |
static ConfigOption<Integer> |
JobManagerOptions.JOB_MANAGER_FUTURE_POOL_SIZE |
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<Integer> |
JobManagerOptions.JOB_MANAGER_HEAP_MEMORY_MB
Deprecated.
use
JobManagerOptions.TOTAL_FLINK_MEMORY for standalone setups and JobManagerOptions.TOTAL_PROCESS_MEMORY for containerized setups. |
static ConfigOption<Integer> |
JobManagerOptions.JOB_MANAGER_IO_POOL_SIZE |
static ConfigOption<String> |
ClusterOptions.JOB_MANAGER_PROCESS_WORKING_DIR_BASE |
static ConfigOption<String> |
JobManagerOptions.JOB_MANAGER_RESOURCE_ID
The JobManager's ResourceID.
|
static ConfigOption<List<MetricOptions.JobStatusMetrics>> |
MetricOptions.JOB_STATUS_METRICS
Controls which job status metrics will be exposed.
|
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<JobManagerOptions.JobStoreType> |
JobManagerOptions.JOB_STORE_TYPE
Config parameter determining the job store implementation in session cluster.
|
static ConfigOption<String> |
ResourceManagerOptions.JOB_TIMEOUT
Timeout for jobs which don't have a job manager as leader assigned.
|
static ConfigOption<Boolean> |
JobManagerOptions.JVM_DIRECT_MEMORY_LIMIT_ENABLED
Off-heap Memory size for the JobManager.
|
static ConfigOption<Boolean> |
AkkaOptions.JVM_EXIT_ON_FATAL_ERROR
Exit JVM on fatal Akka errors.
|
static ConfigOption<MemorySize> |
JobManagerOptions.JVM_HEAP_MEMORY
JVM Heap Memory size for the JobManager.
|
static ConfigOption<MemorySize> |
JobManagerOptions.JVM_METASPACE
JVM Metaspace Size for the JobManager.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.JVM_METASPACE
JVM Metaspace Size for the TaskExecutors.
|
static ConfigOption<Float> |
JobManagerOptions.JVM_OVERHEAD_FRACTION
Fraction of Total Process Memory to be reserved for JVM Overhead.
|
static ConfigOption<Float> |
TaskManagerOptions.JVM_OVERHEAD_FRACTION
Fraction of Total Process Memory to be reserved for JVM Overhead.
|
static ConfigOption<MemorySize> |
JobManagerOptions.JVM_OVERHEAD_MAX
Max JVM Overhead size for the TaskExecutors.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.JVM_OVERHEAD_MAX
Max JVM Overhead size for the TaskExecutors.
|
static ConfigOption<MemorySize> |
JobManagerOptions.JVM_OVERHEAD_MIN
Min JVM Overhead size for the JobManager.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.JVM_OVERHEAD_MIN
Min JVM Overhead size for the TaskExecutors.
|
static ConfigOption<Boolean> |
SecurityOptions.KERBEROS_FETCH_DELEGATION_TOKEN |
static ConfigOption<String> |
SecurityOptions.KERBEROS_KRB5_PATH |
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<List<String>> |
PipelineOptions.KRYO_DEFAULT_SERIALIZERS |
static ConfigOption<List<String>> |
PipelineOptions.KRYO_REGISTERED_CLASSES |
static ConfigOption<Integer> |
MetricOptions.LATENCY_HISTORY_SIZE
The number of measured latencies to maintain at each operator.
|
static ConfigOption<Long> |
MetricOptions.LATENCY_INTERVAL |
static ConfigOption<String> |
MetricOptions.LATENCY_SOURCE_GRANULARITY |
static ConfigOption<Boolean> |
StateBackendOptions.LATENCY_TRACK_ENABLED |
static ConfigOption<Integer> |
StateBackendOptions.LATENCY_TRACK_HISTORY_SIZE |
static ConfigOption<Integer> |
StateBackendOptions.LATENCY_TRACK_SAMPLE_INTERVAL |
static ConfigOption<Boolean> |
StateBackendOptions.LATENCY_TRACK_STATE_NAME_AS_VARIABLE |
static ConfigOption<Integer> |
ResourceManagerOptions.LOCAL_NUMBER_RESOURCE_MANAGER
Deprecated.
|
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<Boolean> |
AkkaOptions.LOG_LIFECYCLE_EVENTS
Log lifecycle events.
|
static ConfigOption<String> |
WebOptions.LOG_PATH
The log file location (may be in /log for standalone but under log directory when using
YARN).
|
static ConfigOption<String> |
AkkaOptions.LOOKUP_TIMEOUT
Deprecated.
|
static ConfigOption<java.time.Duration> |
AkkaOptions.LOOKUP_TIMEOUT_DURATION
Timeout for all blocking calls that look up remote actors.
|
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> |
StateChangelogOptions.MATERIALIZATION_MAX_FAILURES_ALLOWED |
static ConfigOption<Integer> |
JobManagerOptions.MAX_ATTEMPTS_HISTORY_SIZE
The maximum number of prior execution attempts kept in history.
|
static ConfigOption<Integer> |
WebOptions.MAX_EXCEPTION_HISTORY_SIZE
The maximum number of failures kept in the exception history.
|
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.MAX_NUM_TCP_CONNECTIONS
The maximum number of tpc connections between taskmanagers for data communication.
|
static ConfigOption<Integer> |
PipelineOptions.MAX_PARALLELISM |
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<Double> |
ResourceManagerOptions.MAX_TOTAL_CPU |
static ConfigOption<MemorySize> |
ResourceManagerOptions.MAX_TOTAL_MEM |
static ConfigOption<MemorySize> |
TaskManagerOptions.MEMORY_SEGMENT_SIZE
Size of memory buffers used by the network stack and the memory manager.
|
static ConfigOption<Long> |
MetricOptions.METRIC_FETCHER_UPDATE_INTERVAL
The config parameter defining the update interval for the metric fetcher used by the web UI
in milliseconds.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.MIN_MEMORY_SEGMENT_SIZE
Minimum possible size of memory buffers used by the network stack and the memory manager.
|
static ConfigOption<Integer> |
JobManagerOptions.MIN_PARALLELISM_INCREASE |
static ConfigOption<String> |
PipelineOptions.NAME
The job name used for printing and logging.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.NETWORK_BATCH_SHUFFLE_READ_MEMORY
Size of direct memory used by blocking shuffle for shuffle data read (currently only used by
sort-shuffle).
|
static ConfigOption<String> |
NettyShuffleEnvironmentOptions.NETWORK_BLOCKING_SHUFFLE_TYPE |
static ConfigOption<Float> |
NettyShuffleEnvironmentOptions.NETWORK_BUFFERS_MEMORY_FRACTION
Deprecated.
use
TaskManagerOptions.NETWORK_MEMORY_FRACTION instead |
static ConfigOption<String> |
NettyShuffleEnvironmentOptions.NETWORK_BUFFERS_MEMORY_MAX
Deprecated.
use
TaskManagerOptions.NETWORK_MEMORY_MAX instead |
static ConfigOption<String> |
NettyShuffleEnvironmentOptions.NETWORK_BUFFERS_MEMORY_MIN
Deprecated.
use
TaskManagerOptions.NETWORK_MEMORY_MIN instead |
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<Long> |
NettyShuffleEnvironmentOptions.NETWORK_EXCLUSIVE_BUFFERS_REQUEST_TIMEOUT_MILLISECONDS
The timeout for requesting exclusive buffers for each channel.
|
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_NUM_BUFFERS
Deprecated.
|
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 blocking result partition for sort-shuffle.
|
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.NETWORK_SORT_SHUFFLE_MIN_PARALLELISM
Parallelism threshold to switch between sort-based blocking shuffle and 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<Boolean> |
PipelineOptions.OBJECT_REUSE |
static ConfigOption<MemorySize> |
JobManagerOptions.OFF_HEAP_MEMORY
Off-heap Memory size for the JobManager.
|
static ConfigOption<Integer> |
BlobServerOptions.OFFLOAD_MINSIZE
The minimum size for messages to be offloaded to the BlobServer.
|
static ConfigOption<Boolean> |
PipelineOptions.OPERATOR_CHAINING |
static ConfigOption<Boolean> |
JobManagerOptions.PARTITION_RELEASE_DURING_JOB_EXECUTION
Config parameter controlling whether partitions should already be released during the job
execution.
|
static ConfigOption<java.time.Duration> |
StateChangelogOptions.PERIODIC_MATERIALIZATION_INTERVAL |
static ConfigOption<String> |
PipelineOptionsInternal.PIPELINE_FIXED_JOB_ID |
static ConfigOption<List<String>> |
CoreOptions.PLUGIN_ALWAYS_PARENT_FIRST_LOADER_PATTERNS
Plugin-specific option of
CoreOptions.ALWAYS_PARENT_FIRST_LOADER_PATTERNS . |
static ConfigOption<List<String>> |
CoreOptions.PLUGIN_ALWAYS_PARENT_FIRST_LOADER_PATTERNS_ADDITIONAL |
static ConfigOption<List<String>> |
PipelineOptions.POJO_REGISTERED_CLASSES |
static ConfigOption<String> |
BlobServerOptions.PORT
The config parameter defining the server port of the blob service.
|
static ConfigOption<Integer> |
JobManagerOptions.PORT
The config parameter defining the network port to connect to for communication with the job
manager.
|
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> |
WebOptions.PORT
Deprecated.
Use
RestOptions.PORT instead |
static ConfigOption<String> |
ClusterOptions.PROCESS_WORKING_DIR_BASE |
static ConfigOption<Integer> |
QueryableStateOptions.PROXY_ASYNC_QUERY_THREADS
Number of async query threads for the client proxy (0 => #slots).
|
static ConfigOption<Integer> |
QueryableStateOptions.PROXY_NETWORK_THREADS
Number of network (event loop) threads for the client proxy (0 => #slots).
|
static ConfigOption<String> |
QueryableStateOptions.PROXY_PORT_RANGE
The config parameter defining the server port range of the queryable state proxy.
|
static ConfigOption<String> |
MetricOptions.QUERY_SERVICE_PORT
The default network port range for Flink's internal metric query service.
|
static ConfigOption<Integer> |
MetricOptions.QUERY_SERVICE_THREAD_PRIORITY
The thread priority for Flink's internal metric query service.
|
static ConfigOption<Integer> |
ResourceManagerOptions.REDUNDANT_TASK_MANAGER_NUM
The number of redundant task managers.
|
static ConfigOption<Long> |
WebOptions.REFRESH_INTERVAL
The config parameter defining the refresh interval for the web-frontend in milliseconds.
|
static ConfigOption<java.time.Duration> |
TaskManagerOptions.REFUSED_REGISTRATION_BACKOFF
Deprecated.
use
ClusterOptions.REFUSED_REGISTRATION_DELAY instead |
static ConfigOption<Long> |
ClusterOptions.REFUSED_REGISTRATION_DELAY |
static ConfigOption<java.time.Duration> |
TaskManagerOptions.REGISTRATION_MAX_BACKOFF
Deprecated.
use
ClusterOptions.MAX_REGISTRATION_TIMEOUT instead |
static ConfigOption<java.time.Duration> |
TaskManagerOptions.REGISTRATION_TIMEOUT
Defines the timeout it can take for the TaskManager registration.
|
static ConfigOption<String> |
MetricOptions.REPORTER_CLASS |
static ConfigOption<String> |
MetricOptions.REPORTER_CONFIG_PARAMETER |
static ConfigOption<java.time.Duration> |
MetricOptions.REPORTER_INTERVAL |
static ConfigOption<String> |
MetricOptions.REPORTERS_LIST
An optional list of reporter names.
|
static ConfigOption<java.time.Duration> |
JobManagerOptions.RESOURCE_STABILIZATION_TIMEOUT |
static ConfigOption<java.time.Duration> |
JobManagerOptions.RESOURCE_WAIT_TIMEOUT |
static ConfigOption<String> |
RestartStrategyOptions.RESTART_STRATEGY |
static ConfigOption<Double> |
RestartStrategyOptions.RESTART_STRATEGY_EXPONENTIAL_DELAY_BACKOFF_MULTIPLIER |
static ConfigOption<java.time.Duration> |
RestartStrategyOptions.RESTART_STRATEGY_EXPONENTIAL_DELAY_INITIAL_BACKOFF |
static ConfigOption<Double> |
RestartStrategyOptions.RESTART_STRATEGY_EXPONENTIAL_DELAY_JITTER_FACTOR |
static ConfigOption<java.time.Duration> |
RestartStrategyOptions.RESTART_STRATEGY_EXPONENTIAL_DELAY_MAX_BACKOFF |
static ConfigOption<java.time.Duration> |
RestartStrategyOptions.RESTART_STRATEGY_EXPONENTIAL_DELAY_RESET_BACKOFF_THRESHOLD |
static ConfigOption<java.time.Duration> |
RestartStrategyOptions.RESTART_STRATEGY_FAILURE_RATE_DELAY |
static ConfigOption<java.time.Duration> |
RestartStrategyOptions.RESTART_STRATEGY_FAILURE_RATE_FAILURE_RATE_INTERVAL |
static ConfigOption<Integer> |
RestartStrategyOptions.RESTART_STRATEGY_FAILURE_RATE_MAX_FAILURES_PER_INTERVAL |
static ConfigOption<Integer> |
RestartStrategyOptions.RESTART_STRATEGY_FIXED_DELAY_ATTEMPTS |
static ConfigOption<java.time.Duration> |
RestartStrategyOptions.RESTART_STRATEGY_FIXED_DELAY_DELAY |
static ConfigOption<String> |
ConfigConstants.RESTART_STRATEGY_FIXED_DELAY_DELAY
Deprecated.
|
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<Long> |
AkkaOptions.RETRY_GATE_CLOSED_FOR
Milliseconds a gate should be closed for after a remote connection was disconnected.
|
static ConfigOption<Integer> |
RestOptions.RETRY_MAX_ATTEMPTS
The number of retries the client will attempt if a retryable operations fails.
|
static ConfigOption<Integer> |
JobManagerOptions.RPC_BIND_PORT
The local port that the job manager binds to.
|
static ConfigOption<Integer> |
TaskManagerOptions.RPC_BIND_PORT
The local port that the task manager binds to.
|
static ConfigOption<String> |
TaskManagerOptions.RPC_PORT
The default network port range the task manager expects incoming IPC connections.
|
static ConfigOption<RuntimeExecutionMode> |
ExecutionOptions.RUNTIME_MODE |
static ConfigOption<String> |
CheckpointingOptions.SAVEPOINT_DIRECTORY
The default directory for savepoints.
|
static ConfigOption<JobManagerOptions.SchedulerType> |
JobManagerOptions.SCHEDULER
Config parameter determining the scheduler implementation.
|
static ConfigOption<SchedulerExecutionMode> |
JobManagerOptions.SCHEDULER_MODE |
static ConfigOption<String> |
MetricOptions.SCOPE_DELIMITER
The delimiter used to assemble the metric identifier.
|
static ConfigOption<String> |
MetricOptions.SCOPE_NAMING_JM
The scope format string that is applied to all metrics scoped to a JobManager.
|
static ConfigOption<String> |
MetricOptions.SCOPE_NAMING_JM_JOB
The scope format string that is applied to all metrics scoped to a job on a JobManager.
|
static ConfigOption<String> |
MetricOptions.SCOPE_NAMING_OPERATOR
The scope format string that is applied to all metrics scoped to an operator.
|
static ConfigOption<String> |
MetricOptions.SCOPE_NAMING_TASK
The scope format string that is applied to all metrics scoped to a task.
|
static ConfigOption<String> |
MetricOptions.SCOPE_NAMING_TM
The scope format string that is applied to all metrics scoped to a TaskManager.
|
static ConfigOption<String> |
MetricOptions.SCOPE_NAMING_TM_JOB
The scope format string that is applied to all metrics scoped to a job on a TaskManager.
|
static ConfigOption<List<String>> |
SecurityOptions.SECURITY_CONTEXT_FACTORY_CLASSES |
static ConfigOption<List<String>> |
SecurityOptions.SECURITY_MODULE_FACTORY_CLASSES |
static ConfigOption<Integer> |
NettyShuffleEnvironmentOptions.SEND_RECEIVE_BUFFER_SIZE |
static ConfigOption<Integer> |
QueryableStateOptions.SERVER_ASYNC_QUERY_THREADS
Number of async query threads for the KvStateServerHandler (0 => #slots).
|
static ConfigOption<Integer> |
RestOptions.SERVER_MAX_CONTENT_LENGTH
The maximum content length that the server will handle.
|
static ConfigOption<Integer> |
QueryableStateOptions.SERVER_NETWORK_THREADS
Number of network (event loop) threads for the KvState server (0 => #slots).
|
static ConfigOption<Integer> |
RestOptions.SERVER_NUM_THREADS |
static ConfigOption<String> |
QueryableStateOptions.SERVER_PORT_RANGE
The config parameter defining the server port range of the queryable state server.
|
static ConfigOption<Double> |
AkkaOptions.SERVER_SOCKET_WORKER_POOL_SIZE_FACTOR |
static ConfigOption<Integer> |
AkkaOptions.SERVER_SOCKET_WORKER_POOL_SIZE_MAX |
static ConfigOption<Integer> |
AkkaOptions.SERVER_SOCKET_WORKER_POOL_SIZE_MIN |
static ConfigOption<Integer> |
RestOptions.SERVER_THREAD_PRIORITY |
static ConfigOption<String> |
NettyShuffleEnvironmentOptions.SHUFFLE_COMPRESSION_CODEC
The codec to be used when compressing shuffle data.
|
static ConfigOption<Boolean> |
DeploymentOptions.SHUTDOWN_IF_ATTACHED |
static ConfigOption<Boolean> |
DeploymentOptions.SHUTDOWN_ON_APPLICATION_FINISH |
static ConfigOption<Long> |
JobManagerOptions.SLOT_IDLE_TIMEOUT
The timeout in milliseconds for a idle slot in Slot Pool.
|
static ConfigOption<Long> |
ResourceManagerOptions.SLOT_MANAGER_TASK_MANAGER_TIMEOUT
Deprecated.
|
static ConfigOption<Long> |
JobManagerOptions.SLOT_REQUEST_TIMEOUT
The timeout in milliseconds for requesting a slot from Slot Pool.
|
static ConfigOption<Long> |
ResourceManagerOptions.SLOT_REQUEST_TIMEOUT
Deprecated.
|
static ConfigOption<java.time.Duration> |
TaskManagerOptions.SLOT_TIMEOUT
Timeout for identifying inactive slots.
|
static ConfigOption<Boolean> |
ExecutionOptions.SNAPSHOT_COMPRESSION
Should be moved to
ExecutionCheckpointingOptions along with ExecutionConfig#useSnapshotCompression , which should be put into CheckpointConfig . |
static ConfigOption<Integer> |
BlobServerOptions.SO_TIMEOUT
The socket timeout in milliseconds for the blob client.
|
static ConfigOption<Boolean> |
ExecutionOptions.SORT_INPUTS |
static ConfigOption<Float> |
AlgorithmOptions.SORT_SPILLING_THRESHOLD |
static ConfigOption<MemorySize> |
ExecutionOptions.SORTED_INPUTS_MEMORY |
static ConfigOption<Integer> |
AlgorithmOptions.SPILLING_MAX_FAN |
static ConfigOption<String> |
SecurityOptions.SSL_ALGORITHMS
The standard SSL algorithms to be supported.
|
static ConfigOption<Boolean> |
BlobServerOptions.SSL_ENABLED
Flag to override ssl support for the blob service transport.
|
static ConfigOption<Boolean> |
AkkaOptions.SSL_ENABLED
Override SSL support for the Akka transport.
|
static ConfigOption<Boolean> |
SecurityOptions.SSL_ENABLED
Deprecated.
Use
SecurityOptions.SSL_INTERNAL_ENABLED and SecurityOptions.SSL_REST_ENABLED instead. |
static ConfigOption<Boolean> |
WebOptions.SSL_ENABLED
Deprecated.
|
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_KEY_PASSWORD
Secret to decrypt the server key.
|
static ConfigOption<String> |
SecurityOptions.SSL_KEYSTORE
The Java keystore file containing the flink endpoint key and certificate.
|
static ConfigOption<String> |
SecurityOptions.SSL_KEYSTORE_PASSWORD
Secret to decrypt the keystore file.
|
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<String> |
SecurityOptions.SSL_TRUSTSTORE
The truststore file containing the public CA certificates to verify the ssl peers.
|
static ConfigOption<String> |
SecurityOptions.SSL_TRUSTSTORE_PASSWORD
Secret to decrypt the truststore.
|
static ConfigOption<Boolean> |
SecurityOptions.SSL_VERIFY_HOSTNAME
Flag to enable/disable hostname verification for the ssl connections.
|
static ConfigOption<Long> |
ResourceManagerOptions.STANDALONE_CLUSTER_STARTUP_PERIOD_TIME
Time in milliseconds of the start-up period of a standalone cluster.
|
static ConfigOption<Double> |
ResourceManagerOptions.START_WORKER_MAX_FAILURE_RATE
The maximum number of start worker failures (Native Kubernetes / Yarn) per minute before
pausing requesting new workers.
|
static ConfigOption<java.time.Duration> |
ResourceManagerOptions.START_WORKER_RETRY_INTERVAL
The time to wait before requesting new workers (Native Kubernetes / Yarn) once the max
failure rate of starting workers (
ResourceManagerOptions.START_WORKER_MAX_FAILURE_RATE ) is reached. |
static ConfigOption<String> |
AkkaOptions.STARTUP_TIMEOUT
Timeout for the startup of the actor system.
|
static ConfigOption<String> |
StateBackendOptions.STATE_BACKEND
The checkpoint storage used to store operator state locally within the cluster during
execution.
|
static ConfigOption<String> |
CheckpointingOptions.STATE_BACKEND
Deprecated.
|
static ConfigOption<String> |
StateChangelogOptions.STATE_CHANGE_LOG_STORAGE
Which storage to use to store state changelog.
|
static ConfigOption<String> |
BlobServerOptions.STORAGE_DIRECTORY
The config parameter defining the storage directory to be used by the blob server.
|
static ConfigOption<Boolean> |
WebOptions.SUBMIT_ENABLE
Config parameter indicating whether jobs can be uploaded and run from the web-frontend.
|
static ConfigOption<Boolean> |
DeploymentOptions.SUBMIT_FAILED_JOB_ON_APPLICATION_ERROR |
static ConfigOption<Boolean> |
MetricOptions.SYSTEM_RESOURCE_METRICS
Whether Flink should report system resource metrics such as machine's CPU, memory or network
usage.
|
static ConfigOption<Long> |
MetricOptions.SYSTEM_RESOURCE_METRICS_PROBING_INTERVAL
Interval between probing of system resource metrics specified in milliseconds.
|
static ConfigOption<String> |
DeploymentOptions.TARGET |
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<MemorySize> |
TaskManagerOptions.TASK_MANAGER_HEAP_MEMORY
Deprecated.
use
TaskManagerOptions.TOTAL_FLINK_MEMORY for standalone setups and TaskManagerOptions.TOTAL_PROCESS_MEMORY for containerized setups. |
static ConfigOption<Integer> |
TaskManagerOptions.TASK_MANAGER_HEAP_MEMORY_MB
Deprecated.
use
TaskManagerOptions.TOTAL_FLINK_MEMORY for standalone setups and TaskManagerOptions.TOTAL_PROCESS_MEMORY for containerized setups. |
static ConfigOption<String> |
ClusterOptions.TASK_MANAGER_PROCESS_WORKING_DIR_BASE |
static ConfigOption<java.time.Duration> |
ResourceManagerOptions.TASK_MANAGER_REGISTRATION_TIMEOUT
Timeout for TaskManagers to register at the active resource managers.
|
static ConfigOption<Boolean> |
ResourceManagerOptions.TASK_MANAGER_RELEASE_WHEN_RESULT_CONSUMED
Deprecated.
The default value should be reasonable enough in all cases, this option is to
fallback to older behaviour which will be removed or refactored in future.
|
static ConfigOption<String> |
TaskManagerOptions.TASK_MANAGER_RESOURCE_ID
The TaskManager's ResourceID.
|
static ConfigOption<String> |
TaskManagerOptionsInternal.TASK_MANAGER_RESOURCE_ID_METADATA |
static ConfigOption<Long> |
ResourceManagerOptions.TASK_MANAGER_TIMEOUT
The timeout for an idle task manager to be released, in milliseconds.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.TASK_OFF_HEAP_MEMORY
Task Off-Heap Memory size for TaskExecutors.
|
static ConfigOption<Boolean> |
NettyShuffleEnvironmentOptions.TCP_CONNECTION_REUSE_ACROSS_JOBS_ENABLED
Whether to reuse tcp connections across multi jobs.
|
static ConfigOption<String> |
AkkaOptions.TCP_TIMEOUT
The Akka tcp connection timeout.
|
static ConfigOption<Integer> |
ClusterOptions.THREAD_DUMP_STACKTRACE_MAX_DEPTH |
static ConfigOption<Long> |
WebOptions.TIMEOUT
Timeout for asynchronous operations by the web monitor in milliseconds.
|
static ConfigOption<String> |
WebOptions.TMP_DIR
The config parameter defining the flink web directory to be used by the webmonitor.
|
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> |
JobManagerOptions.TOTAL_FLINK_MEMORY
Total Flink Memory size for the JobManager.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.TOTAL_FLINK_MEMORY
Total Flink Memory size for the TaskExecutors.
|
static ConfigOption<MemorySize> |
JobManagerOptions.TOTAL_PROCESS_MEMORY
Total Process Memory size for the JobManager.
|
static ConfigOption<MemorySize> |
TaskManagerOptions.TOTAL_PROCESS_MEMORY
Total Process Memory size for the TaskExecutors.
|
static ConfigOption<String> |
NettyShuffleEnvironmentOptions.TRANSPORT_TYPE |
static ConfigOption<ClusterOptions.UncaughtExceptionHandleMode> |
ClusterOptions.UNCAUGHT_EXCEPTION_HANDLING |
static ConfigOption<String> |
WebOptions.UPLOAD_DIR
The config parameter defining the directory for uploading the job jars.
|
static ConfigOption<Boolean> |
ExecutionOptions.USE_BATCH_STATE_BACKEND |
static ConfigOption<Boolean> |
AlgorithmOptions.USE_LARGE_RECORDS_HANDLER |
static ConfigOption<Boolean> |
HighAvailabilityOptions.USE_OLD_HA_SERVICES
Safety hatch to fallback to the old ha services implementations.
|
static ConfigOption<PipelineOptions.VertexDescriptionMode> |
PipelineOptions.VERTEX_DESCRIPTION_MODE |
static ConfigOption<Boolean> |
PipelineOptions.VERTEX_NAME_INCLUDE_INDEX_PREFIX |
static ConfigOption<String> |
AkkaOptions.WATCH_HEARTBEAT_INTERVAL
Deprecated.
Don't use this option anymore. It has no effect on Flink.
|
static ConfigOption<String> |
AkkaOptions.WATCH_HEARTBEAT_PAUSE
Deprecated.
Don't use this option anymore. It has no effect on Flink.
|
static ConfigOption<Integer> |
AkkaOptions.WATCH_THRESHOLD
Deprecated.
Don't use this option anymore. It has no effect on Flink.
|
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 |
static ConfigOption<Boolean> |
HighAvailabilityOptions.ZOOKEEPER_TOLERATE_SUSPENDED_CONNECTIONS |
Modifier and Type | Method and Description |
---|---|
ConfigOption<T> |
ConfigOptions.TypedConfigOptionBuilder.defaultValue(T value)
Creates a ConfigOption with the given default value.
|
<T> ConfigOption<T> |
ConfigOptions.OptionBuilder.defaultValue(T value)
Deprecated.
define the type explicitly first with one of the intType(), stringType(),
etc.
|
ConfigOption<List<E>> |
ConfigOptions.ListConfigOptionBuilder.defaultValues(E... values)
Creates a ConfigOption with the given default value.
|
static ConfigOption<Integer> |
CoreOptions.fileSystemConnectionLimit(String scheme)
The total number of input plus output connections that a file system for the given scheme may
open.
|
static ConfigOption<Integer> |
CoreOptions.fileSystemConnectionLimitIn(String scheme)
The total number of input connections that a file system for the given scheme may open.
|
static ConfigOption<Integer> |
CoreOptions.fileSystemConnectionLimitOut(String scheme)
The total number of output connections that a file system for the given scheme may open.
|
static ConfigOption<Long> |
CoreOptions.fileSystemConnectionLimitStreamInactivityTimeout(String scheme)
If any connection limit is configured, this option can be optionally set to define after
which time (in milliseconds) inactive streams are reclaimed.
|
static ConfigOption<Long> |
CoreOptions.fileSystemConnectionLimitTimeout(String scheme)
If any connection limit is configured, this option can be optionally set to define after
which time (in milliseconds) stream opening fails with a timeout exception, if no stream
connection becomes available.
|
ConfigOption<String> |
ConfigOptions.OptionBuilder.noDefaultValue()
Deprecated.
define the type explicitly first with one of the intType(), stringType(),
etc.
|
ConfigOption<T> |
ConfigOptions.TypedConfigOptionBuilder.noDefaultValue()
Creates a ConfigOption without a default value.
|
ConfigOption<List<E>> |
ConfigOptions.ListConfigOptionBuilder.noDefaultValue()
Creates a ConfigOption without a default value.
|
ConfigOption<T> |
ConfigOption.withDeprecatedKeys(String... deprecatedKeys)
Creates a new config option, using this option's key and default value, and adding the given
deprecated keys.
|
ConfigOption<T> |
ConfigOption.withDescription(Description description)
Creates a new config option, using this option's key and default value, and adding the given
description.
|
ConfigOption<T> |
ConfigOption.withDescription(String description)
Creates a new config option, using this option's key and default value, and adding the given
description.
|
ConfigOption<T> |
ConfigOption.withFallbackKeys(String... fallbackKeys)
Creates a new config option, using this option's key and default value, and adding the given
fallback keys.
|
Modifier and Type | Method and Description |
---|---|
static Set<ConfigOption<?>> |
ConfigUtils.getAllConfigOptions(Class<?> configOptionsClass) |
Modifier and Type | Method and Description |
---|---|
static boolean |
ConfigurationUtils.canBePrefixMap(ConfigOption<?> configOption)
Maps can be represented in two ways.
|
boolean |
DelegatingConfiguration.contains(ConfigOption<?> configOption) |
boolean |
Configuration.contains(ConfigOption<?> configOption)
Checks whether there is an entry for the given config option.
|
static <IN,OUT,E extends Throwable> |
ConfigUtils.decodeListFromConfig(ReadableConfig configuration,
ConfigOption<List<IN>> key,
FunctionWithException<IN,OUT,E> mapper)
Gets a
List of values of type IN from a ReadableConfig and transforms
it to a List of type OUT based on the provided mapper function. |
static <IN,OUT> void |
ConfigUtils.encodeArrayToConfig(WritableConfig configuration,
ConfigOption<List<OUT>> key,
IN[] values,
java.util.function.Function<IN,OUT> mapper)
|
static <IN,OUT> void |
ConfigUtils.encodeCollectionToConfig(WritableConfig configuration,
ConfigOption<List<OUT>> key,
Collection<IN> values,
java.util.function.Function<IN,OUT> mapper)
Puts a
Collection of values of type IN in a WritableConfig as a
ConfigOption of type List of type OUT . |
<T> T |
ReadableConfig.get(ConfigOption<T> option)
Reads a value using the metadata included in
ConfigOption . |
<T> T |
DelegatingConfiguration.get(ConfigOption<T> option) |
<T> T |
Configuration.get(ConfigOption<T> option) |
boolean |
DelegatingConfiguration.getBoolean(ConfigOption<Boolean> configOption) |
boolean |
Configuration.getBoolean(ConfigOption<Boolean> configOption)
Returns the value associated with the given config option as a boolean.
|
boolean |
DelegatingConfiguration.getBoolean(ConfigOption<Boolean> configOption,
boolean overrideDefault) |
boolean |
Configuration.getBoolean(ConfigOption<Boolean> configOption,
boolean overrideDefault)
Returns the value associated with the given config option as a boolean.
|
double |
DelegatingConfiguration.getDouble(ConfigOption<Double> configOption) |
double |
Configuration.getDouble(ConfigOption<Double> configOption)
Returns the value associated with the given config option as a
double . |
double |
DelegatingConfiguration.getDouble(ConfigOption<Double> configOption,
double overrideDefault) |
double |
Configuration.getDouble(ConfigOption<Double> configOption,
double overrideDefault)
Returns the value associated with the given config option as a
double . |
<T extends Enum<T>> |
DelegatingConfiguration.getEnum(Class<T> enumClass,
ConfigOption<String> configOption) |
<T extends Enum<T>> |
Configuration.getEnum(Class<T> enumClass,
ConfigOption<String> configOption)
Returns the value associated with the given config option as an enum.
|
float |
DelegatingConfiguration.getFloat(ConfigOption<Float> configOption) |
float |
Configuration.getFloat(ConfigOption<Float> configOption)
Returns the value associated with the given config option as a float.
|
float |
DelegatingConfiguration.getFloat(ConfigOption<Float> configOption,
float overrideDefault) |
float |
Configuration.getFloat(ConfigOption<Float> configOption,
float overrideDefault)
Returns the value associated with the given config option as a float.
|
int |
DelegatingConfiguration.getInteger(ConfigOption<Integer> configOption) |
int |
Configuration.getInteger(ConfigOption<Integer> configOption)
Returns the value associated with the given config option as an integer.
|
int |
DelegatingConfiguration.getInteger(ConfigOption<Integer> configOption,
int overrideDefault) |
int |
Configuration.getInteger(ConfigOption<Integer> configOption,
int overrideDefault)
Returns the value associated with the given config option as an integer.
|
long |
DelegatingConfiguration.getLong(ConfigOption<Long> configOption) |
long |
Configuration.getLong(ConfigOption<Long> configOption)
Returns the value associated with the given config option as a long integer.
|
long |
DelegatingConfiguration.getLong(ConfigOption<Long> configOption,
long overrideDefault) |
long |
Configuration.getLong(ConfigOption<Long> configOption,
long overrideDefault)
Returns the value associated with the given config option as a long integer.
|
<T> Optional<T> |
ReadableConfig.getOptional(ConfigOption<T> option)
Reads a value using the metadata included in
ConfigOption . |
<T> Optional<T> |
DelegatingConfiguration.getOptional(ConfigOption<T> option) |
<T> Optional<T> |
Configuration.getOptional(ConfigOption<T> option) |
String |
DelegatingConfiguration.getString(ConfigOption<String> configOption) |
String |
Configuration.getString(ConfigOption<String> configOption)
Returns the value associated with the given config option as a string.
|
String |
DelegatingConfiguration.getString(ConfigOption<String> configOption,
String overrideDefault) |
String |
Configuration.getString(ConfigOption<String> configOption,
String overrideDefault)
Returns the value associated with the given config option as a string.
|
String |
DelegatingConfiguration.getValue(ConfigOption<?> configOption) |
String |
Configuration.getValue(ConfigOption<?> configOption)
Returns the value associated with the given config option as a string.
|
<T> boolean |
UnmodifiableConfiguration.removeConfig(ConfigOption<T> configOption) |
<T> boolean |
DelegatingConfiguration.removeConfig(ConfigOption<T> configOption) |
<T> boolean |
Configuration.removeConfig(ConfigOption<T> configOption)
Removes given config option from the configuration.
|
<T> WritableConfig |
WritableConfig.set(ConfigOption<T> option,
T value)
Stores a given value using the metadata included in the
ConfigOption . |
<T> Configuration |
DelegatingConfiguration.set(ConfigOption<T> option,
T value) |
<T> Configuration |
Configuration.set(ConfigOption<T> option,
T value) |
void |
DelegatingConfiguration.setBoolean(ConfigOption<Boolean> key,
boolean value) |
void |
Configuration.setBoolean(ConfigOption<Boolean> key,
boolean value)
Adds the given value to the configuration object.
|
void |
DelegatingConfiguration.setDouble(ConfigOption<Double> key,
double value) |
void |
Configuration.setDouble(ConfigOption<Double> key,
double value)
Adds the given value to the configuration object.
|
void |
DelegatingConfiguration.setFloat(ConfigOption<Float> key,
float value) |
void |
Configuration.setFloat(ConfigOption<Float> key,
float value)
Adds the given value to the configuration object.
|
void |
DelegatingConfiguration.setInteger(ConfigOption<Integer> key,
int value) |
void |
Configuration.setInteger(ConfigOption<Integer> key,
int value)
Adds the given value to the configuration object.
|
void |
DelegatingConfiguration.setLong(ConfigOption<Long> key,
long value) |
void |
Configuration.setLong(ConfigOption<Long> key,
long value)
Adds the given value to the configuration object.
|
void |
DelegatingConfiguration.setString(ConfigOption<String> key,
String value) |
void |
Configuration.setString(ConfigOption<String> key,
String value)
Adds the given value to the configuration object.
|
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Integer> |
SourceReaderOptions.ELEMENT_QUEUE_CAPACITY |
static ConfigOption<Long> |
SourceReaderOptions.SOURCE_READER_CLOSE_TIMEOUT |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Long> |
AsyncSinkConnectorOptions.FLUSH_BUFFER_SIZE |
static ConfigOption<Long> |
AsyncSinkConnectorOptions.FLUSH_BUFFER_TIMEOUT |
static ConfigOption<Integer> |
AsyncSinkConnectorOptions.MAX_BATCH_SIZE |
static ConfigOption<Integer> |
AsyncSinkConnectorOptions.MAX_BUFFERED_REQUESTS |
static ConfigOption<Integer> |
AsyncSinkConnectorOptions.MAX_IN_FLIGHT_REQUESTS |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
AsyncDynamicTableSinkFactory.optionalOptions() |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
BlackHoleTableSinkFactory.optionalOptions() |
Set<ConfigOption<?>> |
BlackHoleTableSinkFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
DataGenConnectorOptions.FIELD_END
Placeholder
ConfigOption . |
static ConfigOption<String> |
DataGenConnectorOptions.FIELD_KIND
Placeholder
ConfigOption . |
static ConfigOption<Integer> |
DataGenConnectorOptions.FIELD_LENGTH
Placeholder
ConfigOption . |
static ConfigOption<String> |
DataGenConnectorOptions.FIELD_MAX
Placeholder
ConfigOption . |
static ConfigOption<java.time.Duration> |
DataGenConnectorOptions.FIELD_MAX_PAST
Placeholder
ConfigOption . |
static ConfigOption<String> |
DataGenConnectorOptions.FIELD_MIN
Placeholder
ConfigOption . |
static ConfigOption<String> |
DataGenConnectorOptions.FIELD_START
Placeholder
ConfigOption . |
static ConfigOption<Long> |
DataGenConnectorOptions.NUMBER_OF_ROWS |
static ConfigOption<Long> |
DataGenConnectorOptions.ROWS_PER_SECOND |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
DataGeneratorContainer.getOptions() |
Set<ConfigOption<?>> |
DataGenTableSourceFactory.optionalOptions() |
Set<ConfigOption<?>> |
DataGenTableSourceFactory.requiredOptions() |
Modifier and Type | Method and Description |
---|---|
static DataGeneratorContainer |
DataGeneratorContainer.of(DataGenerator generator,
ConfigOption<?>... options) |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<java.time.Duration> |
ElasticsearchConnectorOptions.BULK_FLUSH_BACKOFF_DELAY_OPTION |
static ConfigOption<Integer> |
ElasticsearchConnectorOptions.BULK_FLUSH_BACKOFF_MAX_RETRIES_OPTION |
static ConfigOption<FlushBackoffType> |
ElasticsearchConnectorOptions.BULK_FLUSH_BACKOFF_TYPE_OPTION |
static ConfigOption<java.time.Duration> |
ElasticsearchConnectorOptions.BULK_FLUSH_INTERVAL_OPTION |
static ConfigOption<Integer> |
ElasticsearchConnectorOptions.BULK_FLUSH_MAX_ACTIONS_OPTION |
static ConfigOption<MemorySize> |
ElasticsearchConnectorOptions.BULK_FLUSH_MAX_SIZE_OPTION |
static ConfigOption<String> |
ElasticsearchConnectorOptions.CONNECTION_PATH_PREFIX_OPTION |
static ConfigOption<java.time.Duration> |
ElasticsearchConnectorOptions.CONNECTION_REQUEST_TIMEOUT |
static ConfigOption<java.time.Duration> |
ElasticsearchConnectorOptions.CONNECTION_TIMEOUT |
static ConfigOption<DeliveryGuarantee> |
ElasticsearchConnectorOptions.DELIVERY_GUARANTEE_OPTION |
static ConfigOption<String> |
Elasticsearch6ConnectorOptions.DOCUMENT_TYPE_OPTION |
static ConfigOption<String> |
ElasticsearchConnectorOptions.FORMAT_OPTION |
static ConfigOption<List<String>> |
ElasticsearchConnectorOptions.HOSTS_OPTION |
static ConfigOption<String> |
ElasticsearchConnectorOptions.INDEX_OPTION |
static ConfigOption<String> |
ElasticsearchConnectorOptions.KEY_DELIMITER_OPTION |
static ConfigOption<String> |
ElasticsearchConnectorOptions.PASSWORD_OPTION |
static ConfigOption<java.time.Duration> |
ElasticsearchConnectorOptions.SOCKET_TIMEOUT |
static ConfigOption<String> |
ElasticsearchConnectorOptions.USERNAME_OPTION |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
Elasticsearch6DynamicSinkFactory.forwardOptions() |
Set<ConfigOption<?>> |
Elasticsearch6DynamicSinkFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<MemorySize> |
StreamFormat.FETCH_IO_SIZE
The config option to define how many bytes to be read by the I/O thread in one fetch
operation.
|
static ConfigOption<Integer> |
FileRecordFormat.RECORDS_PER_FETCH
Deprecated.
Config option for the number of records to hand over in each fetch.
|
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
FileSystemTableFactory.forwardOptions() |
Set<ConfigOption<?>> |
FileSystemTableFactory.optionalOptions() |
Set<ConfigOption<?>> |
FileSystemTableFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
KinesisFirehoseConnectorOptions.DELIVERY_STREAM |
static ConfigOption<Boolean> |
KinesisFirehoseConnectorOptions.SINK_FAIL_ON_ERROR |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
KinesisFirehoseDynamicTableFactory.optionalOptions() |
Set<ConfigOption<?>> |
KinesisFirehoseDynamicTableFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Boolean> |
HBaseConnectorOptions.LOOKUP_ASYNC |
static ConfigOption<Long> |
HBaseConnectorOptions.LOOKUP_CACHE_MAX_ROWS |
static ConfigOption<java.time.Duration> |
HBaseConnectorOptions.LOOKUP_CACHE_TTL |
static ConfigOption<Integer> |
HBaseConnectorOptions.LOOKUP_MAX_RETRIES |
static ConfigOption<String> |
HBaseConnectorOptions.NULL_STRING_LITERAL |
static ConfigOption<java.time.Duration> |
HBaseConnectorOptions.SINK_BUFFER_FLUSH_INTERVAL |
static ConfigOption<Integer> |
HBaseConnectorOptions.SINK_BUFFER_FLUSH_MAX_ROWS |
static ConfigOption<MemorySize> |
HBaseConnectorOptions.SINK_BUFFER_FLUSH_MAX_SIZE |
static ConfigOption<Integer> |
HBaseConnectorOptions.SINK_PARALLELISM |
static ConfigOption<String> |
HBaseConnectorOptions.TABLE_NAME |
static ConfigOption<String> |
HBaseConnectorOptions.ZOOKEEPER_QUORUM |
static ConfigOption<String> |
HBaseConnectorOptions.ZOOKEEPER_ZNODE_PARENT |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
HBase1DynamicTableFactory.forwardOptions() |
Set<ConfigOption<?>> |
HBase1DynamicTableFactory.optionalOptions() |
Set<ConfigOption<?>> |
HBase1DynamicTableFactory.requiredOptions() |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
HBase2DynamicTableFactory.forwardOptions() |
Set<ConfigOption<?>> |
HBase2DynamicTableFactory.optionalOptions() |
Set<ConfigOption<?>> |
HBase2DynamicTableFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
JdbcCatalogFactoryOptions.BASE_URL |
static ConfigOption<String> |
JdbcCatalogFactoryOptions.DEFAULT_DATABASE |
static ConfigOption<String> |
JdbcCatalogFactoryOptions.PASSWORD |
static ConfigOption<String> |
JdbcCatalogFactoryOptions.USERNAME |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
JdbcCatalogFactory.optionalOptions() |
Set<ConfigOption<?>> |
JdbcCatalogFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
JdbcConnectorOptions.DRIVER |
static ConfigOption<Long> |
JdbcConnectorOptions.LOOKUP_CACHE_MAX_ROWS |
static ConfigOption<Boolean> |
JdbcConnectorOptions.LOOKUP_CACHE_MISSING_KEY |
static ConfigOption<java.time.Duration> |
JdbcConnectorOptions.LOOKUP_CACHE_TTL |
static ConfigOption<Integer> |
JdbcConnectorOptions.LOOKUP_MAX_RETRIES |
static ConfigOption<java.time.Duration> |
JdbcConnectorOptions.MAX_RETRY_TIMEOUT |
static ConfigOption<String> |
JdbcConnectorOptions.PASSWORD |
static ConfigOption<Boolean> |
JdbcConnectorOptions.SCAN_AUTO_COMMIT |
static ConfigOption<Integer> |
JdbcConnectorOptions.SCAN_FETCH_SIZE |
static ConfigOption<String> |
JdbcConnectorOptions.SCAN_PARTITION_COLUMN |
static ConfigOption<Long> |
JdbcConnectorOptions.SCAN_PARTITION_LOWER_BOUND |
static ConfigOption<Integer> |
JdbcConnectorOptions.SCAN_PARTITION_NUM |
static ConfigOption<Long> |
JdbcConnectorOptions.SCAN_PARTITION_UPPER_BOUND |
static ConfigOption<java.time.Duration> |
JdbcConnectorOptions.SINK_BUFFER_FLUSH_INTERVAL |
static ConfigOption<Integer> |
JdbcConnectorOptions.SINK_BUFFER_FLUSH_MAX_ROWS |
static ConfigOption<Integer> |
JdbcConnectorOptions.SINK_MAX_RETRIES |
static ConfigOption<Integer> |
JdbcConnectorOptions.SINK_PARALLELISM |
static ConfigOption<String> |
JdbcConnectorOptions.TABLE_NAME |
static ConfigOption<String> |
JdbcConnectorOptions.URL |
static ConfigOption<String> |
JdbcConnectorOptions.USERNAME |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
JdbcDynamicTableFactory.forwardOptions() |
Set<ConfigOption<?>> |
JdbcDynamicTableFactory.optionalOptions() |
Set<ConfigOption<?>> |
JdbcDynamicTableFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
KafkaSourceOptions.CLIENT_ID_PREFIX |
static ConfigOption<Boolean> |
KafkaSourceOptions.COMMIT_OFFSETS_ON_CHECKPOINT |
static ConfigOption<Long> |
KafkaSourceOptions.PARTITION_DISCOVERY_INTERVAL_MS |
static ConfigOption<Boolean> |
KafkaSourceOptions.REGISTER_KAFKA_CONSUMER_METRICS |
Modifier and Type | Method and Description |
---|---|
static <T> T |
KafkaSourceOptions.getOption(Properties props,
ConfigOption<?> configOption,
java.util.function.Function<String,T> parser) |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
KinesisConnectorOptions.AWS_REGION |
static ConfigOption<Boolean> |
KinesisConnectorOptions.SINK_FAIL_ON_ERROR |
static ConfigOption<String> |
KinesisConnectorOptions.SINK_PARTITIONER |
static ConfigOption<String> |
KinesisConnectorOptions.SINK_PARTITIONER_FIELD_DELIMITER |
static ConfigOption<String> |
KinesisConnectorOptions.STREAM |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
KinesisDynamicTableSinkFactory.optionalOptions() |
Set<ConfigOption<?>> |
KinesisDynamicTableSinkFactory.requiredOptions() |
Modifier and Type | Method and Description |
---|---|
static Set<ConfigOption<?>> |
KinesisStreamsConnectorOptionsUtils.KinesisProducerOptionsMapper.addDeprecatedKeys(Set<ConfigOption<?>> tableOptions) |
Modifier and Type | Method and Description |
---|---|
static Set<ConfigOption<?>> |
KinesisStreamsConnectorOptionsUtils.KinesisProducerOptionsMapper.addDeprecatedKeys(Set<ConfigOption<?>> tableOptions) |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
PrintConnectorOptions.PRINT_IDENTIFIER |
static ConfigOption<Boolean> |
PrintConnectorOptions.STANDARD_ERROR |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
PrintTableSinkFactory.optionalOptions() |
Set<ConfigOption<?>> |
PrintTableSinkFactory.requiredOptions() |
Modifier and Type | Method and Description |
---|---|
PulsarConfigValidator.PulsarConfigValidatorBuilder |
PulsarConfigValidator.PulsarConfigValidatorBuilder.conflictOptions(ConfigOption<?>... options) |
<T> boolean |
PulsarConfigBuilder.contains(ConfigOption<T> option)
Validate if the config has a existed option.
|
<F,T> T |
PulsarConfiguration.get(ConfigOption<F> option,
java.util.function.Function<F,T> convertor)
Get an option value from the given config, convert it into a new value instance.
|
<T> T |
PulsarConfigBuilder.get(ConfigOption<T> key)
Get an option-related config value.
|
Map<String,String> |
PulsarConfiguration.getProperties(ConfigOption<Map<String,String>> option)
Get the option value by a prefix.
|
<T> void |
PulsarConfigBuilder.override(ConfigOption<T> option,
T value)
Override the option with the given value.
|
PulsarConfigValidator.PulsarConfigValidatorBuilder |
PulsarConfigValidator.PulsarConfigValidatorBuilder.requiredOption(ConfigOption<?> option) |
<T> void |
PulsarConfigBuilder.set(ConfigOption<T> option,
T value)
Add a config option with a not null value.
|
<T> void |
PulsarConfiguration.useOption(ConfigOption<T> option,
java.util.function.Consumer<T> setter)
Set the config option's value to a given builder.
|
<T,V> void |
PulsarConfiguration.useOption(ConfigOption<T> option,
java.util.function.Function<T,V> convertor,
java.util.function.Consumer<V> setter)
Query the config option's value, convert it into a required type, set it to a given builder.
|
Modifier and Type | Method and Description |
---|---|
<T> PulsarSinkBuilder<IN> |
PulsarSinkBuilder.setConfig(ConfigOption<T> key,
T value)
Set an arbitrary property for the PulsarSink and Pulsar Producer.
|
Modifier and Type | Method and Description |
---|---|
<T> PulsarSourceBuilder<OUT> |
PulsarSourceBuilder.setConfig(ConfigOption<T> key,
T value)
Set an arbitrary property for the PulsarSource and Pulsar Consumer.
|
Modifier and Type | Field and Description |
---|---|
static ConfigOption<java.time.Duration> |
HiveOptions.LOOKUP_JOIN_CACHE_TTL |
static ConfigOption<String> |
HiveOptions.STREAMING_SOURCE_CONSUME_START_OFFSET |
static ConfigOption<Boolean> |
HiveOptions.STREAMING_SOURCE_ENABLE |
static ConfigOption<java.time.Duration> |
HiveOptions.STREAMING_SOURCE_MONITOR_INTERVAL |
static ConfigOption<String> |
HiveOptions.STREAMING_SOURCE_PARTITION_INCLUDE |
static ConfigOption<HiveOptions.PartitionOrder> |
HiveOptions.STREAMING_SOURCE_PARTITION_ORDER |
static ConfigOption<Boolean> |
HiveOptions.TABLE_EXEC_HIVE_FALLBACK_MAPRED_READER |
static ConfigOption<Boolean> |
HiveOptions.TABLE_EXEC_HIVE_FALLBACK_MAPRED_WRITER |
static ConfigOption<Boolean> |
HiveOptions.TABLE_EXEC_HIVE_INFER_SOURCE_PARALLELISM |
static ConfigOption<Integer> |
HiveOptions.TABLE_EXEC_HIVE_INFER_SOURCE_PARALLELISM_MAX |
static ConfigOption<Integer> |
HiveOptions.TABLE_EXEC_HIVE_LOAD_PARTITION_SPLITS_THREAD_NUM |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
HiveDynamicTableFactory.optionalOptions() |
Set<ConfigOption<?>> |
HiveDynamicTableFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.BLOCK_CACHE_CAPACITY |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.BLOCK_CACHE_PINNED_USAGE |
static ConfigOption<MemorySize> |
RocksDBConfigurableOptions.BLOCK_CACHE_SIZE |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.BLOCK_CACHE_USAGE |
static ConfigOption<MemorySize> |
RocksDBConfigurableOptions.BLOCK_SIZE |
static ConfigOption<Double> |
RocksDBConfigurableOptions.BLOOM_FILTER_BITS_PER_KEY |
static ConfigOption<Boolean> |
RocksDBConfigurableOptions.BLOOM_FILTER_BLOCK_BASED_MODE |
static ConfigOption<Integer> |
RocksDBOptions.CHECKPOINT_TRANSFER_THREAD_NUM
The number of threads used to transfer (download and upload) files in RocksDBStateBackend.
|
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.COLUMN_FAMILY_AS_VARIABLE |
static ConfigOption<org.rocksdb.CompactionStyle> |
RocksDBConfigurableOptions.COMPACTION_STYLE |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.ESTIMATE_LIVE_DATA_SIZE |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.ESTIMATE_NUM_KEYS |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.ESTIMATE_PENDING_COMPACTION_BYTES |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.ESTIMATE_TABLE_READERS_MEM |
static ConfigOption<MemorySize> |
RocksDBOptions.FIX_PER_SLOT_MEMORY_SIZE |
static ConfigOption<Double> |
RocksDBOptions.HIGH_PRIORITY_POOL_RATIO |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.IS_WRITE_STOPPED |
static ConfigOption<String> |
RocksDBOptions.LOCAL_DIRECTORIES
The local directory (on the TaskManager) where RocksDB puts its files.
|
static ConfigOption<String> |
RocksDBConfigurableOptions.LOG_DIR |
static ConfigOption<Integer> |
RocksDBConfigurableOptions.LOG_FILE_NUM |
static ConfigOption<org.rocksdb.InfoLogLevel> |
RocksDBConfigurableOptions.LOG_LEVEL |
static ConfigOption<MemorySize> |
RocksDBConfigurableOptions.LOG_MAX_FILE_SIZE |
static ConfigOption<Integer> |
RocksDBConfigurableOptions.MAX_BACKGROUND_THREADS |
static ConfigOption<Integer> |
RocksDBConfigurableOptions.MAX_OPEN_FILES |
static ConfigOption<MemorySize> |
RocksDBConfigurableOptions.MAX_SIZE_LEVEL_BASE |
static ConfigOption<Integer> |
RocksDBConfigurableOptions.MAX_WRITE_BUFFER_NUMBER |
static ConfigOption<MemorySize> |
RocksDBConfigurableOptions.METADATA_BLOCK_SIZE |
static ConfigOption<Integer> |
RocksDBConfigurableOptions.MIN_WRITE_BUFFER_NUMBER_TO_MERGE |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_ACTUAL_DELAYED_WRITE_RATE |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_BACKGROUND_ERRORS |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_CUR_SIZE_ACTIVE_MEM_TABLE |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_CUR_SIZE_ALL_MEM_TABLE |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_LIVE_SST_FILES_SIZE |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_MEM_TABLE_FLUSH_PENDING |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_NUM_DELETES_ACTIVE_MEM_TABLE |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_NUM_DELETES_IMM_MEM_TABLE |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_NUM_ENTRIES_ACTIVE_MEM_TABLE |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_NUM_ENTRIES_IMM_MEM_TABLES |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_NUM_IMMUTABLE_MEM_TABLES |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_NUM_LIVE_VERSIONS |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_NUM_RUNNING_COMPACTIONS |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_NUM_RUNNING_FLUSHES |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_NUM_SNAPSHOTS |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_SIZE_ALL_MEM_TABLES |
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.MONITOR_TOTAL_SST_FILES_SIZE |
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<MemorySize> |
RocksDBConfigurableOptions.TARGET_FILE_SIZE_BASE |
static ConfigOption<EmbeddedRocksDBStateBackend.PriorityQueueStateType> |
RocksDBOptions.TIMER_SERVICE_FACTORY
Choice of timer service implementation.
|
static ConfigOption<Boolean> |
RocksDBNativeMetricOptions.TRACK_COMPACTION_PENDING |
static ConfigOption<Boolean> |
RocksDBConfigurableOptions.USE_BLOOM_FILTER |
static ConfigOption<Boolean> |
RocksDBConfigurableOptions.USE_DYNAMIC_LEVEL_SIZE |
static ConfigOption<Boolean> |
RocksDBOptions.USE_MANAGED_MEMORY |
static ConfigOption<Boolean> |
RocksDBOptions.USE_PARTITIONED_INDEX_FILTERS |
static ConfigOption<MemorySize> |
RocksDBConfigurableOptions.WRITE_BATCH_SIZE |
static ConfigOption<Double> |
RocksDBOptions.WRITE_BUFFER_RATIO |
static ConfigOption<MemorySize> |
RocksDBConfigurableOptions.WRITE_BUFFER_SIZE |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
AvroFormatOptions.AVRO_OUTPUT_CODEC |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
AvroFileFormatFactory.forwardOptions() |
Set<ConfigOption<?>> |
AvroFileFormatFactory.optionalOptions() |
Set<ConfigOption<?>> |
AvroFormatFactory.optionalOptions() |
Set<ConfigOption<?>> |
AvroFileFormatFactory.requiredOptions() |
Set<ConfigOption<?>> |
AvroFormatFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
AvroConfluentFormatOptions.BASIC_AUTH_CREDENTIALS_SOURCE |
static ConfigOption<String> |
AvroConfluentFormatOptions.BASIC_AUTH_USER_INFO |
static ConfigOption<String> |
AvroConfluentFormatOptions.BEARER_AUTH_CREDENTIALS_SOURCE |
static ConfigOption<String> |
AvroConfluentFormatOptions.BEARER_AUTH_TOKEN |
static ConfigOption<Map<String,String>> |
AvroConfluentFormatOptions.PROPERTIES |
static ConfigOption<String> |
AvroConfluentFormatOptions.SSL_KEYSTORE_LOCATION |
static ConfigOption<String> |
AvroConfluentFormatOptions.SSL_KEYSTORE_PASSWORD |
static ConfigOption<String> |
AvroConfluentFormatOptions.SSL_TRUSTSTORE_LOCATION |
static ConfigOption<String> |
AvroConfluentFormatOptions.SSL_TRUSTSTORE_PASSWORD |
static ConfigOption<String> |
AvroConfluentFormatOptions.SUBJECT |
static ConfigOption<String> |
AvroConfluentFormatOptions.URL |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
RegistryAvroFormatFactory.forwardOptions() |
Set<ConfigOption<?>> |
RegistryAvroFormatFactory.optionalOptions() |
Set<ConfigOption<?>> |
RegistryAvroFormatFactory.requiredOptions() |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
DebeziumAvroFormatFactory.optionalOptions() |
Set<ConfigOption<?>> |
DebeziumAvroFormatFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Boolean> |
CsvFormatOptions.ALLOW_COMMENTS |
static ConfigOption<String> |
CsvFormatOptions.ARRAY_ELEMENT_DELIMITER |
static ConfigOption<Boolean> |
CsvFormatOptions.DISABLE_QUOTE_CHARACTER |
static ConfigOption<String> |
CsvFormatOptions.ESCAPE_CHARACTER |
static ConfigOption<String> |
CsvFormatOptions.FIELD_DELIMITER |
static ConfigOption<Boolean> |
CsvFormatOptions.IGNORE_PARSE_ERRORS |
static ConfigOption<String> |
CsvFormatOptions.NULL_LITERAL |
static ConfigOption<String> |
CsvFormatOptions.QUOTE_CHARACTER |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
CsvFileFormatFactory.forwardOptions() |
Set<ConfigOption<?>> |
CsvFormatFactory.forwardOptions() |
Set<ConfigOption<?>> |
CsvFileFormatFactory.optionalOptions() |
Set<ConfigOption<?>> |
CsvFormatFactory.optionalOptions() |
Set<ConfigOption<?>> |
CsvFileFormatFactory.requiredOptions() |
Set<ConfigOption<?>> |
CsvFormatFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Boolean> |
JsonFormatOptions.ENCODE_DECIMAL_AS_PLAIN_NUMBER |
static ConfigOption<Boolean> |
JsonFormatOptions.FAIL_ON_MISSING_FIELD |
static ConfigOption<Boolean> |
JsonFormatOptions.IGNORE_PARSE_ERRORS |
static ConfigOption<String> |
JsonFormatOptions.MAP_NULL_KEY_LITERAL |
static ConfigOption<String> |
JsonFormatOptions.MAP_NULL_KEY_MODE |
static ConfigOption<String> |
JsonFormatOptions.TIMESTAMP_FORMAT |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
JsonFormatFactory.forwardOptions() |
Set<ConfigOption<?>> |
JsonFormatFactory.optionalOptions() |
Set<ConfigOption<?>> |
JsonFormatFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
CanalJsonFormatOptions.DATABASE_INCLUDE |
static ConfigOption<Boolean> |
CanalJsonFormatOptions.IGNORE_PARSE_ERRORS |
static ConfigOption<String> |
CanalJsonFormatOptions.JSON_MAP_NULL_KEY_LITERAL |
static ConfigOption<String> |
CanalJsonFormatOptions.JSON_MAP_NULL_KEY_MODE |
static ConfigOption<String> |
CanalJsonFormatOptions.TABLE_INCLUDE |
static ConfigOption<String> |
CanalJsonFormatOptions.TIMESTAMP_FORMAT |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
CanalJsonFormatFactory.optionalOptions() |
Set<ConfigOption<?>> |
CanalJsonFormatFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Boolean> |
DebeziumJsonFormatOptions.IGNORE_PARSE_ERRORS |
static ConfigOption<String> |
DebeziumJsonFormatOptions.JSON_MAP_NULL_KEY_LITERAL |
static ConfigOption<String> |
DebeziumJsonFormatOptions.JSON_MAP_NULL_KEY_MODE |
static ConfigOption<Boolean> |
DebeziumJsonFormatOptions.SCHEMA_INCLUDE |
static ConfigOption<String> |
DebeziumJsonFormatOptions.TIMESTAMP_FORMAT |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
DebeziumJsonFormatFactory.optionalOptions() |
Set<ConfigOption<?>> |
DebeziumJsonFormatFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Boolean> |
MaxwellJsonFormatOptions.IGNORE_PARSE_ERRORS |
static ConfigOption<String> |
MaxwellJsonFormatOptions.JSON_MAP_NULL_KEY_LITERAL |
static ConfigOption<String> |
MaxwellJsonFormatOptions.JSON_MAP_NULL_KEY_MODE |
static ConfigOption<String> |
MaxwellJsonFormatOptions.TIMESTAMP_FORMAT |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
MaxwellJsonFormatFactory.optionalOptions() |
Set<ConfigOption<?>> |
MaxwellJsonFormatFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Boolean> |
OggJsonFormatOptions.IGNORE_PARSE_ERRORS |
static ConfigOption<String> |
OggJsonFormatOptions.JSON_MAP_NULL_KEY_LITERAL |
static ConfigOption<String> |
OggJsonFormatOptions.JSON_MAP_NULL_KEY_MODE |
static ConfigOption<String> |
OggJsonFormatOptions.TIMESTAMP_FORMAT |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
OggJsonFormatFactory.optionalOptions() |
Set<ConfigOption<?>> |
OggJsonFormatFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Boolean> |
ParquetFileFormatFactory.UTC_TIMEZONE |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
ParquetFileFormatFactory.optionalOptions() |
Set<ConfigOption<?>> |
ParquetFileFormatFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
RawFormatOptions.CHARSET |
static ConfigOption<String> |
RawFormatOptions.ENDIANNESS |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
RawFormatFactory.optionalOptions() |
Set<ConfigOption<?>> |
RawFormatFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<MemorySize> |
GSFileSystemOptions.WRITER_CHUNK_SIZE |
static ConfigOption<String> |
GSFileSystemOptions.WRITER_TEMPORARY_BUCKET_NAME |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
AbstractS3FileSystemFactory.ENTROPY_INJECT_KEY_OPTION
The substring to be replaced by random entropy in checkpoint paths.
|
static ConfigOption<Integer> |
AbstractS3FileSystemFactory.ENTROPY_INJECT_LENGTH_OPTION
The number of entropy characters, in case entropy injection is configured.
|
static ConfigOption<Integer> |
AbstractS3FileSystemFactory.MAX_CONCURRENT_UPLOADS |
static ConfigOption<Long> |
AbstractS3FileSystemFactory.PART_UPLOAD_MIN_SIZE |
Modifier and Type | Method and Description |
---|---|
static void |
KubernetesUtils.checkAndUpdatePortConfigOption(Configuration flinkConfig,
ConfigOption<String> port,
int fallbackPort)
Check whether the port config option is a fixed port.
|
static Integer |
KubernetesUtils.parsePort(Configuration flinkConfig,
ConfigOption<String> port)
Parse a valid port for the config option.
|
static <T> String |
KubernetesUtils.resolveUserDefinedValue(Configuration flinkConfig,
ConfigOption<T> configOption,
String valueOfConfigOptionOrDefault,
String valueOfPodTemplate,
String fieldDescription)
Resolve the user defined value with the precedence.
|
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Integer> |
InfluxdbReporterOptions.CONNECT_TIMEOUT |
static ConfigOption<org.influxdb.InfluxDB.ConsistencyLevel> |
InfluxdbReporterOptions.CONSISTENCY |
static ConfigOption<String> |
InfluxdbReporterOptions.DB |
static ConfigOption<String> |
InfluxdbReporterOptions.HOST |
static ConfigOption<String> |
InfluxdbReporterOptions.PASSWORD |
static ConfigOption<Integer> |
InfluxdbReporterOptions.PORT |
static ConfigOption<String> |
InfluxdbReporterOptions.RETENTION_POLICY |
static ConfigOption<org.apache.flink.metrics.influxdb.InfluxdbReporterOptions.Scheme> |
InfluxdbReporterOptions.SCHEME |
static ConfigOption<String> |
InfluxdbReporterOptions.USERNAME |
static ConfigOption<Integer> |
InfluxdbReporterOptions.WRITE_TIMEOUT |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Boolean> |
PrometheusPushGatewayReporterOptions.DELETE_ON_SHUTDOWN |
static ConfigOption<Boolean> |
PrometheusPushGatewayReporterOptions.FILTER_LABEL_VALUE_CHARACTER |
static ConfigOption<String> |
PrometheusPushGatewayReporterOptions.GROUPING_KEY |
static ConfigOption<String> |
PrometheusPushGatewayReporterOptions.HOST
Deprecated.
|
static ConfigOption<String> |
PrometheusPushGatewayReporterOptions.HOST_URL |
static ConfigOption<String> |
PrometheusPushGatewayReporterOptions.JOB_NAME |
static ConfigOption<Integer> |
PrometheusPushGatewayReporterOptions.PORT
Deprecated.
|
static ConfigOption<Boolean> |
PrometheusPushGatewayReporterOptions.RANDOM_JOB_NAME_SUFFIX |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
OrcFileFormatFactory.optionalOptions() |
Set<ConfigOption<?>> |
OrcFileFormatFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Integer> |
PythonOptions.MAP_STATE_ITERATE_RESPONSE_BATCH_SIZE
The maximum number of entries sent to Python UDF worker per request when iterating a Python
MapState.
|
static ConfigOption<Integer> |
PythonOptions.MAP_STATE_READ_CACHE_SIZE
The maximum number of cached items which read from Java side in a Python MapState.
|
static ConfigOption<Integer> |
PythonOptions.MAP_STATE_WRITE_CACHE_SIZE
The maximum number of write requests cached in a Python MapState.
|
static ConfigOption<Integer> |
PythonOptions.MAX_ARROW_BATCH_SIZE
The maximum number of elements to include in an arrow batch.
|
static ConfigOption<Integer> |
PythonOptions.MAX_BUNDLE_SIZE
The maximum number of elements to include in a bundle.
|
static ConfigOption<Long> |
PythonOptions.MAX_BUNDLE_TIME_MILLS
The maximum time to wait before finalising a bundle (in milliseconds).
|
static ConfigOption<String> |
PythonOptions.PYTHON_ARCHIVES |
static ConfigOption<Map<String,String>> |
PythonOptions.PYTHON_ARCHIVES_DISTRIBUTED_CACHE_INFO |
static ConfigOption<String> |
PythonOptions.PYTHON_CLIENT_EXECUTABLE |
static ConfigOption<String> |
PythonOptions.PYTHON_EXECUTABLE |
static ConfigOption<String> |
PythonOptions.PYTHON_EXECUTION_MODE
Specify the python runtime execution mode.
|
static ConfigOption<String> |
PythonOptions.PYTHON_FILES |
static ConfigOption<Map<String,String>> |
PythonOptions.PYTHON_FILES_DISTRIBUTED_CACHE_INFO |
static ConfigOption<Map<String,String>> |
PythonOptions.PYTHON_JOB_OPTIONS |
static ConfigOption<String> |
PythonOptions.PYTHON_LOOPBACK_SERVER_ADDRESS |
static ConfigOption<Boolean> |
PythonOptions.PYTHON_METRIC_ENABLED
The configuration to enable or disable metric for Python execution.
|
static ConfigOption<Boolean> |
PythonOptions.PYTHON_OPERATOR_CHAINING_ENABLED
The configuration to enable or disable python operator chaining.
|
static ConfigOption<Boolean> |
PythonOptions.PYTHON_PROFILE_ENABLED
The configuration to enable or disable profile for Python execution.
|
static ConfigOption<String> |
PythonOptions.PYTHON_REQUIREMENTS |
static ConfigOption<Map<String,String>> |
PythonOptions.PYTHON_REQUIREMENTS_FILE_DISTRIBUTED_CACHE_INFO |
static ConfigOption<Boolean> |
PythonOptions.PYTHON_SYSTEMENV_ENABLED
The configuration to enable or disable system env for Python execution.
|
static ConfigOption<Integer> |
PythonOptions.STATE_CACHE_SIZE
The maximum number of states cached in a Python UDF worker.
|
static ConfigOption<Boolean> |
PythonOptions.USE_MANAGED_MEMORY
Whether the memory used by the Python framework is managed memory.
|
Modifier and Type | Method and Description |
---|---|
<T> T |
PythonConfig.get(ConfigOption<T> option) |
<T> Optional<T> |
PythonConfig.getOptional(ConfigOption<T> option) |
Modifier and Type | Method and Description |
---|---|
static Configuration |
TaskExecutorProcessUtils.getConfigurationMapLegacyTaskManagerHeapSizeToConfigOption(Configuration configuration,
ConfigOption<MemorySize> configOption) |
static double |
TaskExecutorProcessUtils.getCpuCoresWithFallbackConfigOption(Configuration config,
ConfigOption<Double> fallbackOption) |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
ClusterEntrypoint.INTERNAL_CLUSTER_EXECUTION_MODE |
Modifier and Type | Method and Description |
---|---|
static File |
ClusterEntrypointUtils.generateWorkingDirectoryFile(Configuration configuration,
Optional<ConfigOption<String>> workingDirOption,
String workingDirectoryName)
Generate the working directory from the given configuration.
|
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
FileJobGraphRetriever.JOB_GRAPH_FILE_PATH |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Boolean> |
JobResultStoreOptions.DELETE_ON_COMMIT |
static ConfigOption<String> |
JobResultStoreOptions.STORAGE_PATH |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<RestoreMode> |
SavepointConfigOptions.RESTORE_MODE
Describes the mode how Flink should restore from the given savepoint or retained checkpoint.
|
static ConfigOption<Boolean> |
SavepointConfigOptions.SAVEPOINT_IGNORE_UNCLAIMED_STATE
A flag indicating if we allow Flink to skip savepoint state that cannot be restored, e.g.
|
static ConfigOption<String> |
SavepointConfigOptions.SAVEPOINT_PATH
The path to a savepoint that will be used to bootstrap the pipeline's state.
|
Modifier and Type | Method and Description |
---|---|
static JobManagerProcessSpec |
JobManagerProcessUtils.processSpecFromConfigWithNewOptionToInterpretLegacyHeap(Configuration config,
ConfigOption<MemorySize> newOptionToInterpretLegacyHeap) |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
ShuffleServiceOptions.SHUFFLE_SERVICE_FACTORY_CLASS
The full class name of the shuffle service factory implementation to be used by the cluster.
|
Modifier and Type | Method and Description |
---|---|
Configuration |
MemoryBackwardsCompatibilityUtils.getConfWithLegacyHeapSizeMappedToNewConfigOption(Configuration configuration,
ConfigOption<MemorySize> configOption) |
static MemorySize |
ProcessMemoryUtils.getMemorySizeFromConfig(Configuration config,
ConfigOption<MemorySize> option) |
static RangeFraction |
ProcessMemoryUtils.getRangeFraction(MemorySize minSize,
MemorySize maxSize,
ConfigOption<Float> fractionOption,
Configuration config) |
Constructor and Description |
---|
ProcessMemoryOptions(List<ConfigOption<MemorySize>> requiredFineGrainedOptions,
ConfigOption<MemorySize> totalFlinkMemoryOption,
ConfigOption<MemorySize> totalProcessMemoryOption,
JvmMetaspaceAndOverheadOptions jvmOptions) |
Modifier and Type | Method and Description |
---|---|
<T> SavepointWriter |
SavepointWriter.withConfiguration(ConfigOption<T> option,
T value)
Sets a configuration that will be applied to the stream operators used to bootstrap a new
savepoint.
|
<T> F |
WritableSavepoint.withConfiguration(ConfigOption<T> option,
T value)
Deprecated.
Sets a configuration that will be applied to the stream operators used to bootstrap a new
savepoint.
|
Modifier and Type | Field and Description |
---|---|
static ConfigOption<java.time.Duration> |
ExecutionCheckpointingOptions.ALIGNED_CHECKPOINT_TIMEOUT |
static ConfigOption<java.time.Duration> |
ExecutionCheckpointingOptions.ALIGNMENT_TIMEOUT
Deprecated.
|
static ConfigOption<Long> |
ExecutionCheckpointingOptions.CHECKPOINT_ID_OF_IGNORED_IN_FLIGHT_DATA |
static ConfigOption<java.time.Duration> |
ExecutionCheckpointingOptions.CHECKPOINTING_INTERVAL |
static ConfigOption<CheckpointingMode> |
ExecutionCheckpointingOptions.CHECKPOINTING_MODE |
static ConfigOption<java.time.Duration> |
ExecutionCheckpointingOptions.CHECKPOINTING_TIMEOUT |
static ConfigOption<Boolean> |
ExecutionCheckpointingOptions.ENABLE_CHECKPOINTS_AFTER_TASKS_FINISH |
static ConfigOption<Boolean> |
ExecutionCheckpointingOptions.ENABLE_UNALIGNED |
static ConfigOption<CheckpointConfig.ExternalizedCheckpointCleanup> |
ExecutionCheckpointingOptions.EXTERNALIZED_CHECKPOINT |
static ConfigOption<Boolean> |
ExecutionCheckpointingOptions.FORCE_UNALIGNED |
static ConfigOption<Integer> |
ExecutionCheckpointingOptions.MAX_CONCURRENT_CHECKPOINTS |
static ConfigOption<java.time.Duration> |
ExecutionCheckpointingOptions.MIN_PAUSE_BETWEEN_CHECKPOINTS |
static ConfigOption<TimeCharacteristic> |
StreamPipelineOptions.TIME_CHARACTERISTIC |
static ConfigOption<Integer> |
ExecutionCheckpointingOptions.TOLERABLE_FAILURE_NUMBER |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<MemorySize> |
CollectSinkOperatorFactory.MAX_BATCH_SIZE |
static ConfigOption<java.time.Duration> |
CollectSinkOperatorFactory.SOCKET_TIMEOUT |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<MemorySize> |
ElasticsearchConnectorOptions.BULK_FLASH_MAX_SIZE_OPTION |
static ConfigOption<java.time.Duration> |
ElasticsearchConnectorOptions.BULK_FLUSH_BACKOFF_DELAY_OPTION |
static ConfigOption<Integer> |
ElasticsearchConnectorOptions.BULK_FLUSH_BACKOFF_MAX_RETRIES_OPTION |
static ConfigOption<ElasticsearchConnectorOptions.BackOffType> |
ElasticsearchConnectorOptions.BULK_FLUSH_BACKOFF_TYPE_OPTION |
static ConfigOption<java.time.Duration> |
ElasticsearchConnectorOptions.BULK_FLUSH_INTERVAL_OPTION |
static ConfigOption<Integer> |
ElasticsearchConnectorOptions.BULK_FLUSH_MAX_ACTIONS_OPTION |
static ConfigOption<String> |
ElasticsearchConnectorOptions.CONNECTION_PATH_PREFIX |
static ConfigOption<String> |
ElasticsearchConnectorOptions.DOCUMENT_TYPE_OPTION |
static ConfigOption<String> |
ElasticsearchConnectorOptions.FAILURE_HANDLER_OPTION |
static ConfigOption<Boolean> |
ElasticsearchConnectorOptions.FLUSH_ON_CHECKPOINT_OPTION |
static ConfigOption<String> |
ElasticsearchConnectorOptions.FORMAT_OPTION |
static ConfigOption<List<String>> |
ElasticsearchConnectorOptions.HOSTS_OPTION |
static ConfigOption<String> |
ElasticsearchConnectorOptions.INDEX_OPTION |
static ConfigOption<String> |
ElasticsearchConnectorOptions.KEY_DELIMITER_OPTION |
static ConfigOption<String> |
ElasticsearchConnectorOptions.PASSWORD_OPTION |
static ConfigOption<String> |
ElasticsearchConnectorOptions.USERNAME_OPTION |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
Elasticsearch7DynamicSinkFactory.optionalOptions() |
Set<ConfigOption<?>> |
Elasticsearch6DynamicSinkFactory.optionalOptions() |
Set<ConfigOption<?>> |
Elasticsearch7DynamicSinkFactory.requiredOptions() |
Set<ConfigOption<?>> |
Elasticsearch6DynamicSinkFactory.requiredOptions() |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
KafkaDynamicTableFactory.forwardOptions() |
Set<ConfigOption<?>> |
KafkaDynamicTableFactory.optionalOptions() |
Set<ConfigOption<?>> |
UpsertKafkaDynamicTableFactory.optionalOptions() |
Set<ConfigOption<?>> |
KafkaDynamicTableFactory.requiredOptions() |
Set<ConfigOption<?>> |
UpsertKafkaDynamicTableFactory.requiredOptions() |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
KinesisDynamicTableFactory.forwardOptions() |
Set<ConfigOption<?>> |
KinesisDynamicTableFactory.optionalOptions() |
Set<ConfigOption<?>> |
KinesisDynamicTableFactory.requiredOptions() |
Modifier and Type | Method and Description |
---|---|
TableDescriptor.Builder |
TableDescriptor.Builder.format(ConfigOption<String> formatOption,
FormatDescriptor formatDescriptor)
Defines the format to be used for this table.
|
<T> T |
TableConfig.get(ConfigOption<T> option)
Reads a value using the metadata included in
ConfigOption . |
<T> Optional<T> |
TableConfig.getOptional(ConfigOption<T> option)
Reads a value using the metadata included in
ConfigOption . |
<T> TableDescriptor.Builder |
TableDescriptor.Builder.option(ConfigOption<T> configOption,
T value)
Sets the given option on the table.
|
<T> FormatDescriptor.Builder |
FormatDescriptor.Builder.option(ConfigOption<T> configOption,
T value)
Sets the given option on the format.
|
<T> TableConfig |
TableConfig.set(ConfigOption<T> option,
T value)
Sets an application-specific value for the given
ConfigOption . |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
CommonCatalogOptions.CATALOG_TYPE
ConfigOption which is used during catalog discovery to match it against Factory.factoryIdentifier() . |
static ConfigOption<String> |
GenericInMemoryCatalogFactoryOptions.DEFAULT_DATABASE |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
GenericInMemoryCatalogFactory.optionalOptions() |
Set<ConfigOption<?>> |
GenericInMemoryCatalogFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<java.time.Duration> |
HiveConfOptions.LOCK_ACQUIRE_TIMEOUT |
static ConfigOption<java.time.Duration> |
HiveConfOptions.LOCK_CHECK_MAX_SLEEP |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
HiveCatalogFactoryOptions.DEFAULT_DATABASE |
static ConfigOption<String> |
HiveCatalogFactoryOptions.HADOOP_CONF_DIR |
static ConfigOption<String> |
HiveCatalogFactoryOptions.HIVE_CONF_DIR |
static ConfigOption<String> |
HiveCatalogFactoryOptions.HIVE_VERSION |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
HiveCatalogFactory.optionalOptions() |
Set<ConfigOption<?>> |
HiveCatalogFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Integer> |
SqlClientOptions.DISPLAY_MAX_COLUMN_WIDTH |
static ConfigOption<Integer> |
SqlClientOptions.EXECUTION_MAX_TABLE_RESULT_ROWS |
static ConfigOption<ResultMode> |
SqlClientOptions.EXECUTION_RESULT_MODE |
static ConfigOption<Boolean> |
SqlClientOptions.VERBOSE |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Integer> |
SocketDynamicTableFactory.BYTE_DELIMITER |
static ConfigOption<String> |
ChangelogCsvFormatFactory.COLUMN_DELIMITER |
static ConfigOption<String> |
SocketDynamicTableFactory.HOSTNAME |
static ConfigOption<Integer> |
SocketDynamicTableFactory.PORT |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
ChangelogCsvFormatFactory.optionalOptions() |
Set<ConfigOption<?>> |
SocketDynamicTableFactory.optionalOptions() |
Set<ConfigOption<?>> |
ChangelogCsvFormatFactory.requiredOptions() |
Set<ConfigOption<?>> |
SocketDynamicTableFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
FactoryUtil.CONNECTOR |
static ConfigOption<String> |
FactoryUtil.FORMAT |
static ConfigOption<Integer> |
FactoryUtil.PROPERTY_VERSION
Describes the property version.
|
static ConfigOption<Integer> |
FactoryUtil.SINK_PARALLELISM |
Modifier and Type | Method and Description |
---|---|
default Set<ConfigOption<?>> |
DynamicTableFactory.forwardOptions()
Returns a set of
ConfigOption that are directly forwarded to the runtime
implementation but don't affect the final execution topology. |
default Set<ConfigOption<?>> |
FormatFactory.forwardOptions()
Returns a set of
ConfigOption that are directly forwarded to the runtime
implementation but don't affect the final execution topology. |
Set<ConfigOption<?>> |
Factory.optionalOptions()
Returns a set of
ConfigOption that an implementation of this factory consumes in
addition to Factory.requiredOptions() . |
default Set<ConfigOption<?>> |
CatalogFactory.optionalOptions() |
default Set<ConfigOption<?>> |
ModuleFactory.optionalOptions() |
Set<ConfigOption<?>> |
Factory.requiredOptions()
Returns a set of
ConfigOption that an implementation of this factory requires in
addition to Factory.optionalOptions() . |
default Set<ConfigOption<?>> |
CatalogFactory.requiredOptions() |
default Set<ConfigOption<?>> |
ModuleFactory.requiredOptions() |
Modifier and Type | Method and Description |
---|---|
<I,F extends DecodingFormatFactory<I>> |
FactoryUtil.TableFactoryHelper.discoverDecodingFormat(Class<F> formatFactoryClass,
ConfigOption<String> formatOption)
Discovers a
DecodingFormat of the given type using the given option as factory
identifier. |
<I,F extends EncodingFormatFactory<I>> |
FactoryUtil.TableFactoryHelper.discoverEncodingFormat(Class<F> formatFactoryClass,
ConfigOption<String> formatOption)
Discovers a
EncodingFormat of the given type using the given option as factory
identifier. |
<I,F extends DecodingFormatFactory<I>> |
FactoryUtil.TableFactoryHelper.discoverOptionalDecodingFormat(Class<F> formatFactoryClass,
ConfigOption<String> formatOption)
Discovers a
DecodingFormat of the given type using the given option (if present)
as factory identifier. |
<I,F extends EncodingFormatFactory<I>> |
FactoryUtil.TableFactoryHelper.discoverOptionalEncodingFormat(Class<F> formatFactoryClass,
ConfigOption<String> formatOption)
Discovers a
EncodingFormat of the given type using the given option (if present)
as factory identifier. |
static String |
FactoryUtil.getFormatPrefix(ConfigOption<String> formatOption,
String formatIdentifier)
Returns the required option prefix for options of the given format.
|
Modifier and Type | Method and Description |
---|---|
static void |
FactoryUtil.validateFactoryOptions(Set<ConfigOption<?>> requiredOptions,
Set<ConfigOption<?>> optionalOptions,
ReadableConfig options)
Validates the required options and optional options.
|
static void |
FactoryUtil.validateFactoryOptions(Set<ConfigOption<?>> requiredOptions,
Set<ConfigOption<?>> optionalOptions,
ReadableConfig options)
Validates the required options and optional options.
|
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
CommonModuleOptions.MODULE_TYPE
Deprecated.
This is only required for the legacy factory stack
|
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
CoreModuleFactory.optionalOptions() |
Set<ConfigOption<?>> |
CoreModuleFactory.requiredOptions() |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<String> |
HiveModuleOptions.HIVE_VERSION |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
HiveModuleFactory.optionalOptions() |
Set<ConfigOption<?>> |
HiveModuleFactory.requiredOptions() |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
DefaultPlannerFactory.optionalOptions() |
Set<ConfigOption<?>> |
DefaultExpressionParserFactory.optionalOptions() |
Set<ConfigOption<?>> |
DefaultExecutorFactory.optionalOptions() |
Set<ConfigOption<?>> |
DefaultParserFactory.optionalOptions() |
Set<ConfigOption<?>> |
DefaultPlannerFactory.requiredOptions() |
Set<ConfigOption<?>> |
DefaultExpressionParserFactory.requiredOptions() |
Set<ConfigOption<?>> |
DefaultExecutorFactory.requiredOptions() |
Set<ConfigOption<?>> |
DefaultParserFactory.requiredOptions() |
Modifier and Type | Method and Description |
---|---|
Set<ConfigOption<?>> |
HiveParserFactory.optionalOptions() |
Set<ConfigOption<?>> |
HiveParserFactory.requiredOptions() |
Modifier and Type | Method and Description |
---|---|
<T> T |
ExecNodeConfig.get(ConfigOption<T> option) |
<T> Optional<T> |
ExecNodeConfig.getOptional(ConfigOption<T> option) |
Modifier and Type | Field and Description |
---|---|
static Set<ConfigOption<?>> |
ExecNodeMetadataUtil.EXECUTION_CONFIG_OPTIONS |
static Set<ConfigOption<?>> |
ExecNodeMetadataUtil.TABLE_CONFIG_OPTIONS |
Modifier and Type | Method and Description |
---|---|
static <T extends ExecNode<?>> |
ExecNodeMetadataUtil.newPersistedConfig(Class<T> execNodeClass,
ReadableConfig tableConfig,
java.util.stream.Stream<ConfigOption<?>> configOptions) |
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Boolean> |
InternalConfigOptions.TABLE_EXEC_NON_TEMPORAL_SORT_ENABLED |
static ConfigOption<Long> |
InternalConfigOptions.TABLE_QUERY_START_EPOCH_TIME |
static ConfigOption<Long> |
InternalConfigOptions.TABLE_QUERY_START_LOCAL_TIME |
Modifier and Type | Method and Description |
---|---|
<T> FlinkContainersBuilder |
FlinkContainersBuilder.setConfiguration(ConfigOption<T> option,
T value)
Sets a single configuration of the cluster.
|
Modifier and Type | Field and Description |
---|---|
static ConfigOption<Integer> |
YarnConfigOptions.APP_MASTER_VCORES
The vcores used by YARN application master.
|
static ConfigOption<Long> |
YarnConfigOptions.APPLICATION_ATTEMPT_FAILURE_VALIDITY_INTERVAL
The config parameter defining the attemptFailuresValidityInterval of Yarn application.
|
static ConfigOption<String> |
YarnConfigOptions.APPLICATION_ATTEMPTS
Set the number of retries for failed YARN ApplicationMasters/JobManagers in high availability
mode.
|
static ConfigOption<String> |
YarnConfigOptions.APPLICATION_ID |
static ConfigOption<String> |
YarnConfigOptionsInternal.APPLICATION_LOG_CONFIG_FILE |
static ConfigOption<String> |
YarnConfigOptions.APPLICATION_MASTER_PORT
The config parameter defining the Akka actor system port for the ApplicationMaster and
JobManager.
|
static ConfigOption<String> |
YarnConfigOptions.APPLICATION_NAME |
static ConfigOption<Integer> |
YarnConfigOptions.APPLICATION_PRIORITY
A non-negative integer indicating the priority for submitting a Flink YARN application.
|
static ConfigOption<String> |
YarnConfigOptions.APPLICATION_QUEUE |
static ConfigOption<String> |
YarnConfigOptions.APPLICATION_TAGS
A comma-separated list of strings to use as YARN application tags.
|
static ConfigOption<String> |
YarnConfigOptions.APPLICATION_TYPE |
static ConfigOption<YarnConfigOptions.UserJarInclusion> |
YarnConfigOptions.CLASSPATH_INCLUDE_USER_JAR
Defines whether user-jars are included in the system class path as well as their positioning
in the path.
|
static ConfigOption<Integer> |
YarnConfigOptions.CONTAINER_REQUEST_HEARTBEAT_INTERVAL_MILLISECONDS
The heartbeat interval between the Application Master and the YARN Resource Manager if Flink
is requesting containers.
|
static ConfigOption<String> |
YarnConfigOptions.EXTERNAL_RESOURCE_YARN_CONFIG_KEY
If configured, Flink will add this key to the resource profile of container request to Yarn.
|
static ConfigOption<Integer> |
YarnConfigOptions.FILE_REPLICATION
Yarn session client uploads flink jar and user libs to file system (hdfs/s3) as local
resource for yarn application context.
|
static ConfigOption<String> |
YarnConfigOptions.FLINK_DIST_JAR |
static ConfigOption<String> |
YarnConfigOptions.HADOOP_CONFIG_KEY |
static ConfigOption<Integer> |
YarnConfigOptions.HEARTBEAT_DELAY_SECONDS
The heartbeat interval between the Application Master and the YARN Resource Manager.
|
static ConfigOption<String> |
YarnConfigOptions.LOCALIZED_KEYTAB_PATH |
static ConfigOption<String> |
YarnConfigOptions.NODE_LABEL |
static ConfigOption<String> |
YarnConfigOptions.PROPERTIES_FILE_LOCATION
When a Flink job is submitted to YARN, the JobManager's host and the number of available
processing slots is written into a properties file, so that the Flink client is able to pick
those details up.
|
static ConfigOption<List<String>> |
YarnConfigOptions.PROVIDED_LIB_DIRS |
static ConfigOption<List<String>> |
YarnConfigOptions.SHIP_ARCHIVES |
static ConfigOption<List<String>> |
YarnConfigOptions.SHIP_FILES |
static ConfigOption<Boolean> |
YarnConfigOptions.SHIP_LOCAL_KEYTAB |
static ConfigOption<String> |
YarnConfigOptions.STAGING_DIRECTORY |
static ConfigOption<String> |
YarnConfigOptions.TASK_MANAGER_NODE_LABEL |
static ConfigOption<Integer> |
YarnConfigOptions.VCORES
The vcores exposed by YARN.
|
static ConfigOption<List<String>> |
YarnConfigOptions.YARN_ACCESS |
static ConfigOption<String> |
YarnConfigOptions.YARN_CONFIG_KEY |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.