Uses of Annotation Type
org.apache.storm.validation.ConfigValidationAnnotations.IsInteger
Packages that use ConfigValidationAnnotations.IsInteger
-
Uses of ConfigValidationAnnotations.IsInteger in org.apache.storm
Fields in org.apache.storm with annotations of type ConfigValidationAnnotations.IsIntegerModifier and TypeFieldDescriptionstatic final String
DaemonConfig.DRPC_HTTP_PORT
This port is used by Storm DRPC for receiving HTTP DPRC requests from clients.static final String
DaemonConfig.DRPC_HTTPS_PORT
This port is used by Storm DRPC for receiving HTTPS (SSL) DPRC requests from clients.static final String
Config.DRPC_INVOCATIONS_PORT
This port on Storm DRPC is used by DRPC topologies to receive function invocations and send results back.static final String
Config.DRPC_INVOCATIONS_THREADS
DRPC invocations thrift server worker threads.static final String
Config.DRPC_PORT
This port is used by Storm DRPC for receiving DPRC requests from clients.static final String
Config.DRPC_QUEUE_SIZE
DRPC thrift server queue size.static final String
DaemonConfig.DRPC_REQUEST_TIMEOUT_SECS
The timeout on DRPC requests within the DRPC server.static final String
Config.DRPC_WORKER_THREADS
DRPC thrift server worker threads.static final String
How often executor metrics should report to master, used for RPC heartbeat mode.static final String
DaemonConfig.LOGVIEWER_CLEANUP_AGE_MINS
How many minutes since a log was last modified for the log to be considered for clean-up.static final String
DaemonConfig.LOGVIEWER_CLEANUP_INTERVAL_SECS
How often to clean up old log files.static final String
DaemonConfig.LOGVIEWER_HTTPS_PORT
Storm Logviewer HTTPS port.static final String
DaemonConfig.LOGVIEWER_PORT
HTTP UI port for log viewer.static final String
DaemonConfig.NIMBUS_ASSIGNMENTS_SERVICE_THREAD_QUEUE_SIZE
This controls the number of working thread queue size of assignment service.static final String
DaemonConfig.NIMBUS_ASSIGNMENTS_SERVICE_THREADS
This controls the number of working threads for distributing master assignments to supervisors.static final String
DaemonConfig.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 final String
DaemonConfig.NIMBUS_CLEANUP_INBOX_FREQ_SECS
How often nimbus should wake the cleanup thread to clean the inbox.static final String
DaemonConfig.NIMBUS_CODE_SYNC_FREQ_SECS
How often nimbus's background thread to sync code for missing topologies should run.static final String
DaemonConfig.NIMBUS_CREDENTIAL_RENEW_FREQ_SECS
How often nimbus should wake up to renew credentials if needed.static final String
DaemonConfig.NIMBUS_EXECUTORS_PER_TOPOLOGY
A number representing the maximum number of executors any single topology can acquire.static final String
DaemonConfig.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 final String
DaemonConfig.NIMBUS_INBOX_JAR_EXPIRATION_SECS
The length of time a jar file lives in the inbox before being deleted by the cleanup thread.static final String
DaemonConfig.NIMBUS_MONITOR_FREQ_SECS
How often nimbus should wake up to check heartbeats and do reassignments.static final String
Config.NIMBUS_QUEUE_SIZE
Nimbus thrift server queue size, default is 100000.static final String
DaemonConfig.NIMBUS_SLOTS_PER_TOPOLOGY
A number representing the maximum number of workers any single topology can acquire.static final String
DaemonConfig.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 final String
DaemonConfig.NIMBUS_TASK_LAUNCH_SECS
A special timeout used when a task is initially launched.static final String
DaemonConfig.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 final String
The maximum buffer size thrift should use when reading messages.static final String
Config.NIMBUS_THRIFT_PORT
Which port the Thrift interface of Nimbus should run on.static final String
Config.NIMBUS_THRIFT_THREADS
The number of threads that should be used by the nimbus thrift server.static final String
DaemonConfig.NIMBUS_TOPOLOGY_BLOBSTORE_DELETION_DELAY_MS
This controls the number of milliseconds nimbus will wait before deleting a topology blobstore once detected it is able to delete.static final String
Config.NUM_STAT_BUCKETS
The number of Buckets.static final String
Pacemaker Thrift Max Message Size (bytes).static final String
DaemonConfig.RESOURCE_AWARE_SCHEDULER_MAX_STATE_SEARCH
static final String
The maximum number of times that the RAS will attempt to schedule a topology.static final String
DaemonConfig.SCHEDULER_CONFIG_CACHE_EXPIRATION_SECS
How long before a scheduler considers its config cache expired.static final String
DaemonConfig.SCHEDULER_CONFIG_LOADER_POLLTIME_SECS
It is the frequency at which the plugin will call out to artifactory instead of returning the most recently cached result.static final String
DaemonConfig.SCHEDULER_CONFIG_LOADER_TIMEOUT_SECS
It is the amount of time an http connection to the artifactory server will wait before timing out.static final String
DaemonConfig.SCHEDULING_TIMEOUT_SECONDS_PER_TOPOLOGY
Max time to attempt to schedule one topology.static final String
What chunk size to use for storm client to upload dependency jars.static final String
What buffer size to use for the blobstore uploads.static final String
Set replication factor for a blob in HDFS Blobstore Implementation.static final String
DaemonConfig.STORM_DAEMON_METRICS_REPORTER_INTERVAL_SECS
We report the metrics with this interval period.static final String
Max no.of seconds group mapping service will cache user groupsstatic final String
Netty based messaging: The netty write buffer high watermark in bytes.static final String
Netty based messaging: The netty write buffer low watermark in bytes.static final String
Netty based messaging: The buffer size for send/recv buffer.static final String
Netty based messaging: The # of worker threads for the client.static final String
Netty based messaging: The max # of milliseconds that a peer will wait.static final String
Netty based messaging: The min # of milliseconds that a peer will wait.static final String
Netty based messaging: The # of worker threads for the server.static final String
Netty based messaging: Sets the backlog value to specify when the channel binds to a local address.static final String
DaemonConfig.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 final String
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 final String
DaemonConfig.STORM_OCI_LAYER_MOUNTS_TO_KEEP
Target count of OCI layer mounts that we should keep on disk at one time.static final String
DaemonConfig.STORM_ROCKSDB_METADATA_STRING_CACHE_CAPACITY
RocksDB metadata cache capacity.static final String
DaemonConfig.STORM_ROCKSDB_METRIC_DELETION_PERIOD_HOURS
RocksDB setting for period of metric deletion thread.static final String
DaemonConfig.STORM_ROCKSDB_METRIC_RETENTION_HOURS
RocksDB setting for length of metric retention.static final String
How long before a Thrift Client socket hangs before timeout and restart the socket.static final String
The connection timeout for clients to ZooKeeper.static final String
Config.STORM_ZOOKEEPER_PORT
The port Storm will use to connect to each of the ZooKeeper servers.static final String
The interval between retries of a Zookeeper operation.static final String
The ceiling of the interval between retries of a Zookeeper operation.static final String
Config.STORM_ZOOKEEPER_RETRY_TIMES
The number of times to retry a Zookeeper operation.static final String
The session timeout for clients to ZooKeeper.static final String
DaemonConfig.SUPERVISOR_BLOBSTORE_DOWNLOAD_MAX_RETRIES
Maximum number of retries a supervisor is allowed to make for downloading a blob.static final String
DaemonConfig.SUPERVISOR_BLOBSTORE_DOWNLOAD_THREAD_COUNT
What blobstore download parallelism the supervisor should use.static final String
DaemonConfig.SUPERVISOR_HEARTBEAT_FREQUENCY_SECS
how often the supervisor sends a heartbeat to the master.static final String
DaemonConfig.SUPERVISOR_LOCALIZER_CACHE_CLEANUP_INTERVAL_MS
The distributed cache cleanup interval.static final String
DaemonConfig.SUPERVISOR_LOCALIZER_CACHE_TARGET_SIZE_MB
The distributed cache target size in MB.static final String
DaemonConfig.SUPERVISOR_LOCALIZER_UPDATE_BLOB_INTERVAL_SECS
The distributed cache interval for checking for blobs to update.static final String
DaemonConfig.SUPERVISOR_MONITOR_FREQUENCY_SECS
How often the supervisor checks the worker heartbeats to see if any of them need to be restarted.static final String
Config.SUPERVISOR_QUEUE_SIZE
static final String
Config.SUPERVISOR_THRIFT_PORT
static final String
How long before a supervisor Thrift Client socket hangs before timeout and restart the socket.static final String
Config.SUPERVISOR_THRIFT_THREADS
static final String
max timeout for supervisor reported heartbeats when master gains leadership.static final String
How many seconds to allow for graceful worker shutdown when killing workers before resorting to force kill.static final String
DaemonConfig.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 final String
How long a worker can go without heartbeating before the supervisor tries to restart the worker process.static final String
Config.TASK_CREDENTIALS_POLL_SECS
How often a task should sync credentials, worst case.static final String
How often a task should heartbeat its status to the Pacamker.static final String
Config.TASK_REFRESH_POLL_SECS
How often a task should sync its connections with other tasks (if a task is reassigned, the other tasks sending messages to it need to refresh their connections).static final String
Config.TOPOLOGY_ACKER_EXECUTORS
How many executors to spawn for ackers.static final String
How often a worker should check and notify upstream workers about its tasks that are no longer experiencing BP and able to receive new messages.static final String
Configures steps used to determine progression to the next level of wait .. if using WaitStrategyProgressive for BackPressure.static final String
Configures steps used to determine progression to the next level of wait .. if using WaitStrategyProgressive for BackPressure.static final String
How often to send flush tuple to the executors for flushing out batched events.static final String
Configures number of iterations to spend in level 1 of WaitStrategyProgressive, before progressing to level 2.static final String
Configures number of iterations to spend in level 2 of WaitStrategyProgressive, before progressing to level 3.static final String
static final String
static final String
Bolt-specific configuration for windowed bolts to specify the maximum time lag of the tuple timestamp in milliseconds.static final String
static final String
static final String
static final String
The time period that builtin metrics data in bucketed into.static final String
The interval in seconds to use for determining whether to throttle error reported to Zookeeper.static final String
How many executors to spawn for event logger.static final String
If number of items in task's overflowQ exceeds this, new messages coming from other workers to this task will be dropped This prevents OutOfMemoryException that can occur in rare scenarios in the presence of BackPressure.static final String
The size of the receive queue for each executor.static final String
Config.TOPOLOGY_ISOLATED_MACHINES
The maximum number of machines that should be used by this topology.static final String
See doc forConfig.TOPOLOGY_ERROR_THROTTLE_INTERVAL_SECS
.static final String
Config.TOPOLOGY_MAX_SPOUT_PENDING
The maximum number of tuples that can be pending on a spout task at any given time.static final String
The maximum parallelism allowed for a component in this topology.static final String
The maximum amount of time given to the topology to fully process a message emitted by a spout.static final String
Config.TOPOLOGY_PRIORITY
Sets the priority for a topology.static final String
Config.TOPOLOGY_PRODUCER_BATCH_SIZE
The number of tuples to batch before sending to the destination executor.static final String
How many ackers to put in when launching a new worker until we run out of ackers.static final String
The maximum number of states that will be searched looking for a solution in resource aware strategies, e.g.static final String
The maximum number of seconds to spend scheduling a topology using resource aware strategies, e.g.static final String
Max pending tuples in one ShellBolt.static final String
The amount of milliseconds the SleepEmptyEmitStrategy should sleep for.static final String
Config.TOPOLOGY_SPOUT_RECVQ_SKIPS
Check recvQ after every N invocations of Spout's nextTuple() [when ACKing is disabled].static final String
Configures number of iterations to spend in level 1 of WaitStrategyProgressive, before progressing to level 2.static final String
Configures number of iterations to spend in level 2 of WaitStrategyProgressive, before progressing to level 3.static final String
Topology configuration to specify the checkpoint interval (in millis) at which the topology state is saved whenIStatefulBolt
bolts are involved.static final String
The maximum amount of time a component gives a source of state to synchronize before it requests synchronization again.static final String
How long a subprocess can go without heartbeating before the ShellSpout/ShellBolt tries to suicide itself.static final String
Config.TOPOLOGY_TASKS
How many instances to create for a spout/bolt.static final String
How often a tick tuple from the "__system" component and "__tick" stream should be sent to tasks.static final String
Config.TOPOLOGY_TRANSFER_BATCH_SIZE
The size of the transfer queue for each worker.static final String
The size of the transfer queue for each worker.static final String
How often a batch can be emitted in a Trident topology.static final String
Maximum number of tuples that can be stored inmemory cache in windowing operators for fast access without fetching them from store.static final String
Topology configuration to specify the V2 metrics tick interval in seconds.static final String
The size of the shared thread pool for worker tasks to make use of.static final String
Config.TOPOLOGY_WORKER_TIMEOUT_SECS
Topology configurable worker heartbeat timeout before the supervisor tries to restart the worker process.static final String
Config.TOPOLOGY_WORKERS
How many processes should be spawned around the cluster to execute this topology.static final String
Config.TRANSACTIONAL_ZOOKEEPER_PORT
The port to use to connect to the transactional zookeeper servers.static final String
DaemonConfig.UI_HEADER_BUFFER_BYTES
The size of the header buffer for the UI in bytes.static final String
DaemonConfig.UI_HTTPS_PORT
This port is used by Storm UI for receiving HTTPS (SSL) requests from clients.static final String
DaemonConfig.UI_PAGINATION
Storm UI drop-down pagination value.static final String
DaemonConfig.UI_PORT
Storm UI binds to this port.static final String
Interval to check for the worker to check for updated blobs and refresh worker state accordingly.static final String
Config.WORKER_HEAP_MEMORY_MB
The default heap memory size in MB per worker, used in the jvm -Xmx opts for launching the worker.static final String
How often this worker should heartbeat to the supervisor.static final String
How often a worker should check dynamic log level timeouts for expiration.static final String
Config.WORKER_MAX_TIMEOUT_SECS
Enforce maximum onConfig.TOPOLOGY_WORKER_TIMEOUT_SECS
. -
Uses of ConfigValidationAnnotations.IsInteger in org.apache.storm.hdfs.spout
Fields in org.apache.storm.hdfs.spout with annotations of type ConfigValidationAnnotations.IsIntegerModifier and TypeFieldDescriptionstatic final String
Configs.COMMIT_FREQ_COUNT
Deprecated.static final String
Configs.COMMIT_FREQ_SEC
Deprecated.please useHdfsSpout.setCommitFrequencySec(int)
static final String
Configs.LOCK_TIMEOUT
Deprecated.please useHdfsSpout.setLockTimeoutSec(int)
static final String
Configs.MAX_OUTSTANDING
Deprecated.please useHdfsSpout.setMaxOutstanding(int)
HdfsSpout.setCommitFrequencyCount(int)