public class Config extends HashMap<String,Object>
Topology configs are specified as a plain old map. This class provides a convenient way to create a topology config map by providing setter methods for all the configs that can be set. It also makes it easier to do things like add serializations.
This class also provides constants for all the configurations possible on a Storm cluster and Storm topology. Each constant is paired with an annotation that defines the validity criterion of the corresponding field. Default values for these configs can be found in defaults.yaml.
Note that you may put other configurations in any of the configs. Storm will ignore anything it doesn’t recognize, but your topologies are free to make use of them by reading them in the prepare method of Bolts or the open method of Spouts.
AbstractMap.SimpleEntry<K,V>, AbstractMap.SimpleImmutableEntry<K,V>
Modifier and Type | Field and Description |
---|---|
static String |
BACKPRESSURE_DISRUPTOR_HIGH_WATERMARK
This signifies the tuple congestion in a disruptor queue.
|
static String |
BACKPRESSURE_DISRUPTOR_LOW_WATERMARK
This signifies a state that a disruptor queue has left the congestion.
|
static String |
BACKPRESSURE_ZNODE_TIMEOUT_SECS
How long until the backpressure znode is invalid.
|
static String |
BACKPRESSURE_ZNODE_UPDATE_FREQ_SECS
How often will the data (timestamp) of backpressure znode be updated.
|
static String |
BLOBSTORE_CLEANUP_ENABLE
Enable the blobstore cleaner.
|
static String |
BLOBSTORE_DIR
What directory to use for the blobstore.
|
static String |
BLOBSTORE_HDFS_KEYTAB
keytab for nimbus/supervisor to use to access secure hdfs for the blobstore.
|
static String |
BLOBSTORE_HDFS_PRINCIPAL
principal for nimbus/supervisor to use to access secure hdfs for the blobstore.
|
static String |
BLOBSTORE_SUPERUSER
The blobstore super user has all read/write/admin permissions to all blobs - user running the blobstore.
|
static String |
CLIENT_BLOBSTORE
What blobstore implementation the storm client should use.
|
static Object |
CLIENT_JAR_TRANSFORMER
An implementation of @{link org.apache.storm.daemon.JarTransformer} that will can be used to transform a jar file before storm jar runs with it.
|
static String |
DEV_ZOOKEEPER_PATH
The path to use as the zookeeper dir when running a zookeeper server via “storm dev-zookeeper”.
|
static String |
DISABLE_SYMLINKS
On some systems (windows for example) symlinks require special privileges that not everyone wants to grant a headless user.
|
static String |
DRPC_AUTHORIZER
Class name for authorization plugin for DRPC client
|
static String |
DRPC_AUTHORIZER_ACL
The Access Control List for the DRPC Authorizer.
|
static String |
DRPC_AUTHORIZER_ACL_FILENAME
File name of the DRPC Authorizer ACL.
|
static String |
DRPC_AUTHORIZER_ACL_STRICT
Whether the DRPCSimpleAclAuthorizer should deny requests for operations involving functions that have no explicit ACL entry.
|
static String |
DRPC_CHILDOPTS
Childopts for Storm DRPC Java process.
|
static String |
DRPC_HTTP_CREDS_PLUGIN
Class name of the HTTP credentials plugin for DRPC.
|
static String |
DRPC_HTTP_FILTER
A class implementing javax.servlet.Filter for DRPC HTTP requests
|
static String |
DRPC_HTTP_FILTER_PARAMS
Initialization parameters for the javax.servlet.Filter of the DRPC HTTP service
|
static String |
DRPC_HTTP_PORT
This port is used by Storm DRPC for receiving HTTP DPRC requests from clients.
|
static String |
DRPC_HTTPS_KEY_PASSWORD
Password to the private key in the keystore for setting up HTTPS (SSL).
|
static String |
DRPC_HTTPS_KEYSTORE_PASSWORD
Password to the keystore used by Storm DRPC for setting up HTTPS (SSL).
|
static String |
DRPC_HTTPS_KEYSTORE_PATH
Path to the keystore used by Storm DRPC for setting up HTTPS (SSL).
|
static String |
DRPC_HTTPS_KEYSTORE_TYPE
Type of keystore used by Storm DRPC for setting up HTTPS (SSL).
|
static String |
DRPC_HTTPS_NEED_CLIENT_AUTH |
static String |
DRPC_HTTPS_PORT
This port is used by Storm DRPC for receiving HTTPS (SSL) DPRC requests from clients.
|
static String |
DRPC_HTTPS_TRUSTSTORE_PASSWORD
Password to the truststore used by Storm DRPC setting up HTTPS (SSL).
|
static String |
DRPC_HTTPS_TRUSTSTORE_PATH
Path to the truststore used by Storm DRPC setting up HTTPS (SSL).
|
static String |
DRPC_HTTPS_TRUSTSTORE_TYPE
Type of truststore used by Storm DRPC for setting up HTTPS (SSL).
|
static String |
DRPC_HTTPS_WANT_CLIENT_AUTH
Password to the truststore used by Storm DRPC setting up HTTPS (SSL).
|
static String |
DRPC_INVOCATIONS_PORT
This port on Storm DRPC is used by DRPC topologies to receive function invocations and send results back.
|
static String |
DRPC_INVOCATIONS_THREADS
DRPC invocations thrift server worker threads
|
static String |
DRPC_INVOCATIONS_THRIFT_TRANSPORT_PLUGIN
The DRPC invocations transport plug-in for Thrift client/server communication
|
static String |
DRPC_MAX_BUFFER_SIZE
Deprecated.
As SimpleTrasportPlugin is deprecated, no other thrift transport plugin uses this configuration.
|
static String |
DRPC_PORT
This port is used by Storm DRPC for receiving DPRC requests from clients.
|
static String |
DRPC_QUEUE_SIZE
DRPC thrift server queue size
|
static String |
DRPC_REQUEST_TIMEOUT_SECS
The timeout on DRPC requests within the DRPC server.
|
static String |
DRPC_SERVERS
List of DRPC servers so that the DRPCSpout knows who to talk to.
|
static String |
DRPC_THRIFT_TRANSPORT_PLUGIN
The DRPC transport plug-in for Thrift client/server communication
|
static String |
DRPC_WORKER_THREADS
DRPC thrift server worker threads
|
static String |
ISOLATION_SCHEDULER_MACHINES
A map from topology name to the number of machines that should be dedicated for that topology.
|
static String |
JAVA_LIBRARY_PATH
This value is passed to spawned JVMs (e.g., Nimbus, Supervisor, and Workers) for the java.library.path value.
|
static String |
LOGS_GROUPS
A list of groups allowed to view logs via the Log Viewer
|
static String |
LOGS_USERS
A list of users allowed to view logs via the Log Viewer
|
static String |
LOGVIEWER_APPENDER_NAME
Appender name used by log viewer to determine log directory.
|
static String |
LOGVIEWER_CHILDOPTS
Childopts for log viewer java process.
|
static String |
LOGVIEWER_CLEANUP_AGE_MINS
How many minutes since a log was last modified for the log to be considered for clean-up
|
static String |
LOGVIEWER_CLEANUP_INTERVAL_SECS
How often to clean up old log files
|
static String |
LOGVIEWER_HTTPS_KEY_PASSWORD
Password to the private key in the keystore for setting up HTTPS (SSL).
|
static String |
LOGVIEWER_HTTPS_KEYSTORE_PASSWORD
Password for the keystore for HTTPS for Storm Logviewer
|
static String |
LOGVIEWER_HTTPS_KEYSTORE_PATH
Path to the keystore containing the certs used by Storm Logviewer for HTTPS communications
|
static String |
LOGVIEWER_HTTPS_KEYSTORE_TYPE
Type of the keystore for HTTPS for Storm Logviewer.
|
static String |
LOGVIEWER_HTTPS_NEED_CLIENT_AUTH |
static String |
LOGVIEWER_HTTPS_PORT
Storm Logviewer HTTPS port
|
static String |
LOGVIEWER_HTTPS_TRUSTSTORE_PASSWORD
Password for the truststore for HTTPS for Storm Logviewer
|
static String |
LOGVIEWER_HTTPS_TRUSTSTORE_PATH
Path to the truststore containing the certs used by Storm Logviewer for HTTPS communications
|
static String |
LOGVIEWER_HTTPS_TRUSTSTORE_TYPE
Type of the truststore for HTTPS for Storm Logviewer.
|
static String |
LOGVIEWER_HTTPS_WANT_CLIENT_AUTH
Password to the truststore used by Storm Logviewer setting up HTTPS (SSL).
|
static String |
LOGVIEWER_MAX_PER_WORKER_LOGS_SIZE_MB
The maximum number of bytes per worker’s files can take up in MB
|
static String |
LOGVIEWER_MAX_SUM_WORKER_LOGS_SIZE_MB
The maximum number of bytes all worker log files can take up in MB
|
static String |
LOGVIEWER_PORT
HTTP UI port for log viewer
|
static String |
MULTITENANT_SCHEDULER_USER_POOLS
A map from the user name to the number of machines that should that user is allowed to use.
|
static String |
NIMBUS_ADMINS
A list of users that are cluster admins and can run any command.
|
static String |
NIMBUS_AUTHORIZER
Class name for authorization plugin for Nimbus
|
static String |
NIMBUS_AUTO_CRED_PLUGINS
A list of plugins that nimbus should load during submit topology to populate credentials on user’s behalf.
|
static String |
NIMBUS_BLOBSTORE
What blobstore implementation nimbus should use.
|
static String |
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 |
NIMBUS_CHILDOPTS
This parameter is used by the storm-deploy project to configure the jvm options for the nimbus daemon.
|
static String |
NIMBUS_CLEANUP_INBOX_FREQ_SECS
How often nimbus should wake the cleanup thread to clean the inbox.
|
static String |
NIMBUS_CODE_SYNC_FREQ_SECS
How often nimbus’s background thread to sync code for missing topologies should run.
|
static String |
NIMBUS_CREDENTIAL_RENEW_FREQ_SECS
How often nimbus should wake up to renew credentials if needed.
|
static String |
NIMBUS_CREDENTIAL_RENEWERS
A list of credential renewers that nimbus should load.
|
static String |
NIMBUS_DAEMON_USER
This is the user that the Nimbus daemon process is running as.
|
static String |
NIMBUS_EXECUTORS_PER_TOPOLOGY
A number representing the maximum number of executors any single topology can acquire.
|
static String |
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 |
NIMBUS_GROUPS
A list of groups , users belong to these groups are the only ones allowed to run user operation on storm cluster.
|
static String |
NIMBUS_HOST
Deprecated.
|
static String |
NIMBUS_IMPERSONATION_ACL
Impersonation user ACL config entries.
|
static String |
NIMBUS_IMPERSONATION_AUTHORIZER
Impersonation user ACL config entries.
|
static String |
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 |
NIMBUS_MONITOR_FREQ_SECS
How often nimbus should wake up to check heartbeats and do reassignments.
|
static String |
NIMBUS_QUEUE_SIZE
Nimbus thrift server queue size, default is 100000.
|
static String |
NIMBUS_SEEDS
List of seed nimbus hosts to use for leader nimbus discovery.
|
static String |
NIMBUS_SLOTS_PER_TOPOLOGY
A number representing the maximum number of workers any single topology can acquire.
|
static String |
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 |
NIMBUS_SUPERVISOR_USERS
A list of users that run the supervisors and should be authorized to interact with nimbus as a supervisor would.
|
static String |
NIMBUS_TASK_LAUNCH_SECS
A special timeout used when a task is initially launched.
|
static String |
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 |
NIMBUS_THRIFT_MAX_BUFFER_SIZE
Deprecated.
As SimpleTrasportPlugin is deprecated, no other thrift transport plugin uses this configuration.
|
static String |
NIMBUS_THRIFT_PORT
Which port the Thrift interface of Nimbus should run on.
|
static String |
NIMBUS_THRIFT_THREADS
The number of threads that should be used by the nimbus thrift server.
|
static String |
NIMBUS_THRIFT_TRANSPORT_PLUGIN
The Nimbus transport plug-in for Thrift client/server communication
|
static String |
NIMBUS_TOPOLOGY_ACTION_NOTIFIER_PLUGIN
FQCN of a class that implements
I @see org.apache.storm.nimbus.ITopologyActionNotifierPlugin for details. |
static Object |
NIMBUS_TOPOLOGY_ACTION_NOTIFIER_PLUGIN_SCHEMA |
static String |
NIMBUS_TOPOLOGY_VALIDATOR
A custom class that implements ITopologyValidator that is run whenever a topology is submitted.
|
static String |
NIMBUS_USERS
A list of users that are the only ones allowed to run user operation on storm cluster.
|
static String |
PACEMAKER_AUTH_METHOD
This should be one of “DIGEST”, “KERBEROS”, or “NONE” Determines the mode of authentication the pacemaker server and client use.
|
static String |
PACEMAKER_CHILDOPTS
This parameter is used by the storm-deploy project to configure the jvm options for the pacemaker daemon.
|
static String |
PACEMAKER_HOST
Deprecated.
in favor of PACEMAKER_SERVERS for Pacemaker-HA.
|
static String |
PACEMAKER_MAX_THREADS
The maximum number of threads that should be used by the Pacemaker.
|
static String |
PACEMAKER_PORT
The port Pacemaker should run on.
|
static String |
PACEMAKER_SERVERS
The hosts that Pacemaker is running on.
|
static String |
RESOURCE_AWARE_SCHEDULER_EVICTION_STRATEGY
The class that specifies the eviction strategy to use in ResourceAwareScheduler
|
static String |
RESOURCE_AWARE_SCHEDULER_PRIORITY_STRATEGY
the class that specifies the scheduling priority strategy to use in ResourceAwareScheduler
|
static String |
RESOURCE_AWARE_SCHEDULER_USER_POOLS
A map of users to another map of the resource guarantees of the user.
|
static String |
SCHEDULER_DISPLAY_RESOURCE
Whether we want to display all the resource capacity and scheduled usage on the UI page.
|
static String |
STORM_BLOBSTORE_ACL_VALIDATION_ENABLED
For secure mode we would want to turn on this config By default this is turned off assuming the default is insecure
|
static String |
STORM_BLOBSTORE_INPUTSTREAM_BUFFER_SIZE_BYTES
What buffer size to use for the blobstore uploads.
|
static String |
STORM_BLOBSTORE_REPLICATION_FACTOR
Set replication factor for a blob in HDFS Blobstore Implementation
|
static String |
STORM_CLUSTER_METRICS_CONSUMER_PUBLISH_INTERVAL_SECS
How often cluster metrics data is published to metrics consumer.
|
static String |
STORM_CLUSTER_METRICS_CONSUMER_REGISTER
A list of classes implementing IClusterMetricsConsumer (See storm.yaml.example for exact config format).
|
static String |
STORM_CLUSTER_MODE
The mode this Storm cluster is running in.
|
static String |
STORM_CLUSTER_STATE_STORE
The ClusterState factory that worker will use to create a ClusterState to store state in.
|
static String |
STORM_DAEMON_METRICS_REPORTER_CSV_LOG_DIR
A specify csv reporter directory for CvsPreparableReporter daemon metrics reporter.
|
static String |
STORM_DAEMON_METRICS_REPORTER_PLUGIN_DOMAIN
A specify domain for daemon metrics reporter plugin to limit reporting to specific domain.
|
static String |
STORM_DAEMON_METRICS_REPORTER_PLUGIN_DURATION_UNIT
A specify duration-unit in TimeUnit to specify reporting window for daemon metrics reporter plugin.
|
static String |
STORM_DAEMON_METRICS_REPORTER_PLUGIN_LOCALE
A specify Locale for daemon metrics reporter plugin.
|
static String |
STORM_DAEMON_METRICS_REPORTER_PLUGIN_RATE_UNIT
A specify rate-unit in TimeUnit to specify reporting frequency for daemon metrics reporter plugin.
|
static String |
STORM_DAEMON_METRICS_REPORTER_PLUGINS
A list of daemon metrics reporter plugin class names.
|
static String |
STORM_DO_AS_USER
The user as which the nimbus client should be acquired to perform the operation.
|
static String |
STORM_EXHIBITOR_POLL
How often to poll Exhibitor cluster in millis.
|
static String |
STORM_EXHIBITOR_PORT
The port Storm will use to connect to each of the exhibitor servers.
|
static String |
STORM_EXHIBITOR_RETRY_INTERVAL
The interval between retries of an Exhibitor operation.
|
static String |
STORM_EXHIBITOR_RETRY_INTERVAL_CEILING
The ceiling of the interval between retries of an Exhibitor operation.
|
static String |
STORM_EXHIBITOR_RETRY_TIMES
The number of times to retry an Exhibitor operation.
|
static String |
STORM_EXHIBITOR_SERVERS
A list of hosts of Exhibitor servers used to discover/maintain connection to ZooKeeper cluster.
|
static String |
STORM_EXHIBITOR_URIPATH |
static String |
STORM_GROUP_MAPPING_SERVICE_CACHE_DURATION_SECS
Max no.of seconds group mapping service will cache user groups
|
static String |
STORM_GROUP_MAPPING_SERVICE_PARAMS
Initialization parameters for the group mapping service plugin.
|
static String |
STORM_GROUP_MAPPING_SERVICE_PROVIDER_PLUGIN
The plugin that will provide user groups service
|
static String |
STORM_HEALTH_CHECK_DIR
The directory where storm’s health scripts go.
|
static String |
STORM_HEALTH_CHECK_TIMEOUT_MS
The time to allow any given healthcheck script to run before it is marked failed due to timeout
|
static String |
STORM_ID
The id assigned to a running topology.
|
static String |
STORM_LOCAL_DIR
A directory on the local filesystem used by Storm for any local filesystem usage it needs.
|
static String |
STORM_LOCAL_HOSTNAME
The hostname the supervisors/workers should report to nimbus.
|
static String |
STORM_LOCAL_MODE_ZMQ
Whether or not to use ZeroMQ for messaging in local mode.
|
static String |
STORM_LOG4J2_CONF_DIR
A directory that holds configuration files for log4j2.
|
static String |
STORM_MESSAGING_NETTY_AUTHENTICATION
Netty based messaging: Is authentication required for Netty messaging from client worker process to server worker process.
|
static String |
STORM_MESSAGING_NETTY_BUFFER_SIZE
Netty based messaging: The buffer size for send/recv buffer
|
static String |
STORM_MESSAGING_NETTY_CLIENT_WORKER_THREADS
Netty based messaging: The # of worker threads for the client.
|
static String |
STORM_MESSAGING_NETTY_MAX_RETRIES
Deprecated.
"Since netty clients should never stop reconnecting - this does not make sense anymore.
|
static String |
STORM_MESSAGING_NETTY_MAX_SLEEP_MS
Netty based messaging: The max # of milliseconds that a peer will wait.
|
static String |
STORM_MESSAGING_NETTY_MIN_SLEEP_MS
Netty based messaging: The min # of milliseconds that a peer will wait.
|
static String |
STORM_MESSAGING_NETTY_SERVER_WORKER_THREADS
Netty based messaging: The # of worker threads for the server.
|
static String |
STORM_MESSAGING_NETTY_SOCKET_BACKLOG
Netty based messaging: Sets the backlog value to specify when the channel binds to a local address
|
static String |
STORM_MESSAGING_TRANSPORT
The transporter for communication among Storm tasks
|
static String |
STORM_META_SERIALIZATION_DELEGATE
The delegate for serializing metadata, should be used for serialized objects stored in zookeeper and on disk.
|
static String |
STORM_METRICS_REPORTERS |
static String |
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 |
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 |
STORM_NETWORK_TOPOGRAPHY_PLUGIN
What Network Topography detection classes should we use.
|
static String |
STORM_NIMBUS_RETRY_INTERVAL
The starting interval between exponential backoff retries of a Nimbus operation.
|
static String |
STORM_NIMBUS_RETRY_INTERVAL_CEILING
The ceiling of the interval between retries of a client connect to Nimbus operation.
|
static String |
STORM_NIMBUS_RETRY_TIMES
The number of times to retry a Nimbus operation.
|
static String |
STORM_NIMBUS_ZOOKEEPER_ACLS_CHECK
In nimbus on startup check if all of the zookeeper ACLs are correct before starting.
|
static String |
STORM_NIMBUS_ZOOKEEPER_ACLS_FIXUP
In nimbus on startup check if all of the zookeeper ACLs are correct before starting.
|
static String |
STORM_PRINCIPAL_TO_LOCAL_PLUGIN
The plugin that will convert a principal to a local user.
|
static String |
STORM_SCHEDULER
A global task scheduler used to assign topologies’s tasks to supervisors’ workers.
|
static String |
STORM_THRIFT_SOCKET_TIMEOUT_MS
How long before a Thrift Client socket hangs before timeout and restart the socket.
|
static String |
STORM_THRIFT_TRANSPORT_PLUGIN
The default transport plug-in for Thrift client/server communication
|
static String |
STORM_TOPOLOGY_SUBMISSION_NOTIFIER_PLUGIN
FQCN of a class that implements
ISubmitterHook @see ISubmitterHook for details. |
static String |
STORM_WORKER_DISRUPTOR_FLUSHER_MAX_POOL_SIZE
This is a config that is not likely to be used.
|
static String |
STORM_WORKERS_ARTIFACTS_DIR
The workers-artifacts directory (where we place all workers’ logs), can be either absolute or relative.
|
static String |
STORM_ZOOKEEPER_AUTH_PAYLOAD
A string representing the payload for cluster Zookeeper authentication.
|
static String |
STORM_ZOOKEEPER_AUTH_SCHEME
The cluster Zookeeper authentication scheme to use, e.g.
|
static String |
STORM_ZOOKEEPER_CONNECTION_TIMEOUT
The connection timeout for clients to ZooKeeper.
|
static String |
STORM_ZOOKEEPER_PORT
The port Storm will use to connect to each of the ZooKeeper servers.
|
static String |
STORM_ZOOKEEPER_RETRY_INTERVAL
The interval between retries of a Zookeeper operation.
|
static String |
STORM_ZOOKEEPER_RETRY_INTERVAL_CEILING
The ceiling of the interval between retries of a Zookeeper operation.
|
static String |
STORM_ZOOKEEPER_RETRY_TIMES
The number of times to retry a Zookeeper operation.
|
static String |
STORM_ZOOKEEPER_ROOT
The root location at which Storm stores data in ZooKeeper.
|
static String |
STORM_ZOOKEEPER_SERVERS
A list of hosts of ZooKeeper servers used to manage the cluster.
|
static String |
STORM_ZOOKEEPER_SESSION_TIMEOUT
The session timeout for clients to ZooKeeper.
|
static String |
STORM_ZOOKEEPER_SUPERACL
This is part of a temporary workaround to a ZK bug, it is the ‘scheme:acl’ for the user Nimbus and Supervisors use to authenticate with ZK.
|
static String |
STORM_ZOOKEEPER_TOPOLOGY_AUTH_PAYLOAD
A string representing the payload for topology Zookeeper authentication.
|
static String |
STORM_ZOOKEEPER_TOPOLOGY_AUTH_SCHEME
The topology Zookeeper authentication scheme to use, e.g.
|
static String |
SUPERVISOR_BLOBSTORE
What blobstore implementation the supervisor should use.
|
static String |
SUPERVISOR_BLOBSTORE_DOWNLOAD_MAX_RETRIES
Maximum number of retries a supervisor is allowed to make for downloading a blob.
|
static String |
SUPERVISOR_BLOBSTORE_DOWNLOAD_THREAD_COUNT
What blobstore download parallelism the supervisor should use.
|
static String |
SUPERVISOR_CHILDOPTS
This parameter is used by the storm-deploy project to configure the jvm options for the supervisor daemon.
|
static String |
SUPERVISOR_CPU_CAPACITY
The total amount of CPU resources a supervisor is allowed to give to its workers.
|
static String |
SUPERVISOR_ENABLE
Whether or not the supervisor should launch workers assigned to it.
|
static String |
SUPERVISOR_HEARTBEAT_FREQUENCY_SECS
how often the supervisor sends a heartbeat to the master.
|
static String |
SUPERVISOR_LOCALIZER_CACHE_CLEANUP_INTERVAL_MS
The distributed cache cleanup interval.
|
static String |
SUPERVISOR_LOCALIZER_CACHE_TARGET_SIZE_MB
The distributed cache target size in MB.
|
static String |
SUPERVISOR_MEMORY_CAPACITY_MB
The total amount of memory (in MiB) a supervisor is allowed to give to its workers.
|
static String |
SUPERVISOR_MONITOR_FREQUENCY_SECS
How often the supervisor checks the worker heartbeats to see if any of them need to be restarted.
|
static String |
SUPERVISOR_RUN_WORKER_AS_USER
Should the supervior try to run the worker as the lauching user or not.
|
static String |
SUPERVISOR_SCHEDULER_META
the metadata configured on the supervisor
|
static String |
SUPERVISOR_SLOTS_PORTS
A list of ports that can run workers on this supervisor.
|
static String |
SUPERVISOR_WORKER_LAUNCHER
Full path to the worker-laucher executable that will be used to lauch workers when SUPERVISOR_RUN_WORKER_AS_USER is set to true.
|
static String |
SUPERVISOR_WORKER_SHUTDOWN_SLEEP_SECS
How many seconds to sleep for before shutting down threads on worker
|
static String |
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 |
SUPERVISOR_WORKER_TIMEOUT_SECS
How long a worker can go without heartbeating before the supervisor tries to restart the worker process.
|
static String |
TASK_BACKPRESSURE_POLL_SECS
How often to poll for changed topology backpressure flag from ZK
|
static String |
TASK_CREDENTIALS_POLL_SECS
How often a task should sync credentials, worst case.
|
static String |
TASK_HEARTBEAT_FREQUENCY_SECS
How often a task should heartbeat its status to the master.
|
static String |
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 |
TOPOLOGY_ACKER_EXECUTORS
How many executors to spawn for ackers.
|
static String |
TOPOLOGY_AUTO_CREDENTIALS
A list of IAutoCredentials that the topology should load and use.
|
static String |
TOPOLOGY_AUTO_TASK_HOOKS
A list of task hooks that are automatically added to every spout and bolt in the topology.
|
static String |
TOPOLOGY_BACKPRESSURE_ENABLE
Whether to enable backpressure in for a certain topology
|
static String |
TOPOLOGY_BLOBSTORE_MAP
A map with blobstore keys mapped to each filename the worker will have access to in the launch directory to the blob by local file name and uncompress flag.
|
static String |
TOPOLOGY_BOLTS_LATE_TUPLE_STREAM
Bolt-specific configuration for windowed bolts to specify the name of the stream on which late tuples are going to be emitted.
|
static String |
TOPOLOGY_BOLTS_MESSAGE_ID_FIELD_NAME |
static String |
TOPOLOGY_BOLTS_OUTGOING_OVERFLOW_BUFFER_ENABLE |
static String |
TOPOLOGY_BOLTS_SLIDING_INTERVAL_COUNT |
static String |
TOPOLOGY_BOLTS_SLIDING_INTERVAL_DURATION_MS |
static String |
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 |
TOPOLOGY_BOLTS_WATERMARK_EVENT_INTERVAL_MS |
static String |
TOPOLOGY_BOLTS_WINDOW_LENGTH_COUNT |
static String |
TOPOLOGY_BOLTS_WINDOW_LENGTH_DURATION_MS |
static String |
TOPOLOGY_BUILTIN_METRICS_BUCKET_SIZE_SECS
The time period that builtin metrics data in bucketed into.
|
static String |
TOPOLOGY_CLASSPATH
Topology-specific classpath for the worker child process.
|
static String |
TOPOLOGY_COMPONENT_CPU_PCORE_PERCENT
The config indicates the percentage of cpu for a core an instance(executor) of a component will use.
|
static String |
TOPOLOGY_COMPONENT_RESOURCES_OFFHEAP_MEMORY_MB
The maximum amount of memory an instance of a spout/bolt will take off heap.
|
static String |
TOPOLOGY_COMPONENT_RESOURCES_ONHEAP_MEMORY_MB
The maximum amount of memory an instance of a spout/bolt will take on heap.
|
static String |
TOPOLOGY_DEBUG
When set to true, Storm will log every message that’s emitted.
|
static String |
TOPOLOGY_DISABLE_LOADAWARE_MESSAGING
Disable load aware grouping support.
|
static String |
TOPOLOGY_DISRUPTOR_BATCH_SIZE
The number of tuples to batch before sending to the next thread.
|
static String |
TOPOLOGY_DISRUPTOR_BATCH_TIMEOUT_MILLIS
The maximum age in milliseconds a batch can be before being sent to the next thread.
|
static String |
TOPOLOGY_DISRUPTOR_WAIT_STRATEGY
Deprecated.
this is no longer supported Configure the wait strategy used for internal queuing. Can be used to tradeoff latency vs. throughput
|
static String |
TOPOLOGY_DISRUPTOR_WAIT_TIMEOUT_MILLIS
Configure timeout milliseconds used for disruptor queue wait strategy.
|
static String |
TOPOLOGY_ENABLE_MESSAGE_TIMEOUTS
True if Storm should timeout messages or not.
|
static String |
TOPOLOGY_ENVIRONMENT
Topology-specific environment variables for the worker child process.
|
static String |
TOPOLOGY_ERROR_THROTTLE_INTERVAL_SECS
The interval in seconds to use for determining whether to throttle error reported to Zookeeper.
|
static String |
TOPOLOGY_EVENT_LOGGER_REGISTER
A list of classes implementing IEventLogger (See storm.yaml.example for exact config format).
|
static String |
TOPOLOGY_EVENTLOGGER_EXECUTORS
How many executors to spawn for event logger.
|
static String |
TOPOLOGY_EXECUTOR_RECEIVE_BUFFER_SIZE
The size of the Disruptor receive queue for each executor.
|
static String |
TOPOLOGY_EXECUTOR_SEND_BUFFER_SIZE
The size of the Disruptor send queue for each executor.
|
static String |
TOPOLOGY_FALL_BACK_ON_JAVA_SERIALIZATION
Whether or not to use Java serialization in a topology.
|
static String |
TOPOLOGY_GROUPS
A list of groups that are allowed to interact with the topology.
|
static String |
TOPOLOGY_ISOLATED_MACHINES
The number of machines that should be used by this topology to isolate it from all others.
|
static String |
TOPOLOGY_KRYO_DECORATORS
A list of classes that customize storm’s kryo instance during start-up.
|
static String |
TOPOLOGY_KRYO_FACTORY
Class that specifies how to create a Kryo instance for serialization.
|
static String |
TOPOLOGY_KRYO_REGISTER
A list of serialization registrations for Kryo ( https://github.com/EsotericSoftware/kryo ), the underlying serialization framework for Storm.
|
static String |
TOPOLOGY_LOGGING_SENSITIVITY
Topology central logging sensitivity to determine who has access to logs in central logging system.
|
static String |
TOPOLOGY_MAX_ERROR_REPORT_PER_INTERVAL
See doc for TOPOLOGY_ERROR_THROTTLE_INTERVAL_SECS
|
static String |
TOPOLOGY_MAX_REPLICATION_WAIT_TIME_SEC
Maximum wait time for the nimbus host replication to achieve the nimbus.min.replication.count.
|
static String |
TOPOLOGY_MAX_SPOUT_PENDING
The maximum number of tuples that can be pending on a spout task at any given time.
|
static String |
TOPOLOGY_MAX_TASK_PARALLELISM
The maximum parallelism allowed for a component in this topology.
|
static String |
TOPOLOGY_MESSAGE_TIMEOUT_SECS
The maximum amount of time given to the topology to fully process a message emitted by a spout.
|
static String |
TOPOLOGY_METRICS_CONSUMER_REGISTER
A list of classes implementing IMetricsConsumer (See storm.yaml.example for exact config format).
|
static String |
TOPOLOGY_MIN_REPLICATION_COUNT
Minimum number of nimbus hosts where the code must be replicated before leader nimbus is allowed to perform topology activation tasks like setting up heartbeats/assignments and marking the topology as active.
|
static String |
TOPOLOGY_MULTILANG_LOG_HANDLER
The fully qualified name of a
ShellLogHandler to handle output from non-JVM processes e.g. |
static String |
TOPOLOGY_MULTILANG_SERIALIZER
The serializer for communication between shell components and non-JVM processes
|
static String |
TOPOLOGY_NAME
Name of the topology.
|
static String |
TOPOLOGY_PRIORITY
Sets the priority for a topology
|
static String |
TOPOLOGY_SCHEDULER_STRATEGY
The strategy to use when scheduling a topology with Resource Aware Scheduler
|
static String |
TOPOLOGY_SHELLBOLT_MAX_PENDING
Max pending tuples in one ShellBolt
|
static String |
TOPOLOGY_SKIP_MISSING_KRYO_REGISTRATIONS
Whether or not Storm should skip the loading of kryo registrations for which it does not know the class or have the serializer implementation.
|
static String |
TOPOLOGY_SLEEP_SPOUT_WAIT_STRATEGY_TIME_MS
The amount of milliseconds the SleepEmptyEmitStrategy should sleep for.
|
static String |
TOPOLOGY_SPOUT_WAIT_STRATEGY
A class that implements a strategy for what to do when a spout needs to wait.
|
static String |
TOPOLOGY_SPREAD_COMPONENTS
Array of components that scheduler should try to place on separate hosts.
|
static String |
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 |
TOPOLOGY_STATE_PROVIDER
The class name of the
StateProvider implementation. |
static String |
TOPOLOGY_STATE_PROVIDER_CONFIG
The configuration specific to the
StateProvider implementation. |
static String |
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 |
TOPOLOGY_STATS_SAMPLE_RATE
The percentage of tuples to sample to produce stats for a task.
|
static String |
TOPOLOGY_SUBMITTER_PRINCIPAL
The principal who submitted a topology
|
static String |
TOPOLOGY_SUBMITTER_USER
The local user name of the user who submitted a topology.
|
static String |
TOPOLOGY_SUBPROCESS_TIMEOUT_SECS
How long a subprocess can go without heartbeating before the ShellSpout/ShellBolt tries to suicide itself.
|
static String |
TOPOLOGY_TASKS
How many instances to create for a spout/bolt.
|
static String |
TOPOLOGY_TESTING_ALWAYS_TRY_SERIALIZE
Try to serialize all tuples, even for local transfers.
|
static String |
TOPOLOGY_TICK_TUPLE_FREQ_SECS
How often a tick tuple from the “_system“ component and ”_tick” stream should be sent to tasks.
|
static String |
TOPOLOGY_TRANSACTIONAL_ID
This config is available for TransactionalSpouts, and contains the id ( a String) for the transactional topology.
|
static String |
TOPOLOGY_TRANSFER_BUFFER_SIZE
The size of the Disruptor transfer queue for each worker.
|
static String |
TOPOLOGY_TRIDENT_BATCH_EMIT_INTERVAL_MILLIS
How often a batch can be emitted in a Trident topology.
|
static String |
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 |
TOPOLOGY_TUPLE_SERIALIZER
The serializer class for ListDelegate (tuple payload).
|
static String |
TOPOLOGY_USERS
A list of users that are allowed to interact with the topology.
|
static String |
TOPOLOGY_WORKER_CHILDOPTS
Topology-specific options for the worker child process.
|
static String |
TOPOLOGY_WORKER_GC_CHILDOPTS
Topology-specific options GC for the worker child process.
|
static String |
TOPOLOGY_WORKER_LOGWRITER_CHILDOPTS
Topology-specific options for the logwriter process of a worker.
|
static String |
TOPOLOGY_WORKER_MAX_HEAP_SIZE_MB
A per topology config that specifies the maximum amount of memory a worker can use for that specific topology
|
static String |
TOPOLOGY_WORKER_METRICS
A map of metric name to class name implementing IMetric that will be created once per worker JVM
|
static String |
TOPOLOGY_WORKER_SHARED_THREAD_POOL_SIZE
The size of the shared thread pool for worker tasks to make use of.
|
static String |
TOPOLOGY_WORKERS
How many processes should be spawned around the cluster to execute this topology.
|
static String |
TRANSACTIONAL_ZOOKEEPER_PORT
The port to use to connect to the transactional zookeeper servers.
|
static String |
TRANSACTIONAL_ZOOKEEPER_ROOT
The root directory in ZooKeeper for metadata about TransactionalSpouts.
|
static String |
TRANSACTIONAL_ZOOKEEPER_SERVERS
The list of zookeeper servers in which to keep the transactional state.
|
static String |
UI_CENTRAL_LOGGING_URL
Storm UI Central Logging URL.
|
static String |
UI_CHILDOPTS
Childopts for Storm UI Java process.
|
static String |
UI_FILTER
A class implementing javax.servlet.Filter for authenticating/filtering UI requests
|
static String |
UI_FILTER_PARAMS
Initialization parameters for the javax.servlet.Filter
|
static String |
UI_HEADER_BUFFER_BYTES
The size of the header buffer for the UI in bytes
|
static String |
UI_HOST
Storm UI binds to this host/interface.
|
static String |
UI_HTTP_CREDS_PLUGIN
Class name of the HTTP credentials plugin for the UI.
|
static String |
UI_HTTP_X_FRAME_OPTIONS
Value of X-FRAME-OPTIONS HTTP Header option used by Storm UI.
|
static String |
UI_HTTPS_KEY_PASSWORD
Password to the private key in the keystore for setting up HTTPS (SSL).
|
static String |
UI_HTTPS_KEYSTORE_PASSWORD
Password to the keystore used by Storm UI for setting up HTTPS (SSL).
|
static String |
UI_HTTPS_KEYSTORE_PATH
Path to the keystore used by Storm UI for setting up HTTPS (SSL).
|
static String |
UI_HTTPS_KEYSTORE_TYPE
Type of keystore used by Storm UI for setting up HTTPS (SSL).
|
static String |
UI_HTTPS_NEED_CLIENT_AUTH |
static String |
UI_HTTPS_PORT
This port is used by Storm DRPC for receiving HTTPS (SSL) DPRC requests from clients.
|
static String |
UI_HTTPS_TRUSTSTORE_PASSWORD
Password to the truststore used by Storm UI setting up HTTPS (SSL).
|
static String |
UI_HTTPS_TRUSTSTORE_PATH
Path to the truststore used by Storm UI setting up HTTPS (SSL).
|
static String |
UI_HTTPS_TRUSTSTORE_TYPE
Type of truststore used by Storm UI for setting up HTTPS (SSL).
|
static String |
UI_HTTPS_WANT_CLIENT_AUTH
Password to the truststore used by Storm DRPC setting up HTTPS (SSL).
|
static String |
UI_PAGINATION
Storm UI drop-down pagination value.
|
static String |
UI_PORT
Storm UI binds to this port.
|
static String |
UI_PROJECT_BUGTRACKER_URL
Storm UI Project BUGTRACKER Link for reporting issue.
|
static String |
WORKER_CHILDOPTS
The jvm opts provided to workers launched by this supervisor.
|
static String |
WORKER_GC_CHILDOPTS
The jvm opts provided to workers launched by this supervisor for GC.
|
static String |
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 |
WORKER_HEARTBEAT_FREQUENCY_SECS
How often this worker should heartbeat to the supervisor.
|
static String |
WORKER_LOG_LEVEL_RESET_POLL_SECS
How often a worker should check dynamic log level timeouts for expiration.
|
static String |
WORKER_METRICS
A map of metric name to class name implementing IMetric that will be created once per worker JVM
|
static String |
WORKER_PROFILER_CHILDOPTS
The jvm profiler opts provided to workers launched by this supervisor.
|
static String |
WORKER_PROFILER_COMMAND
The command launched supervisor with worker arguments pid, action and [target_directory] Where action is - start profile, stop profile, jstack, heapdump and kill against pid
|
static String |
WORKER_PROFILER_ENABLED
Enable profiling of worker JVMs using Oracle’s Java Flight Recorder.
|
static String |
ZMQ_HWM
Deprecated.
|
static String |
ZMQ_LINGER_MILLIS
Deprecated.
|
static String |
ZMQ_THREADS
Deprecated.
|
Constructor and Description |
---|
Config() |
Modifier and Type | Method and Description |
---|---|
void |
registerDecorator(Class<? extends IKryoDecorator> klass) |
static void |
registerDecorator(Map conf,
Class<? extends IKryoDecorator> klass) |
void |
registerEventLogger(Class<? extends IEventLogger> klass) |
void |
registerEventLogger(Class<? extends IEventLogger> klass,
Map<String,Object> argument) |
static void |
registerEventLogger(Map<String,Object> conf,
Class<? extends IEventLogger> klass) |
static void |
registerEventLogger(Map<String,Object> conf,
Class<? extends IEventLogger> klass,
Map<String,Object> argument) |
void |
registerMetricsConsumer(Class klass) |
void |
registerMetricsConsumer(Class klass,
long parallelismHint) |
void |
registerMetricsConsumer(Class klass,
Object argument,
long parallelismHint) |
static void |
registerMetricsConsumer(Map conf,
Class klass) |
static void |
registerMetricsConsumer(Map conf,
Class klass,
long parallelismHint) |
static void |
registerMetricsConsumer(Map conf,
Class klass,
Object argument,
long parallelismHint) |
void |
registerSerialization(Class klass) |
void |
registerSerialization(Class klass,
Class<? extends com.esotericsoftware.kryo.Serializer> serializerClass) |
static void |
registerSerialization(Map conf,
Class klass) |
static void |
registerSerialization(Map conf,
Class klass,
Class<? extends com.esotericsoftware.kryo.Serializer> serializerClass) |
static void |
setClasspath(Map conf,
String cp) |
void |
setClasspath(String cp) |
void |
setDebug(boolean isOn) |
static void |
setDebug(Map conf,
boolean isOn) |
void |
setEnvironment(Map env) |
static void |
setEnvironment(Map conf,
Map env) |
void |
setFallBackOnJavaSerialization(boolean fallback) |
static void |
setFallBackOnJavaSerialization(Map conf,
boolean fallback) |
void |
setKryoFactory(Class<? extends IKryoFactory> klass) |
static void |
setKryoFactory(Map conf,
Class<? extends IKryoFactory> klass) |
void |
setMaxSpoutPending(int max) |
static void |
setMaxSpoutPending(Map conf,
int max) |
void |
setMaxTaskParallelism(int max) |
static void |
setMaxTaskParallelism(Map conf,
int max) |
void |
setMessageTimeoutSecs(int secs) |
static void |
setMessageTimeoutSecs(Map conf,
int secs) |
void |
setNumAckers(int numExecutors) |
static void |
setNumAckers(Map conf,
int numExecutors) |
void |
setNumEventLoggers(int numExecutors) |
static void |
setNumEventLoggers(Map conf,
int numExecutors) |
void |
setNumWorkers(int workers) |
static void |
setNumWorkers(Map conf,
int workers) |
void |
setSkipMissingKryoRegistrations(boolean skip) |
static void |
setSkipMissingKryoRegistrations(Map conf,
boolean skip) |
void |
setStatsSampleRate(double rate) |
static void |
setStatsSampleRate(Map conf,
double rate) |
void |
setTopologyPriority(int priority)
set the priority for a topology
|
void |
setTopologyStrategy(Class<? extends IStrategy> clazz)
Takes as input the strategy class name.
|
void |
setTopologyWorkerMaxHeapSize(Number size)
set the max heap size allow per worker for this topology
|
clear, clone, compute, computeIfAbsent, computeIfPresent, containsKey, containsValue, entrySet, forEach, get, getOrDefault, isEmpty, keySet, merge, put, putAll, putIfAbsent, remove, remove, replace, replace, replaceAll, size, values
equals, hashCode, toString
public static final String STORM_NIMBUS_ZOOKEEPER_ACLS_CHECK
In nimbus on startup check if all of the zookeeper ACLs are correct before starting. If not don’t start nimbus.
public static final String STORM_NIMBUS_ZOOKEEPER_ACLS_FIXUP
In nimbus on startup check if all of the zookeeper ACLs are correct before starting. If not do your best to fix them before nimbus starts, if it cannot fix them nimbus will not start. This overrides any value set for storm.nimbus.zookeeper.acls.check.
public static final String STORM_ZOOKEEPER_SUPERACL
This is part of a temporary workaround to a ZK bug, it is the ‘scheme:acl’ for the user Nimbus and Supervisors use to authenticate with ZK.
public static final String STORM_MESSAGING_TRANSPORT
The transporter for communication among Storm tasks
public static final String STORM_MESSAGING_NETTY_BUFFER_SIZE
Netty based messaging: The buffer size for send/recv buffer
public static final String STORM_MESSAGING_NETTY_SOCKET_BACKLOG
Netty based messaging: Sets the backlog value to specify when the channel binds to a local address
@Deprecated public static final String STORM_MESSAGING_NETTY_MAX_RETRIES
Netty based messaging: The max # of retries that a peer will perform when a remote is not accessible
public static final String STORM_MESSAGING_NETTY_MIN_SLEEP_MS
Netty based messaging: The min # of milliseconds that a peer will wait.
public static final String STORM_MESSAGING_NETTY_MAX_SLEEP_MS
Netty based messaging: The max # of milliseconds that a peer will wait.
public static final String STORM_MESSAGING_NETTY_SERVER_WORKER_THREADS
Netty based messaging: The # of worker threads for the server.
public static final String STORM_MESSAGING_NETTY_CLIENT_WORKER_THREADS
Netty based messaging: The # of worker threads for the client.
public static final String 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
public static final String STORM_NETTY_FLUSH_CHECK_INTERVAL_MS
We check with this interval that whether the Netty channel is writable and try to write pending messages
public static final String STORM_MESSAGING_NETTY_AUTHENTICATION
Netty based messaging: Is authentication required for Netty messaging from client worker process to server worker process.
public static final String STORM_META_SERIALIZATION_DELEGATE
The delegate for serializing metadata, should be used for serialized objects stored in zookeeper and on disk. This is NOT used for compressing serialized tuples sent between topologies.
public static final String STORM_METRICS_REPORTERS
public static final String STORM_DAEMON_METRICS_REPORTER_PLUGINS
A list of daemon metrics reporter plugin class names. These plugins must implement PreparableReporter
interface.
public static final String STORM_DAEMON_METRICS_REPORTER_PLUGIN_LOCALE
A specify Locale for daemon metrics reporter plugin. Use the specified IETF BCP 47 language tag string for a Locale.
public static final String STORM_DAEMON_METRICS_REPORTER_PLUGIN_DOMAIN
A specify domain for daemon metrics reporter plugin to limit reporting to specific domain.
public static final String STORM_DAEMON_METRICS_REPORTER_PLUGIN_RATE_UNIT
A specify rate-unit in TimeUnit to specify reporting frequency for daemon metrics reporter plugin.
public static final String STORM_DAEMON_METRICS_REPORTER_PLUGIN_DURATION_UNIT
A specify duration-unit in TimeUnit to specify reporting window for daemon metrics reporter plugin.
public static final String STORM_DAEMON_METRICS_REPORTER_CSV_LOG_DIR
A specify csv reporter directory for CvsPreparableReporter daemon metrics reporter.
public static final String STORM_ZOOKEEPER_SERVERS
A list of hosts of ZooKeeper servers used to manage the cluster.
public static final String STORM_ZOOKEEPER_PORT
The port Storm will use to connect to each of the ZooKeeper servers.
public static final String STORM_EXHIBITOR_SERVERS
A list of hosts of Exhibitor servers used to discover/maintain connection to ZooKeeper cluster. Any configured ZooKeeper servers will be used for the curator/exhibitor backup connection string.
public static final String STORM_EXHIBITOR_PORT
The port Storm will use to connect to each of the exhibitor servers.
public static final String STORM_LOCAL_DIR
A directory on the local filesystem used by Storm for any local filesystem usage it needs. The directory must exist and the Storm daemons must have permission to read/write from this location. It could be either absolute or relative. If the setting is a relative directory, it is relative to root directory of Storm installation.
public static final String STORM_LOG4J2_CONF_DIR
A directory that holds configuration files for log4j2. It can be either a relative or an absolute directory. If relative, it is relative to the storm’s home directory.
public static final String STORM_SCHEDULER
A global task scheduler used to assign topologies’s tasks to supervisors’ workers.
If this is not set, a default system scheduler will be used.
public static final String SCHEDULER_DISPLAY_RESOURCE
Whether we want to display all the resource capacity and scheduled usage on the UI page. We suggest to have this variable set if you are using any kind of resource-related scheduler.
If this is not set, we will not display resource capacity and usage on the UI.
public static final String STORM_CLUSTER_MODE
The mode this Storm cluster is running in. Either “distributed” or “local”.
public static final String STORM_NETWORK_TOPOGRAPHY_PLUGIN
What Network Topography detection classes should we use. Given a list of supervisor hostnames (or IP addresses), this class would return a list of rack names that correspond to the supervisors. This information is stored in Cluster.java, and is used in the resource aware scheduler.
public static final String STORM_LOCAL_HOSTNAME
The hostname the supervisors/workers should report to nimbus. If unset, Storm will get the hostname to report by calling InetAddress.getLocalHost().getCanonicalHostName()
.
You should set this config when you don’t have a DNS which supervisors/workers can utilize to find each other based on hostname got from calls to InetAddress.getLocalHost().getCanonicalHostName()
.
public static final String STORM_PRINCIPAL_TO_LOCAL_PLUGIN
The plugin that will convert a principal to a local user.
public static final String STORM_GROUP_MAPPING_SERVICE_PROVIDER_PLUGIN
The plugin that will provide user groups service
public static final String STORM_GROUP_MAPPING_SERVICE_CACHE_DURATION_SECS
Max no.of seconds group mapping service will cache user groups
public static final String STORM_GROUP_MAPPING_SERVICE_PARAMS
Initialization parameters for the group mapping service plugin. Provides a way for a @link{STORM_GROUP_MAPPING_SERVICE_PROVIDER_PLUGIN} implementation to access optional settings.
public static final String STORM_THRIFT_TRANSPORT_PLUGIN
The default transport plug-in for Thrift client/server communication
public static final String TOPOLOGY_TUPLE_SERIALIZER
The serializer class for ListDelegate (tuple payload). The default serializer will be ListDelegateSerializer
public static final String TOPOLOGY_DISABLE_LOADAWARE_MESSAGING
Disable load aware grouping support.
public static final String TOPOLOGY_TESTING_ALWAYS_TRY_SERIALIZE
Try to serialize all tuples, even for local transfers. This should only be used for testing, as a sanity check that all of your tuples are setup properly.
public static final String STORM_LOCAL_MODE_ZMQ
Whether or not to use ZeroMQ for messaging in local mode. If this is set to false, then Storm will use a pure-Java messaging system. The purpose of this flag is to make it easy to run Storm in local mode by eliminating the need for native dependencies, which can be difficult to install. Defaults to false.
public static final String STORM_ZOOKEEPER_ROOT
The root location at which Storm stores data in ZooKeeper.
public static final String STORM_ZOOKEEPER_SESSION_TIMEOUT
The session timeout for clients to ZooKeeper.
public static final String STORM_ZOOKEEPER_CONNECTION_TIMEOUT
The connection timeout for clients to ZooKeeper.
public static final String STORM_ZOOKEEPER_RETRY_TIMES
The number of times to retry a Zookeeper operation.
public static final String STORM_ZOOKEEPER_RETRY_INTERVAL
The interval between retries of a Zookeeper operation.
public static final String STORM_ZOOKEEPER_RETRY_INTERVAL_CEILING
The ceiling of the interval between retries of a Zookeeper operation.
public static final String STORM_ZOOKEEPER_AUTH_SCHEME
The cluster Zookeeper authentication scheme to use, e.g. “digest”. Defaults to no authentication.
public static final String STORM_ZOOKEEPER_AUTH_PAYLOAD
A string representing the payload for cluster Zookeeper authentication. It gets serialized using UTF-8 encoding during authentication. Note that if this is set to something with a secret (as when using digest authentication) then it should only be set in the storm-cluster-auth.yaml file. This file storm-cluster-auth.yaml should then be protected with appropriate permissions that deny access from workers.
public static final String STORM_ZOOKEEPER_TOPOLOGY_AUTH_SCHEME
The topology Zookeeper authentication scheme to use, e.g. “digest”. It is the internal config and user shouldn’t set it.
public static final String STORM_ZOOKEEPER_TOPOLOGY_AUTH_PAYLOAD
A string representing the payload for topology Zookeeper authentication. It gets serialized using UTF-8 encoding during authentication.
public static final String STORM_EXHIBITOR_URIPATH
public static final String STORM_EXHIBITOR_POLL
How often to poll Exhibitor cluster in millis.
public static final String STORM_EXHIBITOR_RETRY_TIMES
The number of times to retry an Exhibitor operation.
public static final String STORM_EXHIBITOR_RETRY_INTERVAL
The interval between retries of an Exhibitor operation.
public static final String STORM_EXHIBITOR_RETRY_INTERVAL_CEILING
The ceiling of the interval between retries of an Exhibitor operation.
public static final String STORM_ID
The id assigned to a running topology. The id is the storm name with a unique nonce appended.
public static final String STORM_WORKERS_ARTIFACTS_DIR
The workers-artifacts directory (where we place all workers’ logs), can be either absolute or relative. By default, ${storm.log.dir}/workers-artifacts is where worker logs go. If the setting is a relative directory, it is relative to storm.log.dir.
public static final String STORM_HEALTH_CHECK_DIR
The directory where storm’s health scripts go.
public static final String STORM_HEALTH_CHECK_TIMEOUT_MS
The time to allow any given healthcheck script to run before it is marked failed due to timeout
public static final String STORM_NIMBUS_RETRY_TIMES
The number of times to retry a Nimbus operation.
public static final String STORM_NIMBUS_RETRY_INTERVAL
The starting interval between exponential backoff retries of a Nimbus operation.
public static final String STORM_NIMBUS_RETRY_INTERVAL_CEILING
The ceiling of the interval between retries of a client connect to Nimbus operation.
public static final String STORM_CLUSTER_STATE_STORE
The ClusterState factory that worker will use to create a ClusterState to store state in. Defaults to ZooKeeper.
public static final String NIMBUS_THRIFT_TRANSPORT_PLUGIN
The Nimbus transport plug-in for Thrift client/server communication
public static final String STORM_THRIFT_SOCKET_TIMEOUT_MS
How long before a Thrift Client socket hangs before timeout and restart the socket.
@Deprecated public static final String NIMBUS_HOST
The host that the master server is running on, added only for backward compatibility, the usage deprecated in favor of nimbus.seeds config.
public static final String NIMBUS_SEEDS
List of seed nimbus hosts to use for leader nimbus discovery.
public static final String NIMBUS_THRIFT_PORT
Which port the Thrift interface of Nimbus should run on. Clients should connect to this port to upload jars and submit topologies.
public static final String NIMBUS_THRIFT_THREADS
The number of threads that should be used by the nimbus thrift server.
public static final String NIMBUS_ADMINS
A list of users that are cluster admins and can run any command. To use this set nimbus.authorizer to org.apache.storm.security.auth.authorizer.SimpleACLAuthorizer
public static final String NIMBUS_USERS
A list of users that are the only ones allowed to run user operation on storm cluster. To use this set nimbus.authorizer to org.apache.storm.security.auth.authorizer.SimpleACLAuthorizer
public static final String NIMBUS_GROUPS
A list of groups , users belong to these groups are the only ones allowed to run user operation on storm cluster. To use this set nimbus.authorizer to org.apache.storm.security.auth.authorizer.SimpleACLAuthorizer
public static final String NIMBUS_SUPERVISOR_USERS
A list of users that run the supervisors and should be authorized to interact with nimbus as a supervisor would. To use this set nimbus.authorizer to org.apache.storm.security.auth.authorizer.SimpleACLAuthorizer
public static final String NIMBUS_DAEMON_USER
This is the user that the Nimbus daemon process is running as. May be used when security is enabled to authorize actions in the cluster.
@Deprecated public static final String NIMBUS_THRIFT_MAX_BUFFER_SIZE
The maximum buffer size thrift should use when reading messages.
public static final String NIMBUS_CHILDOPTS
This parameter is used by the storm-deploy project to configure the jvm options for the nimbus daemon.
public static final String 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.
public static final String NIMBUS_MONITOR_FREQ_SECS
How often nimbus should wake up to check heartbeats and do reassignments. Note that if a machine ever goes down Nimbus will immediately wake up and take action. This parameter is for checking for failures when there’s no explicit event like that occurring.
public static final String NIMBUS_CLEANUP_INBOX_FREQ_SECS
How often nimbus should wake the cleanup thread to clean the inbox.
public static final String NIMBUS_INBOX_JAR_EXPIRATION_SECS
The length of time a jar file lives in the inbox before being deleted by the cleanup thread.
Probably keep this value greater than or equal to NIMBUS_CLEANUP_INBOX_JAR_EXPIRATION_SECS. Note that the time it takes to delete an inbox jar file is going to be somewhat more than NIMBUS_CLEANUP_INBOX_JAR_EXPIRATION_SECS (depending on how often NIMBUS_CLEANUP_FREQ_SECS is set to).
public static final String 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.
public static final String NIMBUS_TASK_LAUNCH_SECS
A special timeout used when a task is initially launched. During launch, this is the timeout used until the first heartbeat, overriding nimbus.task.timeout.secs.
A separate timeout exists for launch because there can be quite a bit of overhead to launching new JVM's and configuring them.
public static final String 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.
public static final String NIMBUS_TOPOLOGY_VALIDATOR
A custom class that implements ITopologyValidator that is run whenever a topology is submitted. Can be used to provide business-specific logic for whether topologies are allowed to run or not.
public static final String NIMBUS_AUTHORIZER
Class name for authorization plugin for Nimbus
public static final String NIMBUS_IMPERSONATION_AUTHORIZER
Impersonation user ACL config entries.
public static final String NIMBUS_IMPERSONATION_ACL
Impersonation user ACL config entries.
public static final String NIMBUS_CREDENTIAL_RENEW_FREQ_SECS
How often nimbus should wake up to renew credentials if needed.
public static final String NIMBUS_CREDENTIAL_RENEWERS
A list of credential renewers that nimbus should load.
public static final String NIMBUS_AUTO_CRED_PLUGINS
A list of plugins that nimbus should load during submit topology to populate credentials on user’s behalf.
public static final String NIMBUS_QUEUE_SIZE
Nimbus thrift server queue size, default is 100000. This is the request queue size , when there are more requests than number of threads to serve the requests, those requests will be queued to this queue. If the request queue size > this config, then the incoming requests will be rejected.
public static final String STORM_TOPOLOGY_SUBMISSION_NOTIFIER_PLUGIN
FQCN of a class that implements ISubmitterHook
@see ISubmitterHook for details.
public static final String NIMBUS_TOPOLOGY_ACTION_NOTIFIER_PLUGIN
FQCN of a class that implements I
@see org.apache.storm.nimbus.ITopologyActionNotifierPlugin for details.
public static final Object NIMBUS_TOPOLOGY_ACTION_NOTIFIER_PLUGIN_SCHEMA
public static final String UI_HOST
Storm UI binds to this host/interface.
public static final String UI_PORT
Storm UI binds to this port.
public static final String UI_PROJECT_BUGTRACKER_URL
Storm UI Project BUGTRACKER Link for reporting issue.
public static final String UI_CENTRAL_LOGGING_URL
Storm UI Central Logging URL.
public static final String UI_PAGINATION
Storm UI drop-down pagination value. Set ui.pagination to be a positive integer or -1 (displays all entries). Valid values: -1, 10, 20, 25 etc.
public static final String LOGVIEWER_PORT
HTTP UI port for log viewer
public static final String LOGVIEWER_CHILDOPTS
Childopts for log viewer java process.
public static final String LOGVIEWER_CLEANUP_INTERVAL_SECS
How often to clean up old log files
public static final String LOGVIEWER_CLEANUP_AGE_MINS
How many minutes since a log was last modified for the log to be considered for clean-up
public static final String LOGVIEWER_MAX_SUM_WORKER_LOGS_SIZE_MB
The maximum number of bytes all worker log files can take up in MB
public static final String LOGVIEWER_MAX_PER_WORKER_LOGS_SIZE_MB
The maximum number of bytes per worker’s files can take up in MB
public static final String LOGVIEWER_HTTPS_PORT
Storm Logviewer HTTPS port
public static final String LOGVIEWER_HTTPS_KEYSTORE_PATH
Path to the keystore containing the certs used by Storm Logviewer for HTTPS communications
public static final String LOGVIEWER_HTTPS_KEYSTORE_PASSWORD
Password for the keystore for HTTPS for Storm Logviewer
public static final String LOGVIEWER_HTTPS_KEYSTORE_TYPE
Type of the keystore for HTTPS for Storm Logviewer. see http://docs.oracle.com/javase/8/docs/api/java/security/KeyStore.html for more details.
public static final String LOGVIEWER_HTTPS_KEY_PASSWORD
Password to the private key in the keystore for setting up HTTPS (SSL).
public static final String LOGVIEWER_HTTPS_TRUSTSTORE_PATH
Path to the truststore containing the certs used by Storm Logviewer for HTTPS communications
public static final String LOGVIEWER_HTTPS_TRUSTSTORE_PASSWORD
Password for the truststore for HTTPS for Storm Logviewer
public static final String LOGVIEWER_HTTPS_TRUSTSTORE_TYPE
Type of the truststore for HTTPS for Storm Logviewer. see http://docs.oracle.com/javase/8/docs/api/java/security/Truststore.html for more details.
public static final String LOGVIEWER_HTTPS_WANT_CLIENT_AUTH
Password to the truststore used by Storm Logviewer setting up HTTPS (SSL).
public static final String LOGVIEWER_HTTPS_NEED_CLIENT_AUTH
public static final String LOGS_USERS
A list of users allowed to view logs via the Log Viewer
public static final String LOGS_GROUPS
A list of groups allowed to view logs via the Log Viewer
public static final String LOGVIEWER_APPENDER_NAME
Appender name used by log viewer to determine log directory.
public static final String UI_CHILDOPTS
Childopts for Storm UI Java process.
public static final String UI_FILTER
A class implementing javax.servlet.Filter for authenticating/filtering UI requests
public static final String UI_FILTER_PARAMS
Initialization parameters for the javax.servlet.Filter
public static final String UI_HEADER_BUFFER_BYTES
The size of the header buffer for the UI in bytes
public static final String UI_HTTPS_PORT
This port is used by Storm DRPC for receiving HTTPS (SSL) DPRC requests from clients.
public static final String UI_HTTPS_KEYSTORE_PATH
Path to the keystore used by Storm UI for setting up HTTPS (SSL).
public static final String UI_HTTPS_KEYSTORE_PASSWORD
Password to the keystore used by Storm UI for setting up HTTPS (SSL).
public static final String UI_HTTPS_KEYSTORE_TYPE
Type of keystore used by Storm UI for setting up HTTPS (SSL). see http://docs.oracle.com/javase/7/docs/api/java/security/KeyStore.html for more details.
public static final String UI_HTTPS_KEY_PASSWORD
Password to the private key in the keystore for setting up HTTPS (SSL).
public static final String UI_HTTPS_TRUSTSTORE_PATH
Path to the truststore used by Storm UI setting up HTTPS (SSL).
public static final String UI_HTTPS_TRUSTSTORE_PASSWORD
Password to the truststore used by Storm UI setting up HTTPS (SSL).
public static final String UI_HTTPS_TRUSTSTORE_TYPE
Type of truststore used by Storm UI for setting up HTTPS (SSL). see http://docs.oracle.com/javase/7/docs/api/java/security/KeyStore.html for more details.
public static final String UI_HTTPS_WANT_CLIENT_AUTH
Password to the truststore used by Storm DRPC setting up HTTPS (SSL).
public static final String UI_HTTPS_NEED_CLIENT_AUTH
public static final String UI_HTTP_X_FRAME_OPTIONS
Value of X-FRAME-OPTIONS HTTP Header option used by Storm UI.
public static final String PACEMAKER_SERVERS
The hosts that Pacemaker is running on.
@Deprecated public static final String PACEMAKER_HOST
The host that Pacemaker is running on.
public static final String PACEMAKER_PORT
The port Pacemaker should run on. Clients should connect to this port to submit or read heartbeats.
public static final String PACEMAKER_MAX_THREADS
The maximum number of threads that should be used by the Pacemaker. When Pacemaker gets loaded it will spawn new threads, up to this many total, to handle the load.
public static final String PACEMAKER_CHILDOPTS
This parameter is used by the storm-deploy project to configure the jvm options for the pacemaker daemon.
public static final String PACEMAKER_AUTH_METHOD
This should be one of “DIGEST”, “KERBEROS”, or “NONE” Determines the mode of authentication the pacemaker server and client use. The client must either match the server, or be NONE. In the case of NONE, no authentication is performed for the client, and if the server is running with DIGEST or KERBEROS, the client can only write to the server (no reads). This is intended to provide a primitive form of access-control.
public static final String DRPC_SERVERS
List of DRPC servers so that the DRPCSpout knows who to talk to.
public static final String DRPC_HTTP_PORT
This port is used by Storm DRPC for receiving HTTP DPRC requests from clients.
public static final String DRPC_HTTPS_PORT
This port is used by Storm DRPC for receiving HTTPS (SSL) DPRC requests from clients.
public static final String DRPC_HTTPS_KEYSTORE_PATH
Path to the keystore used by Storm DRPC for setting up HTTPS (SSL).
public static final String DRPC_HTTPS_KEYSTORE_PASSWORD
Password to the keystore used by Storm DRPC for setting up HTTPS (SSL).
public static final String DRPC_HTTPS_KEYSTORE_TYPE
Type of keystore used by Storm DRPC for setting up HTTPS (SSL). see http://docs.oracle.com/javase/7/docs/api/java/security/KeyStore.html for more details.
public static final String DRPC_HTTPS_KEY_PASSWORD
Password to the private key in the keystore for setting up HTTPS (SSL).
public static final String DRPC_HTTPS_TRUSTSTORE_PATH
Path to the truststore used by Storm DRPC setting up HTTPS (SSL).
public static final String DRPC_HTTPS_TRUSTSTORE_PASSWORD
Password to the truststore used by Storm DRPC setting up HTTPS (SSL).
public static final String DRPC_HTTPS_TRUSTSTORE_TYPE
Type of truststore used by Storm DRPC for setting up HTTPS (SSL). see http://docs.oracle.com/javase/7/docs/api/java/security/KeyStore.html for more details.
public static final String DRPC_HTTPS_WANT_CLIENT_AUTH
Password to the truststore used by Storm DRPC setting up HTTPS (SSL).
public static final String DRPC_HTTPS_NEED_CLIENT_AUTH
public static final String DRPC_THRIFT_TRANSPORT_PLUGIN
The DRPC transport plug-in for Thrift client/server communication
public static final String DRPC_PORT
This port is used by Storm DRPC for receiving DPRC requests from clients.
public static final String DRPC_AUTHORIZER
Class name for authorization plugin for DRPC client
public static final String DRPC_AUTHORIZER_ACL
The Access Control List for the DRPC Authorizer.
DRPCSimpleACLAuthorizer
,
Constant Field Valuespublic static final String DRPC_AUTHORIZER_ACL_FILENAME
File name of the DRPC Authorizer ACL.
DRPCSimpleACLAuthorizer
,
Constant Field Valuespublic static final String DRPC_AUTHORIZER_ACL_STRICT
Whether the DRPCSimpleAclAuthorizer should deny requests for operations involving functions that have no explicit ACL entry. When set to false (the default) DRPC functions that have no entry in the ACL will be permitted, which is appropriate for a development environment. When set to true, explicit ACL entries are required for every DRPC function, and any request for functions will be denied.
DRPCSimpleACLAuthorizer
,
Constant Field Valuespublic static final String DRPC_WORKER_THREADS
DRPC thrift server worker threads
@Deprecated public static final String DRPC_MAX_BUFFER_SIZE
The maximum buffer size thrift should use when reading messages for DRPC.
public static final String DRPC_QUEUE_SIZE
DRPC thrift server queue size
public static final String DRPC_INVOCATIONS_THRIFT_TRANSPORT_PLUGIN
The DRPC invocations transport plug-in for Thrift client/server communication
public static final String DRPC_INVOCATIONS_PORT
This port on Storm DRPC is used by DRPC topologies to receive function invocations and send results back.
public static final String DRPC_INVOCATIONS_THREADS
DRPC invocations thrift server worker threads
public static final String DRPC_REQUEST_TIMEOUT_SECS
The timeout on DRPC requests within the DRPC server. Defaults to 10 minutes. Note that requests can also timeout based on the socket timeout on the DRPC client, and separately based on the topology message timeout for the topology implementing the DRPC function.
public static final String DRPC_CHILDOPTS
Childopts for Storm DRPC Java process.
public static final String UI_HTTP_CREDS_PLUGIN
Class name of the HTTP credentials plugin for the UI.
public static final String DRPC_HTTP_CREDS_PLUGIN
Class name of the HTTP credentials plugin for DRPC.
public static final String SUPERVISOR_SCHEDULER_META
the metadata configured on the supervisor
public static final String SUPERVISOR_SLOTS_PORTS
A list of ports that can run workers on this supervisor. Each worker uses one port, and the supervisor will only run one worker per port. Use this configuration to tune how many workers run on each machine.
public static final String SUPERVISOR_BLOBSTORE
What blobstore implementation the supervisor should use.
public static final String SUPERVISOR_LOCALIZER_CACHE_TARGET_SIZE_MB
The distributed cache target size in MB. This is a soft limit to the size of the distributed cache contents.
public static final String SUPERVISOR_LOCALIZER_CACHE_CLEANUP_INTERVAL_MS
The distributed cache cleanup interval. Controls how often it scans to attempt to cleanup anything over the cache target size.
public static final String CLIENT_BLOBSTORE
What blobstore implementation the storm client should use.
public static final String SUPERVISOR_BLOBSTORE_DOWNLOAD_THREAD_COUNT
What blobstore download parallelism the supervisor should use.
public static final String SUPERVISOR_BLOBSTORE_DOWNLOAD_MAX_RETRIES
Maximum number of retries a supervisor is allowed to make for downloading a blob.
public static final String BLOBSTORE_SUPERUSER
The blobstore super user has all read/write/admin permissions to all blobs - user running the blobstore.
public static final String BLOBSTORE_DIR
What directory to use for the blobstore. The directory is expected to be an absolute path when using HDFS blobstore, for LocalFsBlobStore it could be either absolute or relative. If the setting is a relative directory, it is relative to root directory of Storm installation.
public static final String STORM_BLOBSTORE_INPUTSTREAM_BUFFER_SIZE_BYTES
What buffer size to use for the blobstore uploads.
public static final String BLOBSTORE_CLEANUP_ENABLE
Enable the blobstore cleaner. Certain blobstores may only want to run the cleaner on one daemon. Currently Nimbus handles setting this.
public static final String BLOBSTORE_HDFS_PRINCIPAL
principal for nimbus/supervisor to use to access secure hdfs for the blobstore.
public static final String BLOBSTORE_HDFS_KEYTAB
keytab for nimbus/supervisor to use to access secure hdfs for the blobstore.
public static final String STORM_BLOBSTORE_REPLICATION_FACTOR
Set replication factor for a blob in HDFS Blobstore Implementation
public static final String STORM_BLOBSTORE_ACL_VALIDATION_ENABLED
For secure mode we would want to turn on this config By default this is turned off assuming the default is insecure
public static final String NIMBUS_BLOBSTORE
What blobstore implementation nimbus should use.
public static final String 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.
public static final String TOPOLOGY_BLOBSTORE_MAP
A map with blobstore keys mapped to each filename the worker will have access to in the launch directory to the blob by local file name and uncompress flag. Both localname and uncompress flag are optional. It uses the key is localname is not specified. Each topology will have different map of blobs. Example: topology.blobstore.map: {“blobstorekey” : {“localname”: “myblob”, “uncompress”: false}, “blobstorearchivekey” : {“localname”: “myarchive”, “uncompress”: true}}
public static final String NIMBUS_SLOTS_PER_TOPOLOGY
A number representing the maximum number of workers any single topology can acquire.
public static final String DRPC_HTTP_FILTER
A class implementing javax.servlet.Filter for DRPC HTTP requests
public static final String DRPC_HTTP_FILTER_PARAMS
Initialization parameters for the javax.servlet.Filter of the DRPC HTTP service
public static final String NIMBUS_EXECUTORS_PER_TOPOLOGY
A number representing the maximum number of executors any single topology can acquire.
public static final String SUPERVISOR_CHILDOPTS
This parameter is used by the storm-deploy project to configure the jvm options for the supervisor daemon.
public static final String SUPERVISOR_WORKER_TIMEOUT_SECS
How long a worker can go without heartbeating before the supervisor tries to restart the worker process.
public static final String SUPERVISOR_WORKER_SHUTDOWN_SLEEP_SECS
How many seconds to sleep for before shutting down threads on worker
public static final String 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. This value override supervisor.worker.timeout.secs during launch because there is additional overhead to starting and configuring the JVM on launch.
public static final String SUPERVISOR_ENABLE
Whether or not the supervisor should launch workers assigned to it. Defaults to true – and you should probably never change this value. This configuration is used in the Storm unit tests.
public static final String SUPERVISOR_HEARTBEAT_FREQUENCY_SECS
how often the supervisor sends a heartbeat to the master.
public static final String SUPERVISOR_MONITOR_FREQUENCY_SECS
How often the supervisor checks the worker heartbeats to see if any of them need to be restarted.
public static final String SUPERVISOR_RUN_WORKER_AS_USER
Should the supervior try to run the worker as the lauching user or not. Defaults to false.
public static final String SUPERVISOR_WORKER_LAUNCHER
Full path to the worker-laucher executable that will be used to lauch workers when SUPERVISOR_RUN_WORKER_AS_USER is set to true.
public static final String SUPERVISOR_MEMORY_CAPACITY_MB
The total amount of memory (in MiB) a supervisor is allowed to give to its workers. A default value will be set for this config if user does not override
public static final String SUPERVISOR_CPU_CAPACITY
The total amount of CPU resources a supervisor is allowed to give to its workers. By convention 1 cpu core should be about 100, but this can be adjusted if needed using 100 makes it simple to set the desired value to the capacity measurement for single threaded bolts. A default value will be set for this config if user does not override
public static final String DISABLE_SYMLINKS
On some systems (windows for example) symlinks require special privileges that not everyone wants to grant a headless user. You can completely disable the use of symlinks by setting this config to true, but by doing so you may also lose some features from storm. For example the blobstore feature does not currently work without symlinks enabled.
public static final String WORKER_CHILDOPTS
The jvm opts provided to workers launched by this supervisor. All “%ID%”, “%WORKER-ID%”, “%TOPOLOGY-ID%”, “%WORKER-PORT%” and “%HEAP-MEM%” substrings are replaced with: %ID% -> port (for backward compatibility), %WORKER-ID% -> worker-id, %TOPOLOGY-ID% -> topology-id, %WORKER-PORT% -> port. %HEAP-MEM% -> mem-onheap.
public static final String WORKER_HEAP_MEMORY_MB
The default heap memory size in MB per worker, used in the jvm -Xmx opts for launching the worker
public static final String WORKER_PROFILER_CHILDOPTS
The jvm profiler opts provided to workers launched by this supervisor.
public static final String WORKER_PROFILER_ENABLED
Enable profiling of worker JVMs using Oracle’s Java Flight Recorder. Unlocking commercial features requires a special license from Oracle. See http://www.oracle.com/technetwork/java/javase/terms/products/index.html
public static final String WORKER_PROFILER_COMMAND
The command launched supervisor with worker arguments pid, action and [target_directory] Where action is - start profile, stop profile, jstack, heapdump and kill against pid
public static final String WORKER_GC_CHILDOPTS
The jvm opts provided to workers launched by this supervisor for GC. All “%ID%” substrings are replaced with an identifier for this worker. Because the JVM complains about multiple GC opts the topology can override this default value by setting topology.worker.gc.childopts.
public static final String WORKER_HEARTBEAT_FREQUENCY_SECS
How often this worker should heartbeat to the supervisor.
public static final String TASK_HEARTBEAT_FREQUENCY_SECS
How often a task should heartbeat its status to the master.
public static final String 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). In general though, when a reassignment happens other tasks will be notified almost immediately. This configuration is here just in case that notification doesn’t come through.
public static final String WORKER_LOG_LEVEL_RESET_POLL_SECS
How often a worker should check dynamic log level timeouts for expiration. For expired logger settings, the clean up polling task will reset the log levels to the original levels (detected at startup), and will clean up the timeout map
public static final String TASK_CREDENTIALS_POLL_SECS
How often a task should sync credentials, worst case.
public static final String TASK_BACKPRESSURE_POLL_SECS
How often to poll for changed topology backpressure flag from ZK
public static final String TOPOLOGY_BACKPRESSURE_ENABLE
Whether to enable backpressure in for a certain topology
public static final String BACKPRESSURE_DISRUPTOR_HIGH_WATERMARK
This signifies the tuple congestion in a disruptor queue. When the used ratio of a disruptor queue is higher than the high watermark, the backpressure scheme, if enabled, should slow down the tuple sending speed of the spouts until reaching the low watermark.
public static final String BACKPRESSURE_DISRUPTOR_LOW_WATERMARK
This signifies a state that a disruptor queue has left the congestion. If the used ratio of a disruptor queue is lower than the low watermark, it will unset the backpressure flag.
public static final String BACKPRESSURE_ZNODE_TIMEOUT_SECS
How long until the backpressure znode is invalid. It’s measured by the data (timestamp) of the znode, not the ctime (creation time) or mtime (modification time), etc. This must be larger than BACKPRESSURE_ZNODE_UPDATE_FREQ_SECS.
public static final String BACKPRESSURE_ZNODE_UPDATE_FREQ_SECS
How often will the data (timestamp) of backpressure znode be updated. But if the worker backpressure status (on/off) changes, the znode will be updated anyway.
public static final String STORM_CLUSTER_METRICS_CONSUMER_REGISTER
A list of classes implementing IClusterMetricsConsumer (See storm.yaml.example for exact config format). Each listed class will be routed cluster related metrics data. Each listed class maps 1:1 to a ClusterMetricsConsumerExecutor and they’re executed in Nimbus. Only consumers which run in leader Nimbus receives metrics data.
public static final String STORM_CLUSTER_METRICS_CONSUMER_PUBLISH_INTERVAL_SECS
How often cluster metrics data is published to metrics consumer.
public static final String TOPOLOGY_USERS
A list of users that are allowed to interact with the topology. To use this set nimbus.authorizer to org.apache.storm.security.auth.authorizer.SimpleACLAuthorizer
public static final String TOPOLOGY_GROUPS
A list of groups that are allowed to interact with the topology. To use this set nimbus.authorizer to org.apache.storm.security.auth.authorizer.SimpleACLAuthorizer
public static final String TOPOLOGY_ENABLE_MESSAGE_TIMEOUTS
True if Storm should timeout messages or not. Defaults to true. This is meant to be used in unit tests to prevent tuples from being accidentally timed out during the test.
public static final String TOPOLOGY_DEBUG
When set to true, Storm will log every message that’s emitted.
public static final String TOPOLOGY_MULTILANG_LOG_HANDLER
The fully qualified name of a ShellLogHandler
to handle output from non-JVM processes e.g. “com.mycompany.CustomShellLogHandler”. If not provided, org.apache.storm.utils.DefaultLogHandler will be used.
public static final String TOPOLOGY_MULTILANG_SERIALIZER
The serializer for communication between shell components and non-JVM processes
public static final String TOPOLOGY_WORKERS
How many processes should be spawned around the cluster to execute this topology. Each process will execute some number of tasks as threads within them. This parameter should be used in conjunction with the parallelism hints on each component in the topology to tune the performance of a topology.
public static final String TOPOLOGY_TASKS
How many instances to create for a spout/bolt. A task runs on a thread with zero or more other tasks for the same spout/bolt. The number of tasks for a spout/bolt is always the same throughout the lifetime of a topology, but the number of executors (threads) for a spout/bolt can change over time. This allows a topology to scale to more or less resources without redeploying the topology or violating the constraints of Storm (such as a fields grouping guaranteeing that the same value goes to the same task).
public static final String TOPOLOGY_COMPONENT_RESOURCES_ONHEAP_MEMORY_MB
The maximum amount of memory an instance of a spout/bolt will take on heap. This enables the scheduler to allocate slots on machines with enough available memory. A default value will be set for this config if user does not override
public static final String TOPOLOGY_COMPONENT_RESOURCES_OFFHEAP_MEMORY_MB
The maximum amount of memory an instance of a spout/bolt will take off heap. This enables the scheduler to allocate slots on machines with enough available memory. A default value will be set for this config if user does not override
public static final String TOPOLOGY_COMPONENT_CPU_PCORE_PERCENT
The config indicates the percentage of cpu for a core an instance(executor) of a component will use. Assuming the a core value to be 100, a value of 10 indicates 10% of the core. The P in PCORE represents the term “physical”. A default value will be set for this config if user does not override
public static final String TOPOLOGY_STATE_PROVIDER
The class name of the StateProvider
implementation. If not specified defaults to InMemoryKeyValueStateProvider
. This can be overridden at the component level.
public static final String TOPOLOGY_STATE_PROVIDER_CONFIG
The configuration specific to the StateProvider
implementation. This can be overridden at the component level. The value and the interpretation of this config is based on the state provider implementation. For e.g. this could be just a config file name which contains the config for the state provider implementation.
public static final String 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.
public static final String TOPOLOGY_WORKER_MAX_HEAP_SIZE_MB
A per topology config that specifies the maximum amount of memory a worker can use for that specific topology
public static final String TOPOLOGY_SCHEDULER_STRATEGY
The strategy to use when scheduling a topology with Resource Aware Scheduler
public static final String TOPOLOGY_ACKER_EXECUTORS
How many executors to spawn for ackers.
By not setting this variable or setting it as null, Storm will set the number of acker executors to be equal to the number of workers configured for this topology. If this variable is set to 0, then Storm will immediately ack tuples as soon as they come off the spout, effectively disabling reliability.
public static final String TOPOLOGY_EVENT_LOGGER_REGISTER
A list of classes implementing IEventLogger (See storm.yaml.example for exact config format). Each listed class will be routed all the events sampled from emitting tuples. If there’s no class provided to the option, default event logger will be initialized and used unless you disable event logger executor.
Note that EventLoggerBolt takes care of all the implementations of IEventLogger, hence registering many implementations (especially they’re implemented as ‘blocking’ manner) would slow down overall topology.
public static final String TOPOLOGY_EVENTLOGGER_EXECUTORS
How many executors to spawn for event logger.
By not setting this variable or setting it as null, Storm will set the number of eventlogger executors to be equal to the number of workers configured for this topology. If this variable is set to 0, event logging will be disabled.
public static final String TOPOLOGY_MESSAGE_TIMEOUT_SECS
The maximum amount of time given to the topology to fully process a message emitted by a spout. If the message is not acked within this time frame, Storm will fail the message on the spout. Some spouts implementations will then replay the message at a later time.
public static final String TOPOLOGY_KRYO_REGISTER
A list of serialization registrations for Kryo ( https://github.com/EsotericSoftware/kryo ), the underlying serialization framework for Storm. A serialization can either be the name of a class (in which case Kryo will automatically create a serializer for the class that saves all the object’s fields), or an implementation of com.esotericsoftware.kryo.Serializer.
See Kryo’s documentation for more information about writing custom serializers.
public static final String TOPOLOGY_KRYO_DECORATORS
A list of classes that customize storm’s kryo instance during start-up. Each listed class name must implement IKryoDecorator. During start-up the listed class is instantiated with 0 arguments, then its ‘decorate’ method is called with storm’s kryo instance as the only argument.
public static final String TOPOLOGY_KRYO_FACTORY
Class that specifies how to create a Kryo instance for serialization. Storm will then apply topology.kryo.register and topology.kryo.decorators on top of this. The default implementation implements topology.fall.back.on.java.serialization and turns references off.
public static final String TOPOLOGY_SKIP_MISSING_KRYO_REGISTRATIONS
Whether or not Storm should skip the loading of kryo registrations for which it does not know the class or have the serializer implementation. Otherwise, the task will fail to load and will throw an error at runtime. The use case of this is if you want to declare your serializations on the storm.yaml files on the cluster rather than every single time you submit a topology. Different applications may use different serializations and so a single application may not have the code for the other serializers used by other apps. By setting this config to true, Storm will ignore that it doesn’t have those other serializations rather than throw an error.
public static final String TOPOLOGY_METRICS_CONSUMER_REGISTER
A list of classes implementing IMetricsConsumer (See storm.yaml.example for exact config format). Each listed class will be routed all the metrics data generated by the storm metrics API. Each listed class maps 1:1 to a system bolt named __metrics_ClassName#N, and it’s parallelism is configurable.
public static final String TOPOLOGY_WORKER_METRICS
A map of metric name to class name implementing IMetric that will be created once per worker JVM
public static final String WORKER_METRICS
A map of metric name to class name implementing IMetric that will be created once per worker JVM
public static final String TOPOLOGY_MAX_TASK_PARALLELISM
The maximum parallelism allowed for a component in this topology. This configuration is typically used in testing to limit the number of threads spawned in local mode.
public static final String TOPOLOGY_MAX_SPOUT_PENDING
The maximum number of tuples that can be pending on a spout task at any given time. This config applies to individual tasks, not to spouts or topologies as a whole.
A pending tuple is one that has been emitted from a spout but has not been acked or failed yet. Note that this config parameter has no effect for unreliable spouts that don’t tag their tuples with a message id.
public static final String TOPOLOGY_SPOUT_WAIT_STRATEGY
A class that implements a strategy for what to do when a spout needs to wait. Waiting is triggered in one of two conditions:
public static final String TOPOLOGY_SLEEP_SPOUT_WAIT_STRATEGY_TIME_MS
The amount of milliseconds the SleepEmptyEmitStrategy should sleep for.
public static final String TOPOLOGY_STATE_SYNCHRONIZATION_TIMEOUT_SECS
The maximum amount of time a component gives a source of state to synchronize before it requests synchronization again.
public static final String TOPOLOGY_STATS_SAMPLE_RATE
The percentage of tuples to sample to produce stats for a task.
public static final String TOPOLOGY_BUILTIN_METRICS_BUCKET_SIZE_SECS
The time period that builtin metrics data in bucketed into.
public static final String TOPOLOGY_FALL_BACK_ON_JAVA_SERIALIZATION
Whether or not to use Java serialization in a topology.
public static final String TOPOLOGY_WORKER_CHILDOPTS
Topology-specific options for the worker child process. This is used in addition to WORKER_CHILDOPTS.
public static final String TOPOLOGY_WORKER_GC_CHILDOPTS
Topology-specific options GC for the worker child process. This overrides WORKER_GC_CHILDOPTS.
public static final String TOPOLOGY_WORKER_LOGWRITER_CHILDOPTS
Topology-specific options for the logwriter process of a worker.
public static final String TOPOLOGY_CLASSPATH
Topology-specific classpath for the worker child process. This is combined to the usual classpath.
public static final String TOPOLOGY_ENVIRONMENT
Topology-specific environment variables for the worker child process. This is added to the existing environment (that of the supervisor)
public static final String TOPOLOGY_BOLTS_OUTGOING_OVERFLOW_BUFFER_ENABLE
public static final String TOPOLOGY_BOLTS_WINDOW_LENGTH_COUNT
public static final String TOPOLOGY_BOLTS_WINDOW_LENGTH_DURATION_MS
public static final String TOPOLOGY_BOLTS_SLIDING_INTERVAL_COUNT
public static final String TOPOLOGY_BOLTS_SLIDING_INTERVAL_DURATION_MS
public static final String TOPOLOGY_BOLTS_LATE_TUPLE_STREAM
Bolt-specific configuration for windowed bolts to specify the name of the stream on which late tuples are going to be emitted. This configuration should only be used from the BaseWindowedBolt.withLateTupleStream builder method, and not as global parameter, otherwise IllegalArgumentException is going to be thrown.
public static final String 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. It means that the tuple timestamps cannot be out of order by more than this amount. This config will be effective only if TimestampExtractor
is specified.
public static final String TOPOLOGY_BOLTS_WATERMARK_EVENT_INTERVAL_MS
public static final String TOPOLOGY_BOLTS_MESSAGE_ID_FIELD_NAME
public static final String TOPOLOGY_TRANSACTIONAL_ID
This config is available for TransactionalSpouts, and contains the id ( a String) for the transactional topology. This id is used to store the state of the transactional topology in Zookeeper.
public static final String TOPOLOGY_AUTO_TASK_HOOKS
A list of task hooks that are automatically added to every spout and bolt in the topology. An example of when you’d do this is to add a hook that integrates with your internal monitoring system. These hooks are instantiated using the zero-arg constructor.
public static final String TOPOLOGY_EXECUTOR_RECEIVE_BUFFER_SIZE
The size of the Disruptor receive queue for each executor. Must be a power of 2.
public static final String TOPOLOGY_EXECUTOR_SEND_BUFFER_SIZE
The size of the Disruptor send queue for each executor. Must be a power of 2.
public static final String TOPOLOGY_TRANSFER_BUFFER_SIZE
The size of the Disruptor transfer queue for each worker.
public static final String TOPOLOGY_TICK_TUPLE_FREQ_SECS
How often a tick tuple from the “_system“ component and ”_tick” stream should be sent to tasks. Meant to be used as a component-specific configuration.
@Deprecated public static final String TOPOLOGY_DISRUPTOR_WAIT_STRATEGY
public static final String TOPOLOGY_WORKER_SHARED_THREAD_POOL_SIZE
The size of the shared thread pool for worker tasks to make use of. The thread pool can be accessed via the TopologyContext.
public static final String TOPOLOGY_ERROR_THROTTLE_INTERVAL_SECS
The interval in seconds to use for determining whether to throttle error reported to Zookeeper. For example, an interval of 10 seconds with topology.max.error.report.per.interval set to 5 will only allow 5 errors to be reported to Zookeeper per task for every 10 second interval of time.
public static final String TOPOLOGY_MAX_ERROR_REPORT_PER_INTERVAL
See doc for TOPOLOGY_ERROR_THROTTLE_INTERVAL_SECS
public static final String TOPOLOGY_TRIDENT_BATCH_EMIT_INTERVAL_MILLIS
How often a batch can be emitted in a Trident topology.
public static final String 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.
public static final String TOPOLOGY_NAME
Name of the topology. This config is automatically set by Storm when the topology is submitted.
public static final String TOPOLOGY_SUBMITTER_PRINCIPAL
The principal who submitted a topology
public static final String TOPOLOGY_SUBMITTER_USER
The local user name of the user who submitted a topology.
public static final String TOPOLOGY_SPREAD_COMPONENTS
Array of components that scheduler should try to place on separate hosts.
public static final String TOPOLOGY_AUTO_CREDENTIALS
A list of IAutoCredentials that the topology should load and use.
public static final String TOPOLOGY_SHELLBOLT_MAX_PENDING
Max pending tuples in one ShellBolt
public static final String TOPOLOGY_SUBPROCESS_TIMEOUT_SECS
How long a subprocess can go without heartbeating before the ShellSpout/ShellBolt tries to suicide itself.
public static final String TOPOLOGY_LOGGING_SENSITIVITY
Topology central logging sensitivity to determine who has access to logs in central logging system. The possible values are: S0 - Public (open to all users on grid) S1 - Restricted S2 - Confidential S3 - Secret (default.)
public static final String TOPOLOGY_PRIORITY
Sets the priority for a topology
public static final String TRANSACTIONAL_ZOOKEEPER_ROOT
The root directory in ZooKeeper for metadata about TransactionalSpouts.
public static final String TRANSACTIONAL_ZOOKEEPER_SERVERS
The list of zookeeper servers in which to keep the transactional state. If null (which is default), will use storm.zookeeper.servers
public static final String TRANSACTIONAL_ZOOKEEPER_PORT
The port to use to connect to the transactional zookeeper servers. If null (which is default), will use storm.zookeeper.port
public static final String STORM_DO_AS_USER
The user as which the nimbus client should be acquired to perform the operation.
@Deprecated public static final String ZMQ_THREADS
The number of threads that should be used by the zeromq context in each worker process.
@Deprecated public static final String ZMQ_LINGER_MILLIS
How long a connection should retry sending messages to a target host when the connection is closed. This is an advanced configuration and can almost certainly be ignored.
@Deprecated public static final String ZMQ_HWM
The high water for the ZeroMQ push sockets used for networking. Use this config to prevent buffer explosion on the networking layer.
public static final String JAVA_LIBRARY_PATH
This value is passed to spawned JVMs (e.g., Nimbus, Supervisor, and Workers) for the java.library.path value. java.library.path tells the JVM where to look for native libraries. It is necessary to set this config correctly since Storm uses the ZeroMQ and JZMQ native libs.
public static final String DEV_ZOOKEEPER_PATH
The path to use as the zookeeper dir when running a zookeeper server via “storm dev-zookeeper”. This zookeeper instance is only intended for development; it is not a production grade zookeeper setup.
public static final String ISOLATION_SCHEDULER_MACHINES
A map from topology name to the number of machines that should be dedicated for that topology. Set storm.scheduler to org.apache.storm.scheduler.IsolationScheduler to make use of the isolation scheduler.
public static final String MULTITENANT_SCHEDULER_USER_POOLS
A map from the user name to the number of machines that should that user is allowed to use. Set storm.scheduler to org.apache.storm.scheduler.multitenant.MultitenantScheduler
public static final String RESOURCE_AWARE_SCHEDULER_USER_POOLS
A map of users to another map of the resource guarantees of the user. Used by Resource Aware Scheduler to ensure per user resource guarantees.
public static final String RESOURCE_AWARE_SCHEDULER_EVICTION_STRATEGY
The class that specifies the eviction strategy to use in ResourceAwareScheduler
public static final String RESOURCE_AWARE_SCHEDULER_PRIORITY_STRATEGY
the class that specifies the scheduling priority strategy to use in ResourceAwareScheduler
public static final String TOPOLOGY_ISOLATED_MACHINES
The number of machines that should be used by this topology to isolate it from all others. Set storm.scheduler to org.apache.storm.scheduler.multitenant.MultitenantScheduler
public static final String TOPOLOGY_DISRUPTOR_WAIT_TIMEOUT_MILLIS
Configure timeout milliseconds used for disruptor queue wait strategy. Can be used to tradeoff latency vs. CPU usage
public static final String TOPOLOGY_DISRUPTOR_BATCH_SIZE
The number of tuples to batch before sending to the next thread. This number is just an initial suggestion and the code may adjust it as your topology runs.
public static final String TOPOLOGY_DISRUPTOR_BATCH_TIMEOUT_MILLIS
The maximum age in milliseconds a batch can be before being sent to the next thread. This number is just an initial suggestion and the code may adjust it as your topology runs.
public static final String TOPOLOGY_MIN_REPLICATION_COUNT
Minimum number of nimbus hosts where the code must be replicated before leader nimbus is allowed to perform topology activation tasks like setting up heartbeats/assignments and marking the topology as active. default is 0.
public static final String TOPOLOGY_MAX_REPLICATION_WAIT_TIME_SEC
Maximum wait time for the nimbus host replication to achieve the nimbus.min.replication.count. Once this time is elapsed nimbus will go ahead and perform topology activation tasks even if required nimbus.min.replication.count is not achieved. The default is 0 seconds, a value of -1 indicates to wait for ever.
public static final String NIMBUS_CODE_SYNC_FREQ_SECS
How often nimbus’s background thread to sync code for missing topologies should run.
public static final Object CLIENT_JAR_TRANSFORMER
An implementation of @{link org.apache.storm.daemon.JarTransformer} that will can be used to transform a jar file before storm jar runs with it. Use with extreme caution. If you want to enable a transition between org.apache.storm and org.apache.storm to run older topologies you can set this to org.apache.storm.hack.StormShadeTransformer. But this is likely to be deprecated in future releases.
public static final String STORM_WORKER_DISRUPTOR_FLUSHER_MAX_POOL_SIZE
This is a config that is not likely to be used. Internally the disruptor queue will batch entries written into the queue. A background thread pool will flush those batches if they get too old. By default that pool can grow rather large, and sacrifice some CPU time to keep the latency low. In some cases you may want the queue to be smaller so there is less CPU used, but the latency will increase in some situations. This configs is on a per cluster bases, if you want to control this on a per topology bases you need to set the java System property for the worker “num_flusher_pool_threads” to the value you want.
public void setClasspath(String cp)
public void setEnvironment(Map env)
public static void setDebug(Map conf, boolean isOn)
public void setDebug(boolean isOn)
public static void setNumWorkers(Map conf, int workers)
public void setNumWorkers(int workers)
public static void setNumAckers(Map conf, int numExecutors)
public void setNumAckers(int numExecutors)
public static void setNumEventLoggers(Map conf, int numExecutors)
public void setNumEventLoggers(int numExecutors)
public static void setMessageTimeoutSecs(Map conf, int secs)
public void setMessageTimeoutSecs(int secs)
public void registerSerialization(Class klass)
public static void registerSerialization(Map conf, Class klass, Class<? extends com.esotericsoftware.kryo.Serializer> serializerClass)
public void registerSerialization(Class klass, Class<? extends com.esotericsoftware.kryo.Serializer> serializerClass)
public void registerEventLogger(Class<? extends IEventLogger> klass, Map<String,Object> argument)
public void registerEventLogger(Class<? extends IEventLogger> klass)
public static void registerEventLogger(Map<String,Object> conf, Class<? extends IEventLogger> klass, Map<String,Object> argument)
public static void registerEventLogger(Map<String,Object> conf, Class<? extends IEventLogger> klass)
public static void registerMetricsConsumer(Map conf, Class klass, Object argument, long parallelismHint)
public void registerMetricsConsumer(Class klass, Object argument, long parallelismHint)
public static void registerMetricsConsumer(Map conf, Class klass, long parallelismHint)
public void registerMetricsConsumer(Class klass, long parallelismHint)
public void registerMetricsConsumer(Class klass)
public static void registerDecorator(Map conf, Class<? extends IKryoDecorator> klass)
public void registerDecorator(Class<? extends IKryoDecorator> klass)
public static void setKryoFactory(Map conf, Class<? extends IKryoFactory> klass)
public void setKryoFactory(Class<? extends IKryoFactory> klass)
public static void setSkipMissingKryoRegistrations(Map conf, boolean skip)
public void setSkipMissingKryoRegistrations(boolean skip)
public static void setMaxTaskParallelism(Map conf, int max)
public void setMaxTaskParallelism(int max)
public static void setMaxSpoutPending(Map conf, int max)
public void setMaxSpoutPending(int max)
public static void setStatsSampleRate(Map conf, double rate)
public void setStatsSampleRate(double rate)
public static void setFallBackOnJavaSerialization(Map conf, boolean fallback)
public void setFallBackOnJavaSerialization(boolean fallback)
public void setTopologyWorkerMaxHeapSize(Number size)
set the max heap size allow per worker for this topology
size
- public void setTopologyPriority(int priority)
set the priority for a topology
priority
- Copyright © 2019 The Apache Software Foundation. All Rights Reserved.