Package | Description |
---|---|
org.apache.storm |
Modifier and Type | Field and Description |
---|---|
static String |
Config.BACKPRESSURE_ZNODE_TIMEOUT_SECS
How long until the backpressure znode is invalid.
|
static String |
Config.BACKPRESSURE_ZNODE_UPDATE_FREQ_SECS
How often will the data (timestamp) of backpressure znode be updated.
|
static String |
Config.DRPC_HTTP_PORT
This port is used by Storm DRPC for receiving HTTP DPRC requests from clients.
|
static String |
Config.DRPC_HTTPS_PORT
This port is used by Storm DRPC for receiving HTTPS (SSL) DPRC requests from clients.
|
static String |
Config.DRPC_INVOCATIONS_PORT
This port on Storm DRPC is used by DRPC topologies to receive function invocations and send results back.
|
static String |
Config.DRPC_INVOCATIONS_THREADS
DRPC invocations thrift server worker threads
|
static String |
Config.DRPC_PORT
This port is used by Storm DRPC for receiving DPRC requests from clients.
|
static String |
Config.DRPC_QUEUE_SIZE
DRPC thrift server queue size
|
static String |
Config.DRPC_REQUEST_TIMEOUT_SECS
The timeout on DRPC requests within the DRPC server.
|
static String |
Config.DRPC_WORKER_THREADS
DRPC thrift server worker threads
|
static String |
Config.LOGVIEWER_CLEANUP_AGE_MINS
How many minutes since a log was last modified for the log to be considered for clean-up
|
static String |
Config.LOGVIEWER_CLEANUP_INTERVAL_SECS
How often to clean up old log files
|
static String |
Config.LOGVIEWER_HTTPS_PORT
Storm Logviewer HTTPS port
|
static String |
Config.LOGVIEWER_PORT
HTTP UI port for log viewer
|
static String |
Config.NIMBUS_BLOBSTORE_EXPIRATION_SECS
During operations with the blob store, via master, how long a connection is idle before nimbus considers it dead and drops the session and any associated connections.
|
static String |
Config.NIMBUS_CLEANUP_INBOX_FREQ_SECS
How often nimbus should wake the cleanup thread to clean the inbox.
|
static String |
Config.NIMBUS_CODE_SYNC_FREQ_SECS
How often nimbus’s background thread to sync code for missing topologies should run.
|
static String |
Config.NIMBUS_CREDENTIAL_RENEW_FREQ_SECS
How often nimbus should wake up to renew credentials if needed.
|
static String |
Config.NIMBUS_EXECUTORS_PER_TOPOLOGY
A number representing the maximum number of executors any single topology can acquire.
|
static String |
Config.NIMBUS_FILE_COPY_EXPIRATION_SECS
During upload/download with the master, how long an upload or download connection is idle before nimbus considers it dead and drops the connection.
|
static String |
Config.NIMBUS_INBOX_JAR_EXPIRATION_SECS
The length of time a jar file lives in the inbox before being deleted by the cleanup thread.
|
static String |
Config.NIMBUS_MONITOR_FREQ_SECS
How often nimbus should wake up to check heartbeats and do reassignments.
|
static String |
Config.NIMBUS_QUEUE_SIZE
Nimbus thrift server queue size, default is 100000.
|
static String |
Config.NIMBUS_SLOTS_PER_TOPOLOGY
A number representing the maximum number of workers any single topology can acquire.
|
static String |
Config.NIMBUS_SUPERVISOR_TIMEOUT_SECS
How long before a supervisor can go without heartbeating before nimbus considers it dead and stops assigning new work to it.
|
static String |
Config.NIMBUS_TASK_LAUNCH_SECS
A special timeout used when a task is initially launched.
|
static String |
Config.NIMBUS_TASK_TIMEOUT_SECS
How long without heartbeating a task can go before nimbus will consider the task dead and reassign it to another location.
|
static String |
Config.NIMBUS_THRIFT_MAX_BUFFER_SIZE
Deprecated.
As SimpleTrasportPlugin is deprecated, no other thrift transport plugin uses this configuration.
|
static String |
Config.NIMBUS_THRIFT_PORT
Which port the Thrift interface of Nimbus should run on.
|
static String |
Config.NIMBUS_THRIFT_THREADS
The number of threads that should be used by the nimbus thrift server.
|
static String |
Config.STORM_BLOBSTORE_INPUTSTREAM_BUFFER_SIZE_BYTES
What buffer size to use for the blobstore uploads.
|
static String |
Config.STORM_BLOBSTORE_REPLICATION_FACTOR
Set replication factor for a blob in HDFS Blobstore Implementation
|
static String |
Config.STORM_EXHIBITOR_POLL
How often to poll Exhibitor cluster in millis.
|
static String |
Config.STORM_EXHIBITOR_PORT
The port Storm will use to connect to each of the exhibitor servers.
|
static String |
Config.STORM_EXHIBITOR_RETRY_INTERVAL
The interval between retries of an Exhibitor operation.
|
static String |
Config.STORM_EXHIBITOR_RETRY_INTERVAL_CEILING
The ceiling of the interval between retries of an Exhibitor operation.
|
static String |
Config.STORM_EXHIBITOR_RETRY_TIMES
The number of times to retry an Exhibitor operation.
|
static String |
Config.STORM_GROUP_MAPPING_SERVICE_CACHE_DURATION_SECS
Max no.of seconds group mapping service will cache user groups
|
static String |
Config.STORM_MESSAGING_NETTY_BUFFER_SIZE
Netty based messaging: The buffer size for send/recv buffer
|
static String |
Config.STORM_MESSAGING_NETTY_CLIENT_WORKER_THREADS
Netty based messaging: The # of worker threads for the client.
|
static String |
Config.STORM_MESSAGING_NETTY_MAX_RETRIES
Deprecated.
"Since netty clients should never stop reconnecting - this does not make sense anymore.
|
static String |
Config.STORM_MESSAGING_NETTY_MAX_SLEEP_MS
Netty based messaging: The max # of milliseconds that a peer will wait.
|
static String |
Config.STORM_MESSAGING_NETTY_MIN_SLEEP_MS
Netty based messaging: The min # of milliseconds that a peer will wait.
|
static String |
Config.STORM_MESSAGING_NETTY_SERVER_WORKER_THREADS
Netty based messaging: The # of worker threads for the server.
|
static String |
Config.STORM_MESSAGING_NETTY_SOCKET_BACKLOG
Netty based messaging: Sets the backlog value to specify when the channel binds to a local address
|
static String |
Config.STORM_NETTY_FLUSH_CHECK_INTERVAL_MS
We check with this interval that whether the Netty channel is writable and try to write pending messages
|
static String |
Config.STORM_NETTY_MESSAGE_BATCH_SIZE
If the Netty messaging layer is busy, the Netty client will try to batch message as more as possible up to the size of STORM_NETTY_MESSAGE_BATCH_SIZE bytes
|
static String |
Config.STORM_THRIFT_SOCKET_TIMEOUT_MS
How long before a Thrift Client socket hangs before timeout and restart the socket.
|
static String |
Config.STORM_WORKER_DISRUPTOR_FLUSHER_MAX_POOL_SIZE
This is a config that is not likely to be used.
|
static String |
Config.STORM_ZOOKEEPER_CONNECTION_TIMEOUT
The connection timeout for clients to ZooKeeper.
|
static String |
Config.STORM_ZOOKEEPER_PORT
The port Storm will use to connect to each of the ZooKeeper servers.
|
static String |
Config.STORM_ZOOKEEPER_RETRY_INTERVAL
The interval between retries of a Zookeeper operation.
|
static String |
Config.STORM_ZOOKEEPER_RETRY_INTERVAL_CEILING
The ceiling of the interval between retries of a Zookeeper operation.
|
static String |
Config.STORM_ZOOKEEPER_RETRY_TIMES
The number of times to retry a Zookeeper operation.
|
static String |
Config.STORM_ZOOKEEPER_SESSION_TIMEOUT
The session timeout for clients to ZooKeeper.
|
static String |
Config.SUPERVISOR_BLOBSTORE_DOWNLOAD_MAX_RETRIES
Maximum number of retries a supervisor is allowed to make for downloading a blob.
|
static String |
Config.SUPERVISOR_BLOBSTORE_DOWNLOAD_THREAD_COUNT
What blobstore download parallelism the supervisor should use.
|
static String |
Config.SUPERVISOR_HEARTBEAT_FREQUENCY_SECS
how often the supervisor sends a heartbeat to the master.
|
static String |
Config.SUPERVISOR_LOCALIZER_CACHE_CLEANUP_INTERVAL_MS
The distributed cache cleanup interval.
|
static String |
Config.SUPERVISOR_LOCALIZER_CACHE_TARGET_SIZE_MB
The distributed cache target size in MB.
|
static String |
Config.SUPERVISOR_MONITOR_FREQUENCY_SECS
How often the supervisor checks the worker heartbeats to see if any of them need to be restarted.
|
static String |
Config.SUPERVISOR_WORKER_SHUTDOWN_SLEEP_SECS
How many seconds to sleep for before shutting down threads on worker
|
static String |
Config.SUPERVISOR_WORKER_START_TIMEOUT_SECS
How long a worker can go without heartbeating during the initial launch before the supervisor tries to restart the worker process.
|
static String |
Config.SUPERVISOR_WORKER_TIMEOUT_SECS
How long a worker can go without heartbeating before the supervisor tries to restart the worker process.
|
static String |
Config.TASK_BACKPRESSURE_POLL_SECS
How often to poll for changed topology backpressure flag from ZK
|
static String |
Config.TASK_CREDENTIALS_POLL_SECS
How often a task should sync credentials, worst case.
|
static String |
Config.TASK_HEARTBEAT_FREQUENCY_SECS
How often a task should heartbeat its status to the master.
|
static String |
Config.TASK_REFRESH_POLL_SECS
How often a task should sync its connections with other tasks (if a task is reassigned, the other tasks sending messages to it need to refresh their connections).
|
static String |
Config.TOPOLOGY_ACKER_EXECUTORS
How many executors to spawn for ackers.
|
static String |
Config.TOPOLOGY_BOLTS_SLIDING_INTERVAL_COUNT |
static String |
Config.TOPOLOGY_BOLTS_SLIDING_INTERVAL_DURATION_MS |
static String |
Config.TOPOLOGY_BOLTS_TUPLE_TIMESTAMP_MAX_LAG_MS
Bolt-specific configuration for windowed bolts to specify the maximum time lag of the tuple timestamp in milliseconds.
|
static String |
Config.TOPOLOGY_BOLTS_WATERMARK_EVENT_INTERVAL_MS |
static String |
Config.TOPOLOGY_BOLTS_WINDOW_LENGTH_COUNT |
static String |
Config.TOPOLOGY_BOLTS_WINDOW_LENGTH_DURATION_MS |
static String |
Config.TOPOLOGY_BUILTIN_METRICS_BUCKET_SIZE_SECS
The time period that builtin metrics data in bucketed into.
|
static String |
Config.TOPOLOGY_DISRUPTOR_BATCH_SIZE
The number of tuples to batch before sending to the next thread.
|
static String |
Config.TOPOLOGY_DISRUPTOR_BATCH_TIMEOUT_MILLIS
The maximum age in milliseconds a batch can be before being sent to the next thread.
|
static String |
Config.TOPOLOGY_DISRUPTOR_WAIT_TIMEOUT_MILLIS
Configure timeout milliseconds used for disruptor queue wait strategy.
|
static String |
Config.TOPOLOGY_ERROR_THROTTLE_INTERVAL_SECS
The interval in seconds to use for determining whether to throttle error reported to Zookeeper.
|
static String |
Config.TOPOLOGY_EVENTLOGGER_EXECUTORS
How many executors to spawn for event logger.
|
static String |
Config.TOPOLOGY_ISOLATED_MACHINES
The number of machines that should be used by this topology to isolate it from all others.
|
static String |
Config.TOPOLOGY_MAX_ERROR_REPORT_PER_INTERVAL
See doc for TOPOLOGY_ERROR_THROTTLE_INTERVAL_SECS
|
static String |
Config.TOPOLOGY_MAX_SPOUT_PENDING
The maximum number of tuples that can be pending on a spout task at any given time.
|
static String |
Config.TOPOLOGY_MAX_TASK_PARALLELISM
The maximum parallelism allowed for a component in this topology.
|
static String |
Config.TOPOLOGY_MESSAGE_TIMEOUT_SECS
The maximum amount of time given to the topology to fully process a message emitted by a spout.
|
static String |
Config.TOPOLOGY_PRIORITY
Sets the priority for a topology
|
static String |
Config.TOPOLOGY_SHELLBOLT_MAX_PENDING
Max pending tuples in one ShellBolt
|
static String |
Config.TOPOLOGY_SLEEP_SPOUT_WAIT_STRATEGY_TIME_MS
The amount of milliseconds the SleepEmptyEmitStrategy should sleep for.
|
static String |
Config.TOPOLOGY_STATE_CHECKPOINT_INTERVAL
Topology configuration to specify the checkpoint interval (in millis) at which the topology state is saved when
IStatefulBolt bolts are involved. |
static String |
Config.TOPOLOGY_STATE_SYNCHRONIZATION_TIMEOUT_SECS
The maximum amount of time a component gives a source of state to synchronize before it requests synchronization again.
|
static String |
Config.TOPOLOGY_SUBPROCESS_TIMEOUT_SECS
How long a subprocess can go without heartbeating before the ShellSpout/ShellBolt tries to suicide itself.
|
static String |
Config.TOPOLOGY_TASKS
How many instances to create for a spout/bolt.
|
static String |
Config.TOPOLOGY_TICK_TUPLE_FREQ_SECS
How often a tick tuple from the “_system“ component and ”_tick” stream should be sent to tasks.
|
static String |
Config.TOPOLOGY_TRANSFER_BUFFER_SIZE
The size of the Disruptor transfer queue for each worker.
|
static String |
Config.TOPOLOGY_TRIDENT_BATCH_EMIT_INTERVAL_MILLIS
How often a batch can be emitted in a Trident topology.
|
static String |
Config.TOPOLOGY_TRIDENT_WINDOWING_INMEMORY_CACHE_LIMIT
Maximum number of tuples that can be stored inmemory cache in windowing operators for fast access without fetching them from store.
|
static String |
Config.TOPOLOGY_WORKER_SHARED_THREAD_POOL_SIZE
The size of the shared thread pool for worker tasks to make use of.
|
static String |
Config.TOPOLOGY_WORKERS
How many processes should be spawned around the cluster to execute this topology.
|
static String |
Config.TRANSACTIONAL_ZOOKEEPER_PORT
The port to use to connect to the transactional zookeeper servers.
|
static String |
Config.UI_HEADER_BUFFER_BYTES
The size of the header buffer for the UI in bytes
|
static String |
Config.UI_HTTPS_PORT
This port is used by Storm DRPC for receiving HTTPS (SSL) DPRC requests from clients.
|
static String |
Config.UI_PAGINATION
Storm UI drop-down pagination value.
|
static String |
Config.UI_PORT
Storm UI binds to this port.
|
static String |
Config.WORKER_HEAP_MEMORY_MB
The default heap memory size in MB per worker, used in the jvm -Xmx opts for launching the worker
|
static String |
Config.WORKER_HEARTBEAT_FREQUENCY_SECS
How often this worker should heartbeat to the supervisor.
|
static String |
Config.WORKER_LOG_LEVEL_RESET_POLL_SECS
How often a worker should check dynamic log level timeouts for expiration.
|
static String |
Config.ZMQ_HWM
Deprecated.
|
static String |
Config.ZMQ_LINGER_MILLIS
Deprecated.
|
static String |
Config.ZMQ_THREADS
Deprecated.
|
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.