Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

A

A - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
abort() - Method in class org.apache.storm.hive.common.HiveWriter
Aborts the current Txn and switches to next Txn.
abort() - Method in class org.apache.storm.security.auth.kerberos.AutoTGTKrb5LoginModule
 
ABS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
ABSOLUTE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
absoluteHealthCheckDir(Map<String, Object>) - Static method in class org.apache.storm.utils.ServerConfigUtils
 
absoluteStormBlobStoreDir(Map<String, Object>) - Static method in class org.apache.storm.utils.ConfigUtils
 
absoluteStormLocalDir(Map<String, Object>) - Static method in class org.apache.storm.utils.ConfigUtils
 
AbstractAvroSerializer - Class in org.apache.storm.hdfs.avro
This abstract class can be extended to implement concrete classes capable of (de)serializing generic avro objects across a Topology.
AbstractAvroSerializer() - Constructor for class org.apache.storm.hdfs.avro.AbstractAvroSerializer
 
AbstractDNSToSwitchMapping - Class in org.apache.storm.networktopography
This is a base class for DNS to Switch mappings.
AbstractDNSToSwitchMapping() - Constructor for class org.apache.storm.networktopography.AbstractDNSToSwitchMapping
Create an unconfigured instance.
AbstractEsBolt - Class in org.apache.storm.elasticsearch.bolt
 
AbstractEsBolt(EsConfig) - Constructor for class org.apache.storm.elasticsearch.bolt.AbstractEsBolt
 
AbstractExecutionResultHandler - Class in org.apache.storm.cassandra
Default interface to define strategies to apply when a query is either succeed or failed.
AbstractExecutionResultHandler() - Constructor for class org.apache.storm.cassandra.AbstractExecutionResultHandler
 
AbstractHadoopAutoCreds - Class in org.apache.storm.common
The base class that for auto credential plugins that abstracts out some of the common functionality.
AbstractHadoopAutoCreds() - Constructor for class org.apache.storm.common.AbstractHadoopAutoCreds
 
AbstractHadoopNimbusPluginAutoCreds - Class in org.apache.storm.common
The base class that for auto credential plugins that abstracts out some of the common functionality.
AbstractHadoopNimbusPluginAutoCreds() - Constructor for class org.apache.storm.common.AbstractHadoopNimbusPluginAutoCreds
 
AbstractHBaseBolt - Class in org.apache.storm.hbase.bolt
 
AbstractHBaseBolt(String, HBaseMapper) - Constructor for class org.apache.storm.hbase.bolt.AbstractHBaseBolt
 
AbstractHdfsBolt - Class in org.apache.storm.hdfs.bolt
 
AbstractHdfsBolt() - Constructor for class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
 
AbstractHDFSWriter - Class in org.apache.storm.hdfs.common
 
AbstractHDFSWriter(FileRotationPolicy, Path) - Constructor for class org.apache.storm.hdfs.common.AbstractHDFSWriter
 
AbstractJdbcBolt - Class in org.apache.storm.jdbc.bolt
 
AbstractJdbcBolt(ConnectionProvider) - Constructor for class org.apache.storm.jdbc.bolt.AbstractJdbcBolt
Constructor.
AbstractMongoBolt - Class in org.apache.storm.mongodb.bolt
 
AbstractMongoBolt(String, String) - Constructor for class org.apache.storm.mongodb.bolt.AbstractMongoBolt
AbstractMongoBolt Constructor.
AbstractRankerBolt - Class in org.apache.storm.starter.bolt
This abstract bolt provides the basic behavior of bolts that rank objects according to their count.
AbstractRankerBolt() - Constructor for class org.apache.storm.starter.bolt.AbstractRankerBolt
 
AbstractRankerBolt(int) - Constructor for class org.apache.storm.starter.bolt.AbstractRankerBolt
 
AbstractRankerBolt(int, int) - Constructor for class org.apache.storm.starter.bolt.AbstractRankerBolt
 
AbstractRedisBolt - Class in org.apache.storm.redis.bolt
AbstractRedisBolt class is for users to implement custom bolts which makes interaction with Redis.
AbstractRedisBolt(JedisPoolConfig) - Constructor for class org.apache.storm.redis.bolt.AbstractRedisBolt
Constructor for single Redis environment (JedisPool).
AbstractRedisBolt(JedisClusterConfig) - Constructor for class org.apache.storm.redis.bolt.AbstractRedisBolt
Constructor for Redis Cluster environment (JedisCluster).
AbstractRedisMapState<T> - Class in org.apache.storm.redis.trident.state
AbstractRedisMapState is base class of any RedisMapState, which implements IBackingMap.
AbstractRedisMapState() - Constructor for class org.apache.storm.redis.trident.state.AbstractRedisMapState
 
AbstractRedisStateQuerier<T extends State> - Class in org.apache.storm.redis.trident.state
AbstractRedisStateQuerier is base class of any RedisStateQuerier, which implements BaseQueryFunction.
AbstractRedisStateQuerier(RedisLookupMapper) - Constructor for class org.apache.storm.redis.trident.state.AbstractRedisStateQuerier
Constructor.
AbstractRedisStateUpdater<T extends State> - Class in org.apache.storm.redis.trident.state
AbstractRedisStateUpdater is base class of any RedisStateUpdater, which implements BaseStateUpdater.
AbstractRedisStateUpdater(RedisStoreMapper) - Constructor for class org.apache.storm.redis.trident.state.AbstractRedisStateUpdater
Constructor.
AbstractStreamsProcessor - Class in org.apache.storm.sql
 
AbstractStreamsProcessor() - Constructor for class org.apache.storm.sql.AbstractStreamsProcessor
 
AbstractTridentWindowManager<T> - Class in org.apache.storm.trident.windowing
Basic functionality to manage trident tuple events using WindowManager and WindowsStore for storing tuples and triggers related information.
AbstractTridentWindowManager(WindowConfig, String, WindowsStore, Aggregator, BatchOutputCollector) - Constructor for class org.apache.storm.trident.windowing.AbstractTridentWindowManager
 
AbstractUserTopology - Class in org.apache.storm.jdbc.topology
For topology-related code reusage.
AbstractUserTopology() - Constructor for class org.apache.storm.jdbc.topology.AbstractUserTopology
 
accept(Object) - Method in class org.apache.storm.daemon.worker.WorkerTransfer
 
accept(Object) - Method in class org.apache.storm.executor.Executor
 
accept(T) - Method in interface org.apache.storm.streams.operations.Consumer
Performs an operation on the given argument.
accept(T) - Method in class org.apache.storm.streams.operations.PrintConsumer
 
accept(TridentTuple) - Method in interface org.apache.storm.trident.operation.Consumer
Performs the operation on the input trident tuple.
accept(Object) - Method in interface org.apache.storm.utils.JCQueue.Consumer
 
AccessControl - Class in org.apache.storm.generated
 
AccessControl() - Constructor for class org.apache.storm.generated.AccessControl
 
AccessControl(AccessControlType, int) - Constructor for class org.apache.storm.generated.AccessControl
 
AccessControl(AccessControl) - Constructor for class org.apache.storm.generated.AccessControl
Performs a deep copy on other.
AccessControl._Fields - Enum in org.apache.storm.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
accessControlToString(AccessControl) - Static method in class org.apache.storm.blobstore.BlobStoreAclHandler
 
AccessControlType - Enum in org.apache.storm.generated
 
AccessLoggingFilter - Class in org.apache.storm.logging.filters
 
AccessLoggingFilter() - Constructor for class org.apache.storm.logging.filters.AccessLoggingFilter
 
ack(Object) - Method in class org.apache.storm.clojure.ClojureSpout
 
ack(Tuple) - Method in class org.apache.storm.coordination.BatchOutputCollectorImpl
 
ack(Tuple) - Method in class org.apache.storm.coordination.CoordinatedBolt.CoordinatedOutputCollector
 
ack(Object) - Method in class org.apache.storm.drpc.DRPCSpout
 
ack(Object) - Method in class org.apache.storm.elasticsearch.bolt.EsIndexTopology.UserDataSpout
Acknowledges the message with id msgId.
ack(long) - Method in class org.apache.storm.elasticsearch.trident.TridentEsTopology.FixedBatchSpout
Acknowledges the message with id msgId.
ack(Object) - Method in class org.apache.storm.eventhubs.spout.EventHubSpout
 
ack(String) - Method in interface org.apache.storm.eventhubs.spout.IPartitionManager
 
ack(String) - Method in class org.apache.storm.eventhubs.spout.PartitionManager
 
ack(String) - Method in class org.apache.storm.eventhubs.spout.SimplePartitionManager
 
ack(Tuple) - Method in class org.apache.storm.executor.bolt.BoltOutputCollectorImpl
 
ack(Object) - Method in class org.apache.storm.hbase.topology.WordSpout
 
ack(Object) - Method in class org.apache.storm.hdfs.bolt.HdfsFileTopology.SentenceSpout
 
ack(Object) - Method in class org.apache.storm.hdfs.bolt.SequenceFileTopology.SentenceSpout
 
ack(Object) - Method in class org.apache.storm.hdfs.spout.HdfsSpout
 
ack(long) - Method in class org.apache.storm.hdfs.trident.FixedBatchSpout
 
ack(Object) - Method in class org.apache.storm.hive.bolt.BucketTestHiveTopology.UserDataSpout
 
ack(Object) - Method in class org.apache.storm.hive.bolt.HiveTopology.UserDataSpout
 
ack(Object) - Method in class org.apache.storm.hive.bolt.HiveTopologyPartitioned.UserDataSpout
 
ack(long) - Method in class org.apache.storm.hive.trident.TridentHiveTopology.FixedBatchSpout
 
ack(Object) - Method in class org.apache.storm.jdbc.spout.UserSpout
 
ack(Object) - Method in class org.apache.storm.jms.spout.JmsSpout
Ack a successfully handled message by the matching JmsMessageID.
ack(Object) - Method in class org.apache.storm.kafka.spout.KafkaSpout
 
ack(Object) - Method in class org.apache.storm.kinesis.spout.KinesisSpout
 
ack(Object) - Method in class org.apache.storm.loadgen.LoadSpout
 
ack(Object) - Method in class org.apache.storm.mongodb.topology.WordSpout
 
ack(Object) - Method in class org.apache.storm.mqtt.spout.MqttSpout
Storm has determined that the tuple emitted by this spout with the msgId identifier has been fully processed.
ack(long) - Method in class org.apache.storm.opentsdb.MetricGenBatchSpout
 
ack(Object) - Method in class org.apache.storm.perf.spout.ConstSpout
 
ack(Object) - Method in class org.apache.storm.perf.spout.StringGenSpout
 
ack(Object) - Method in class org.apache.storm.redis.topology.WordSpout
 
ack() - Method in class org.apache.storm.rocketmq.ConsumerBatchMessage
Countdown if the sub message is successful.
ack(Object) - Method in class org.apache.storm.rocketmq.spout.RocketMqSpout
 
ack(Object) - Method in class org.apache.storm.spout.CheckpointSpout
 
ack(Object) - Method in interface org.apache.storm.spout.ISpout
Storm has determined that the tuple emitted by this spout with the msgId identifier has been fully processed.
ack(Object) - Method in class org.apache.storm.spout.ShellSpout
 
ack(Object) - Method in class org.apache.storm.sql.runtime.datasource.socket.spout.SocketSpout
 
ack(Object) - Method in class org.apache.storm.st.topology.window.IncrementingSpout
 
ack(Object) - Method in class org.apache.storm.starter.AnchoredWordCount.RandomSentenceSpout
 
ack(Object) - Method in class org.apache.storm.starter.BlobStoreAPIWordCountTopology.RandomSentenceSpout
 
ack(Object) - Method in class org.apache.storm.starter.FastWordCountTopology.FastRandomSentenceSpout
 
ack(Object) - Method in class org.apache.storm.starter.InOrderDeliveryTest.InOrderSpout
 
ack(Object) - Method in class org.apache.storm.starter.spout.RandomIntegerSpout
 
ack(long) - Method in class org.apache.storm.starter.spout.RandomNumberGeneratorSpout
 
ack(Object) - Method in class org.apache.storm.starter.spout.RandomSentenceSpout
 
ack(Tuple) - Method in interface org.apache.storm.task.IOutputCollector
 
ack(Tuple) - Method in class org.apache.storm.task.OutputCollector
 
ack(Object) - Method in interface org.apache.storm.testing.AckFailDelegate
 
ack(Object) - Method in class org.apache.storm.testing.AckFailMapTracker
 
ack(Object) - Method in class org.apache.storm.testing.AckTracker
 
ack(Object) - Method in class org.apache.storm.testing.FeederSpout
 
ack(Object) - Method in class org.apache.storm.testing.FixedTupleSpout
 
ack(Object) - Method in class org.apache.storm.testing.SpoutTracker
 
ack(Object) - Method in class org.apache.storm.testing.TestEventLogSpout
 
ack(Object) - Method in class org.apache.storm.testing.TestPlannerSpout
 
ack(Object) - Method in class org.apache.storm.testing.TestWordSpout
 
ack(Object) - Method in class org.apache.storm.topology.base.BaseRichSpout
 
ack(long) - Method in interface org.apache.storm.trident.spout.IBatchSpout
 
ack(Object) - Method in class org.apache.storm.trident.spout.RichSpoutBatchTriggerer
 
ack(long) - Method in class org.apache.storm.trident.testing.FixedBatchSpout
 
ack(Object) - Method in class org.apache.storm.trident.topology.MasterBatchCoordinator
 
ack() - Method in class org.apache.storm.utils.BatchHelper
 
acked(KinesisMessageId) - Method in class org.apache.storm.kinesis.spout.ExponentialBackoffRetrier
 
acked(KinesisMessageId) - Method in interface org.apache.storm.kinesis.spout.FailedMessageRetryHandler
message with messageId succeeded/acked in the spout.
Acker - Class in org.apache.storm.daemon
 
Acker() - Constructor for class org.apache.storm.daemon.Acker
 
ACKER_ACK_STREAM_ID - Static variable in class org.apache.storm.daemon.Acker
 
ACKER_COMPONENT_ID - Static variable in class org.apache.storm.daemon.Acker
 
ACKER_FAIL_STREAM_ID - Static variable in class org.apache.storm.daemon.Acker
 
ACKER_INIT_STREAM_ID - Static variable in class org.apache.storm.daemon.Acker
 
ACKER_RESET_TIMEOUT_STREAM_ID - Static variable in class org.apache.storm.daemon.Acker
 
ackerInputs(StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
 
AckFailDelegate - Interface in org.apache.storm.testing
 
AckFailMapTracker - Class in org.apache.storm.testing
 
AckFailMapTracker() - Constructor for class org.apache.storm.testing.AckFailMapTracker
 
ackingEnabled - Variable in class org.apache.storm.executor.Executor
 
ackingTaskId - Variable in class org.apache.storm.hooks.info.BoltAckInfo
 
ackSpoutMsg(SpoutExecutor, Task, Long, TupleInfo) - Method in class org.apache.storm.executor.spout.SpoutExecutor
 
AckTracker - Class in org.apache.storm.testing
 
AckTracker() - Constructor for class org.apache.storm.testing.AckTracker
 
AclEnforcement - Class in org.apache.storm.zookeeper
This is code intended to enforce ZK ACLs.
AclEnforcement() - Constructor for class org.apache.storm.zookeeper.AclEnforcement
 
aclFileName - Variable in class org.apache.storm.security.auth.authorizer.DRPCSimpleACLAuthorizer
 
AclFunctionEntry(Collection<String>, String) - Constructor for class org.apache.storm.security.auth.authorizer.DRPCSimpleACLAuthorizer.AclFunctionEntry
 
aclHandler - Variable in class org.apache.storm.blobstore.LocalFsBlobStore
 
acquireNewPort() - Static method in class org.apache.storm.utils.InprocMessaging
 
acquireOldestExpiredLock(FileSystem, Path, int, String) - Static method in class org.apache.storm.hdfs.spout.FileLock
Finds a oldest expired lock file (using modification timestamp), then takes ownership of the lock file.
ACTION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
activate() - Method in class org.apache.storm.clojure.ClojureSpout
 
Activate - Class in org.apache.storm.command
 
Activate() - Constructor for class org.apache.storm.command.Activate
 
activate(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
 
activate(String, AsyncMethodCallback<Void>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
 
activate(String, AsyncMethodCallback<Void>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
 
activate() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.activate
 
activate(String) - Method in class org.apache.storm.generated.Nimbus.Client
 
activate(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
 
activate() - Constructor for class org.apache.storm.generated.Nimbus.Processor.activate
 
activate() - Method in class org.apache.storm.hbase.topology.WordSpout
 
activate(String) - Method in interface org.apache.storm.ILocalCluster
Activate a topology.
activate() - Method in class org.apache.storm.jdbc.spout.UserSpout
 
activate() - Method in class org.apache.storm.kafka.spout.KafkaSpout
 
activate() - Method in class org.apache.storm.kinesis.spout.KinesisSpout
 
activate(String) - Method in class org.apache.storm.LocalCluster
 
activate() - Method in class org.apache.storm.mongodb.topology.WordSpout
 
activate() - Method in class org.apache.storm.mqtt.spout.MqttSpout
 
activate() - Method in class org.apache.storm.pmml.RawInputFromCSVSpout
 
activate() - Method in class org.apache.storm.redis.topology.WordSpout
 
activate() - Method in class org.apache.storm.rocketmq.spout.RocketMqSpout
 
activate() - Method in interface org.apache.storm.spout.ISpout
Called when a spout has been activated out of a deactivated mode.
activate() - Method in class org.apache.storm.spout.ShellSpout
 
activate() - Method in class org.apache.storm.sql.runtime.datasource.socket.spout.SocketSpout
 
activate() - Method in class org.apache.storm.testing.FixedTupleSpout
 
activate() - Method in class org.apache.storm.topology.base.BaseRichSpout
 
activate() - Method in class org.apache.storm.trident.spout.RichSpoutBatchTriggerer
 
activate() - Method in class org.apache.storm.trident.topology.MasterBatchCoordinator
 
activate_args() - Constructor for class org.apache.storm.generated.Nimbus.activate_args
 
activate_args(String) - Constructor for class org.apache.storm.generated.Nimbus.activate_args
 
activate_args(Nimbus.activate_args) - Constructor for class org.apache.storm.generated.Nimbus.activate_args
Performs a deep copy on other.
activate_call(String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.activate_call
 
activate_result() - Constructor for class org.apache.storm.generated.Nimbus.activate_result
 
activate_result(NotAliveException, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.activate_result
 
activate_result(Nimbus.activate_result) - Constructor for class org.apache.storm.generated.Nimbus.activate_result
Performs a deep copy on other.
activateStorm(String, StormBase, Map<String, Object>) - Method in interface org.apache.storm.cluster.IStormClusterState
 
activateStorm(String, StormBase, Map<String, Object>) - Method in class org.apache.storm.cluster.StormClusterStateImpl
 
activateWorkerWhenAllConnectionsReady() - Method in class org.apache.storm.daemon.worker.WorkerState
we will wait all connections to be ready and then activate the spout/bolt when the worker bootup.
activeAnonSize - Variable in class org.apache.storm.container.cgroup.core.MemoryCore.Stat
 
activeFileSize - Variable in class org.apache.storm.container.cgroup.core.MemoryCore.Stat
 
activeKeys() - Method in interface org.apache.storm.cluster.IStormClusterState
 
activeKeys() - Method in class org.apache.storm.cluster.StormClusterStateImpl
 
activeStorms() - Method in interface org.apache.storm.cluster.IStormClusterState
 
activeStorms() - Method in class org.apache.storm.cluster.StormClusterStateImpl
 
ADA - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
add(TopologyResources) - Method in class org.apache.storm.daemon.nimbus.TopologyResources
Add the values in other to this and return a combined resources object.
add(Runnable) - Method in interface org.apache.storm.event.EventManager
 
add(Runnable) - Method in class org.apache.storm.event.EventManagerImp
 
add(InputStream) - Method in class org.apache.storm.loadgen.LoadBolt
 
add(LoadMetricsServer.Measurements) - Method in class org.apache.storm.loadgen.LoadMetricsServer.Measurements
Add other to this.
add(TaskMessage) - Method in class org.apache.storm.messaging.netty.MessageBuffer
 
add(NormalizedResourcesWithMemory) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceOffer
 
add(NormalizedResourceRequest) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
Add the resources in other to this.
add(WorkerResources) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
Add the resources from a worker to those in this.
add(NormalizedResources) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
 
add(WorkerResources) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
Add the resources from a worker to this.
add(WorkerResources) - Method in class org.apache.storm.scheduler.SupervisorResources
 
ADD - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
add(int, Object, List<Object>) - Method in interface org.apache.storm.state.ISynchronizeOutputCollector
 
add(int, Object, List<Object>) - Method in class org.apache.storm.state.SynchronizeOutputCollector
 
add(StormTimer.QueueEntry) - Method in class org.apache.storm.StormTimer.StormTimerTask
 
add(int, Object) - Method in class org.apache.storm.trident.tuple.ConsList
 
add(Object, V) - Method in class org.apache.storm.utils.KeyedRoundRobinQueue
 
add(Object) - Method in class org.apache.storm.utils.ListDelegate
 
add(int, Object) - Method in class org.apache.storm.utils.ListDelegate
 
add(TaskMessage) - Method in class org.apache.storm.utils.TransferDrainer
 
add(Event<T>) - Method in class org.apache.storm.windowing.persistence.WindowState
 
add(T) - Method in class org.apache.storm.windowing.WindowManager
Add an event into the window, with System.currentTimeMillis() as the tracking ts.
add(T, long) - Method in class org.apache.storm.windowing.WindowManager
Add an event into the window, with the given ts as the tracking ts.
add(Event<T>) - Method in class org.apache.storm.windowing.WindowManager
Tracks a window event.
add_escapes(String) - Method in exception org.apache.storm.sql.parser.impl.ParseException
Used to convert raw characters to their escaped version when these raw version cannot be used as part of an ASCII string literal.
add_listener(ConnectionStateListener) - Method in interface org.apache.storm.cluster.IStateStorage
Add a StateStorageListener to the connection.
add_listener(ConnectionStateListener) - Method in class org.apache.storm.cluster.PaceMakerStateStorage
 
add_listener(ConnectionStateListener) - Method in class org.apache.storm.cluster.ZKStateStorage
 
add_to_acl(AccessControl) - Method in class org.apache.storm.generated.SettableBlobMeta
 
add_to_args_list(JavaObjectArg) - Method in class org.apache.storm.generated.JavaObject
 
add_to_dependency_artifacts(String) - Method in class org.apache.storm.generated.StormTopology
 
add_to_dependency_jars(String) - Method in class org.apache.storm.generated.StormTopology
 
add_to_errors(ErrorInfo) - Method in class org.apache.storm.generated.ComponentPageInfo
 
add_to_exec_stats(ExecutorAggregateStats) - Method in class org.apache.storm.generated.ComponentPageInfo
 
add_to_executors(ExecutorInfo) - Method in class org.apache.storm.generated.LocalAssignment
 
add_to_executors(ExecutorInfo) - Method in class org.apache.storm.generated.LSWorkerHeartbeat
 
add_to_executors(ExecutorInfo) - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
 
add_to_executors(ExecutorSummary) - Method in class org.apache.storm.generated.TopologyInfo
 
add_to_groups(String) - Method in class org.apache.storm.generated.LSTopoHistory
 
add_to_keys(String) - Method in class org.apache.storm.generated.ListBlobsResult
 
add_to_meta(long) - Method in class org.apache.storm.generated.SupervisorInfo
 
add_to_metrics(WorkerMetricPoint) - Method in class org.apache.storm.generated.WorkerMetricList
 
add_to_nimbuses(NimbusSummary) - Method in class org.apache.storm.generated.ClusterSummary
 
add_to_output_fields(String) - Method in class org.apache.storm.generated.StreamInfo
 
add_to_port(long) - Method in class org.apache.storm.generated.NodeInfo
 
add_to_pulseIds(String) - Method in class org.apache.storm.generated.HBNodes
 
add_to_pulses(HBPulse) - Method in class org.apache.storm.generated.HBRecords
 
add_to_success(ProfileRequest) - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
 
add_to_success(OwnerResourceSummary) - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
 
add_to_supervisor_summaries(SupervisorSummary) - Method in class org.apache.storm.generated.SupervisorPageInfo
 
add_to_supervisors(SupervisorSummary) - Method in class org.apache.storm.generated.ClusterSummary
 
add_to_topo_history(LSTopoHistory) - Method in class org.apache.storm.generated.LSTopoHistoryList
 
add_to_topo_ids(String) - Method in class org.apache.storm.generated.TopologyHistoryInfo
 
add_to_topologies(TopologySummary) - Method in class org.apache.storm.generated.ClusterSummary
 
add_to_used_ports(long) - Method in class org.apache.storm.generated.SupervisorInfo
 
add_to_users(String) - Method in class org.apache.storm.generated.LSTopoHistory
 
add_to_worker_heartbeats(SupervisorWorkerHeartbeat) - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
 
add_to_worker_hooks(ByteBuffer) - Method in class org.apache.storm.generated.StormTopology
 
add_to_worker_summaries(WorkerSummary) - Method in class org.apache.storm.generated.SupervisorPageInfo
 
add_to_workers(WorkerSummary) - Method in class org.apache.storm.generated.TopologyPageInfo
 
addAcker(Map<String, Object>, StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
 
addAggLevel(AggLevel) - Method in class org.apache.storm.metricstore.FilterOptions
Add an aggregation level to search for.
addAll(Collection<?>) - Method in class org.apache.storm.utils.ListDelegate
 
addAll(int, Collection<?>) - Method in class org.apache.storm.utils.ListDelegate
 
addAllBolts(List<BoltDef>, boolean) - Method in class org.apache.storm.flux.model.TopologyDef
Adds a list of bolt definitions.
addAllComponents(List<BeanDef>, boolean) - Method in class org.apache.storm.flux.model.TopologyDef
Adds a list of component definitions.
addAllSpouts(List<SpoutDef>, boolean) - Method in class org.apache.storm.flux.model.TopologyDef
Adds a list of spout definitions.
addAllStreams(List<StreamDef>, boolean) - Method in class org.apache.storm.flux.model.TopologyDef
Adds a list of stream definitions.
addAnchor(String) - Method in class org.apache.storm.multilang.ShellMsg
 
addAssignmentsForNode(String, String, Integer, SupervisorAssignments, StormMetricsRegistry) - Method in class org.apache.storm.nimbus.AssignmentDistributionService
Add an assignments for a node/supervisor for distribution.
addAvroKryoSerializations(Config) - Static method in class org.apache.storm.hdfs.avro.AvroUtils
A helper method to extract avro serialization configurations from the topology configuration and register specific kryo serializers as necessary.
addBatch(Tuple) - Method in class org.apache.storm.utils.BatchHelper
 
addBolt(IBatchBolt, Number) - Method in class org.apache.storm.drpc.LinearDRPCTopologyBuilder
 
addBolt(IBatchBolt) - Method in class org.apache.storm.drpc.LinearDRPCTopologyBuilder
 
addBolt(IRichBolt, Number) - Method in class org.apache.storm.drpc.LinearDRPCTopologyBuilder
Deprecated.
addBolt(IRichBolt) - Method in class org.apache.storm.drpc.LinearDRPCTopologyBuilder
Deprecated.
addBolt(IBasicBolt, Number) - Method in class org.apache.storm.drpc.LinearDRPCTopologyBuilder
 
addBolt(IBasicBolt) - Method in class org.apache.storm.drpc.LinearDRPCTopologyBuilder
 
addBolt(String, Object) - Method in class org.apache.storm.flux.model.ExecutionContext
 
addChild(Component) - Method in class org.apache.storm.scheduler.Component
Add a child link.
addClassLoader(CompilingClassLoader) - Method in class org.apache.storm.sql.planner.streams.StreamsPlanCreator
 
addColumn(HBaseProjectionCriteria.ColumnMetaData) - Method in class org.apache.storm.hbase.bolt.mapper.HBaseProjectionCriteria
Only this column from the the columnFamily will be included as result of HBase lookup.
addColumn(byte[], byte[], long, byte[]) - Method in class org.apache.storm.hbase.common.ColumnList
Add a standard HBase column.
addColumn(byte[], byte[], byte[]) - Method in class org.apache.storm.hbase.common.ColumnList
Add a standard HBase column.
addColumn(IColumn) - Method in class org.apache.storm.hbase.common.ColumnList
Add a standard HBase column given an instance of a class that implements the IColumn interface.
addColumnFamily(String) - Method in class org.apache.storm.hbase.bolt.mapper.HBaseProjectionCriteria
all columns from this family will be included as result of HBase lookup.
addColumnFamily(byte[]) - Method in class org.apache.storm.hbase.bolt.mapper.HBaseProjectionCriteria
all columns from this family will be included as result of HBase lookup.
addCommandLineOptions(Options) - Static method in class org.apache.storm.loadgen.LoadMetricsServer
Add Command line options for configuring the output of this.
addComponent(String, Object) - Method in class org.apache.storm.flux.model.ExecutionContext
 
addComponentConfig(String, Object) - Method in class org.apache.storm.flux.wrappers.bolts.FluxShellBolt
Add configuration for this bolt.
addComponentConfig(String, List<Object>) - Method in class org.apache.storm.flux.wrappers.bolts.FluxShellBolt
Add configuration for this bolt.
addComponentConfig(String, Object) - Method in class org.apache.storm.flux.wrappers.spouts.FluxShellSpout
Add configuration for this spout.
addComponentConfig(String, List<Object>) - Method in class org.apache.storm.flux.wrappers.spouts.FluxShellSpout
Add configuration for this spout.
addConfiguration(String, Object) - Method in class org.apache.storm.topology.BaseConfigurationDeclarer
 
addConfiguration(String, Object) - Method in interface org.apache.storm.topology.ComponentConfigurationDeclarer
Add in a single config.
addConfigurations(Map<String, Object>) - Method in interface org.apache.storm.topology.ComponentConfigurationDeclarer
add in several configs to the component.
addConfigurations(Map<String, Object>) - Method in class org.apache.storm.topology.TopologyBuilder.ConfigGetter
 
addCounter(byte[], byte[], long) - Method in class org.apache.storm.hbase.common.ColumnList
Add an HBase counter column.
addCounter(ICounter) - Method in class org.apache.storm.hbase.common.ColumnList
Add an HBase counter column given an instance of a class that implements the ICounter interface.
addEmptyTopoForTests(String) - Method in class org.apache.storm.daemon.nimbus.HeartbeatCache
Add an empty topology to the cache for testing purposes.
addEscapes(String) - Static method in error org.apache.storm.sql.parser.impl.TokenMgrError
Replaces unprintable characters by their espaced (or unicode escaped) equivalents in the given string
addEventLogger(Map<String, Object>, StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
 
addGroup(Group) - Method in class org.apache.storm.trident.graph.GraphGrouper
 
additionalKey - Variable in class org.apache.storm.redis.trident.state.AbstractRedisStateQuerier
 
additionalKey - Variable in class org.apache.storm.redis.trident.state.AbstractRedisStateUpdater
 
addListener(CuratorFramework, ConnectionStateListener) - Static method in class org.apache.storm.zookeeper.ClientZookeeper
 
addLocalSupervisor(Supervisor) - Method in class org.apache.storm.nimbus.AssignmentDistributionService
 
addMem(Double) - Method in class org.apache.storm.scheduler.SupervisorResources
 
addMetricComponents(Map<String, Object>, StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
 
addMetricStreams(StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
 
addMockData(String, String, Values...) - Method in class org.apache.storm.testing.MockedSources
add mock data for the spout.
addMockData(String, Values...) - Method in class org.apache.storm.testing.MockedSources
 
addNimbusHost(String, NimbusSummary) - Method in interface org.apache.storm.cluster.IStormClusterState
 
addNimbusHost(String, NimbusSummary) - Method in class org.apache.storm.cluster.StormClusterStateImpl
 
addNode(Node) - Method in class org.apache.storm.trident.TridentTopology
 
addOffHeap(double) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
 
addOnHeap(double) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
 
addPartition(Partition) - Method in class org.apache.storm.eventhubs.trident.Partitions
 
addPredicate(Predicate<? super T>, String) - Method in class org.apache.storm.streams.processors.BranchProcessor
 
addPrivateWorkerKey(WorkerTokenServiceType, String, long, PrivateWorkerKey) - Method in interface org.apache.storm.cluster.IStormClusterState
Store a new version of a private key.
addPrivateWorkerKey(WorkerTokenServiceType, String, long, PrivateWorkerKey) - Method in class org.apache.storm.cluster.StormClusterStateImpl
 
addProcs(int) - Method in class org.apache.storm.container.cgroup.CgroupCommon
 
addProcs(int) - Method in interface org.apache.storm.container.cgroup.CgroupCommonOperation
add a process to cgroup.
addProfilerActions(Set<Slot.TopoProfileAction>) - Method in class org.apache.storm.daemon.supervisor.Slot
 
addReceiver(TridentProcessor) - Method in class org.apache.storm.trident.planner.SubtopologyBolt.InitialReceiver
 
addReference(PortAndAssignment, BlobChangingCallback) - Method in class org.apache.storm.localizer.LocallyCachedBlob
Mark that a given port and assignment are using this.
addRequestContextFilter(ServletContextHandler, String, Map<String, Object>) - Static method in class org.apache.storm.daemon.drpc.DRPCServer
Add a request context filter to the Servlet Context Handler.
addRequestContextFilter(ServletContextHandler, String, Map<String, Object>) - Static method in class org.apache.storm.daemon.ui.UIServer
addRequestContextFilter.
addResource(String, Number) - Method in class org.apache.storm.topology.BaseConfigurationDeclarer
 
addResource(String, Number) - Method in interface org.apache.storm.topology.ComponentConfigurationDeclarer
Add generic resource for this component.
addResource(String, Number) - Method in class org.apache.storm.topology.TopologyBuilder.ConfigGetter
 
addResourceMap(Map<String, Double>, Map<String, Double>) - Static method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
 
addResources(ConcurrentMap<String, ? extends LocallyCachedBlob>) - Method in class org.apache.storm.localizer.LocalizedResourceRetentionSet
Add blobs to be checked if they can be deleted.
addResources(Map<String, Double>) - Method in class org.apache.storm.topology.BaseConfigurationDeclarer
Add generic resources for this component.
addResources(Map<String, Double>) - Method in interface org.apache.storm.topology.ComponentConfigurationDeclarer
Add generic resources for this component.
addResources(Map<String, Double>) - Method in class org.apache.storm.topology.TopologyBuilder.ConfigGetter
 
addResourcesForExec(ExecutorDetails, NormalizedResourceRequest) - Method in class org.apache.storm.scheduler.TopologyDetails
add resource requirements for a executor.
AddressedTuple - Class in org.apache.storm.tuple
A Tuple that is addressed to a destination.
AddressedTuple(int, Tuple) - Constructor for class org.apache.storm.tuple.AddressedTuple
 
addRotationAction(RotationAction) - Method in class org.apache.storm.hdfs.bolt.AvroGenericRecordBolt
 
addRotationAction(RotationAction) - Method in class org.apache.storm.hdfs.bolt.HdfsBolt
 
addRotationAction(RotationAction) - Method in class org.apache.storm.hdfs.bolt.SequenceFileBolt
 
addRotationAction(RotationAction) - Method in class org.apache.storm.hdfs.trident.HdfsState.HdfsFileOptions
Deprecated.
addRotationAction(RotationAction) - Method in class org.apache.storm.hdfs.trident.HdfsState.SequenceFileOptions
 
addSharedMemory(SharedMemory) - Method in interface org.apache.storm.topology.ResourceDeclarer
Add in request for shared memory that this component will use.
addSharedMemory(SharedMemory) - Method in class org.apache.storm.topology.TopologyBuilder.ConfigGetter
 
addSharedMemory(SharedMemory) - Method in class org.apache.storm.trident.operation.DefaultResourceDeclarer
 
addSharedMemory(SharedMemory) - Method in class org.apache.storm.trident.Stream
 
addSharedMemory(SharedMemory) - Method in class org.apache.storm.trident.TridentState
 
addShutdownHooks(MyThread...) - Static method in class org.apache.storm.perf.queuetest.JCQueuePerfTest
 
addShutdownHooks(MyThd...) - Static method in class org.apache.storm.perf.toolstest.JCToolsPerfTest
 
addShutdownHookWithDelayedForceKill(Runnable, int) - Static method in class org.apache.storm.utils.Utils
Adds the user supplied function as a shutdown hook for cleanup.
addShutdownHookWithForceKillIn1Sec(Runnable) - Static method in class org.apache.storm.utils.Utils
Adds the user supplied function as a shutdown hook for cleanup.
addSourcedNode(List<Stream>, Node) - Method in class org.apache.storm.trident.TridentTopology
 
addSourcedNode(Stream, Node) - Method in class org.apache.storm.trident.TridentTopology
 
addSourcedStateNode(List<Stream>, Node) - Method in class org.apache.storm.trident.TridentTopology
 
addSourcedStateNode(Stream, Node) - Method in class org.apache.storm.trident.TridentTopology
 
addSpout(String, IRichSpout) - Method in class org.apache.storm.flux.model.ExecutionContext
 
addStream(Stream<Values>) - Method in class org.apache.storm.sql.planner.streams.StreamsPlanCreator
 
addSupervisor(Supervisor) - Method in class org.apache.storm.daemon.nimbus.Nimbus
Used for local cluster.
addSupervisor() - Method in class org.apache.storm.LocalCluster
Add another supervisor to the topology.
addSupervisor(Number) - Method in class org.apache.storm.LocalCluster
Add another supervisor to the topology.
addSupervisor(Number, String) - Method in class org.apache.storm.LocalCluster
Add another supervisor to the topology.
addSupervisor(Number, Map<String, Object>, String) - Method in class org.apache.storm.LocalCluster
Add another supervisor to the topology.
addSystemComponents(Map<String, Object>, StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
 
addSystemStreams(StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
 
addTask(int) - Method in class org.apache.storm.container.cgroup.CgroupCommon
 
addTask(int) - Method in interface org.apache.storm.container.cgroup.CgroupCommonOperation
add task to cgroup.
addTaskHook(ITaskHook) - Method in class org.apache.storm.task.TopologyContext
 
addToAckMsgs(KafkaSpoutMessageId) - Method in class org.apache.storm.kafka.spout.internal.OffsetManager
 
addToCache(String, String) - Static method in class org.apache.storm.starter.ResourceAwareExampleTopology.ExclamationBolt
 
addToEmitMsgs(long) - Method in class org.apache.storm.kafka.spout.internal.OffsetManager
 
addToLeaderLockQueue() - Method in interface org.apache.storm.nimbus.ILeaderElector
queue up for leadership lock.
addToLeaderLockQueue() - Method in class org.apache.storm.testing.MockLeaderElector
 
addToLeaderLockQueue() - Method in class org.apache.storm.zookeeper.LeaderElectorImp
 
addTopoConf(String, Subject, Map<String, Object>) - Method in class org.apache.storm.daemon.nimbus.TopoCache
Add a new topology config.
addTopology(String, Subject, StormTopology) - Method in class org.apache.storm.daemon.nimbus.TopoCache
Add a new topology.
addTopology(TopologyDetails) - Method in class org.apache.storm.scheduler.multitenant.DefaultPool
 
addTopology(TopologyDetails) - Method in class org.apache.storm.scheduler.multitenant.FreePool
 
addTopology(TopologyDetails) - Method in class org.apache.storm.scheduler.multitenant.IsolatedPool
 
addTopology(TopologyDetails) - Method in class org.apache.storm.scheduler.multitenant.NodePool
Add a topology to the pool.
addTopologyHistory(LSTopoHistory) - Method in class org.apache.storm.utils.LocalState
 
addTuple(Object) - Method in class org.apache.storm.multilang.ShellMsg
 
addTuplesBatch(Object, List<TridentTuple>) - Method in class org.apache.storm.trident.windowing.InMemoryTridentWindowManager
 
addTuplesBatch(Object, List<TridentTuple>) - Method in interface org.apache.storm.trident.windowing.ITridentWindowManager
Add received batch of tuples to cache/store and add them to WindowManager.
addTuplesBatch(Object, List<TridentTuple>) - Method in class org.apache.storm.trident.windowing.StoreBasedTridentWindowManager
 
addValue(double) - Method in class org.apache.storm.metricstore.Metric
Adds an additional value to the metric.
addVersions(StormTopology) - Static method in class org.apache.storm.utils.Utils
Add version information to the given topology.
addWorkerHook(IWorkerHook) - Method in class org.apache.storm.topology.TopologyBuilder
Add a new worker lifecycle hook.
adjustBeginLineColumn(int, int) - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
Method to adjust line and column numbers for the start of a token.
ADMIN - Static variable in class org.apache.storm.blobstore.BlobStoreAclHandler
 
ADMIN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
AdminCommands - Class in org.apache.storm.command
 
AdminCommands() - Constructor for class org.apache.storm.command.AdminCommands
 
AdminCommands.AdminCommand - Interface in org.apache.storm.command
 
admins - Variable in class org.apache.storm.security.auth.authorizer.SimpleACLAuthorizer
 
admins - Variable in class org.apache.storm.security.auth.authorizer.SupervisorSimpleACLAuthorizer
 
adminsGroups - Variable in class org.apache.storm.security.auth.authorizer.SimpleACLAuthorizer
 
adminsGroups - Variable in class org.apache.storm.security.auth.authorizer.SupervisorSimpleACLAuthorizer
 
advanceClusterTime(int) - Method in interface org.apache.storm.ILocalCluster
Advance the cluster time when the cluster is using SimulatedTime.
advanceClusterTime(int, int) - Method in interface org.apache.storm.ILocalCluster
Advance the cluster time when the cluster is using SimulatedTime.
advanceClusterTime(int) - Method in class org.apache.storm.LocalCluster
 
advanceClusterTime(int, int) - Method in class org.apache.storm.LocalCluster
 
advanceClusterTime(ILocalCluster, Integer) - Static method in class org.apache.storm.Testing
Simulated time wait for a cluster.
advanceClusterTime(ILocalCluster, Integer, Integer) - Static method in class org.apache.storm.Testing
Simulated time wait for a cluster.
AdvancedFSOps - Class in org.apache.storm.daemon.supervisor
 
AdvancedFSOps(Map<String, Object>) - Constructor for class org.apache.storm.daemon.supervisor.AdvancedFSOps
 
advanceTime(long) - Static method in class org.apache.storm.utils.Time
 
advanceTimeNanos(long) - Static method in class org.apache.storm.utils.Time
 
advanceTimeSecs(long) - Static method in class org.apache.storm.utils.Time
 
AetherUtils - Class in org.apache.storm.submit.dependency
Utility class of Aether.
AFTER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
afterExecute(Runnable, Throwable) - Method in class org.apache.storm.utils.ExtendedThreadPoolExecutor
 
aggBoltExecWinStats(Map<String, Object>, Map<String, Object>, boolean) - Static method in class org.apache.storm.stats.StatsUtil
aggregate windowed stats from a bolt executor stats with a Map of accumulated stats.
aggBoltLatAndCount(Map<List<String>, Double>, Map<List<String>, Double>, Map<List<String>, Long>) - Static method in class org.apache.storm.stats.StatsUtil
Aggregates number executed, process latency, and execute latency across all streams.
aggBoltStreamsLatAndCount(Map<K, Double>, Map<K, Double>, Map<K, Long>) - Static method in class org.apache.storm.stats.StatsUtil
aggregate number executed and process & execute latencies.
aggCompExecsStats(Map, Map, Map<List<Integer>, Map<String, Object>>, String, boolean, String, StormTopology, String) - Static method in class org.apache.storm.stats.StatsUtil
aggregate component executor stats.
aggCompExecStats(String, boolean, Map<String, Object>, Map<String, Object>, String) - Static method in class org.apache.storm.stats.StatsUtil
Combines the aggregate stats of one executor with the given map, selecting the appropriate window and including system components as specified.
AggLevel - Enum in org.apache.storm.metricstore
Specifies the available timeframes for Metric aggregation.
aggPartition(S) - Method in interface org.apache.storm.trident.fluent.GlobalAggregationScheme
 
aggPartition(GroupedStream) - Method in class org.apache.storm.trident.fluent.GroupedStream
 
aggPreMergeCompPageBolt(Map<String, Object>, String, boolean) - Static method in class org.apache.storm.stats.StatsUtil
pre-merge component page bolt stats from an executor heartbeat 1.
aggPreMergeCompPageSpout(Map<String, Object>, String, boolean) - Static method in class org.apache.storm.stats.StatsUtil
pre-merge component page spout stats from an executor heartbeat 1.
aggPreMergeTopoPageBolt(Map<String, Object>, String, boolean) - Static method in class org.apache.storm.stats.StatsUtil
pre-merge component stats of specified bolt id.
aggPreMergeTopoPageSpout(Map<String, Object>, String, boolean) - Static method in class org.apache.storm.stats.StatsUtil
pre-merge component stats of specified spout id and returns { comp id -> comp-stats }.
aggregate(CombinerAggregator<? super T, A, ? extends R>) - Method in class org.apache.storm.streams.Stream
Aggregates the values in this stream using the aggregator.
aggregate(R, BiFunction<? super R, ? super T, ? extends R>, BiFunction<? super R, ? super R, ? extends R>) - Method in class org.apache.storm.streams.Stream
Aggregates the values in this stream using the given initial value, accumulator and combiner.
aggregate(Aggregator, Fields) - Method in class org.apache.storm.trident.fluent.ChainedAggregatorDeclarer
 
aggregate(Fields, Aggregator, Fields) - Method in class org.apache.storm.trident.fluent.ChainedAggregatorDeclarer
 
aggregate(CombinerAggregator, Fields) - Method in class org.apache.storm.trident.fluent.ChainedAggregatorDeclarer
 
aggregate(Fields, CombinerAggregator, Fields) - Method in class org.apache.storm.trident.fluent.ChainedAggregatorDeclarer
 
aggregate(ReducerAggregator, Fields) - Method in class org.apache.storm.trident.fluent.ChainedAggregatorDeclarer
 
aggregate(Fields, ReducerAggregator, Fields) - Method in class org.apache.storm.trident.fluent.ChainedAggregatorDeclarer
 
aggregate(Aggregator, Fields) - Method in interface org.apache.storm.trident.fluent.ChainedFullAggregatorDeclarer
 
aggregate(Fields, Aggregator, Fields) - Method in interface org.apache.storm.trident.fluent.ChainedFullAggregatorDeclarer
 
aggregate(CombinerAggregator, Fields) - Method in interface org.apache.storm.trident.fluent.ChainedFullAggregatorDeclarer
 
aggregate(Fields, CombinerAggregator, Fields) - Method in interface org.apache.storm.trident.fluent.ChainedFullAggregatorDeclarer
 
aggregate(ReducerAggregator, Fields) - Method in interface org.apache.storm.trident.fluent.ChainedFullAggregatorDeclarer
 
aggregate(Fields, ReducerAggregator, Fields) - Method in interface org.apache.storm.trident.fluent.ChainedFullAggregatorDeclarer
 
aggregate(Aggregator, Fields) - Method in class org.apache.storm.trident.fluent.GroupedStream
 
aggregate(Fields, Aggregator, Fields) - Method in class org.apache.storm.trident.fluent.GroupedStream
 
aggregate(CombinerAggregator, Fields) - Method in class org.apache.storm.trident.fluent.GroupedStream
 
aggregate(Fields, CombinerAggregator, Fields) - Method in class org.apache.storm.trident.fluent.GroupedStream
 
aggregate(ReducerAggregator, Fields) - Method in class org.apache.storm.trident.fluent.GroupedStream
 
aggregate(Fields, ReducerAggregator, Fields) - Method in class org.apache.storm.trident.fluent.GroupedStream
 
aggregate(T, TridentTuple, TridentCollector) - Method in interface org.apache.storm.trident.operation.Aggregator
 
aggregate(ComparisonAggregator.State, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.builtin.ComparisonAggregator
 
aggregate(FirstN.FirstNAgg.State, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.builtin.FirstN.FirstNAgg
 
aggregate(PriorityQueue, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.builtin.FirstN.FirstNSortedAgg
 
aggregate(ChainedResult, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.ChainedAggregatorImpl
 
aggregate(Result, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.CombinerAggregatorCombineImpl
 
aggregate(Object[], TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.GroupedAggregator
 
aggregate(Result, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.ReducerAggregatorImpl
 
aggregate(SingleEmitAggregator.SingleEmitState, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.operation.impl.SingleEmitAggregator
 
aggregate(Aggregator, Fields) - Method in class org.apache.storm.trident.Stream
 
aggregate(Fields, Aggregator, Fields) - Method in class org.apache.storm.trident.Stream
 
aggregate(CombinerAggregator, Fields) - Method in class org.apache.storm.trident.Stream
 
aggregate(Fields, CombinerAggregator, Fields) - Method in class org.apache.storm.trident.Stream
 
aggregate(ReducerAggregator, Fields) - Method in class org.apache.storm.trident.Stream
 
aggregate(Fields, ReducerAggregator, Fields) - Method in class org.apache.storm.trident.Stream
 
aggregate(CountAsAggregator.State, TridentTuple, TridentCollector) - Method in class org.apache.storm.trident.testing.CountAsAggregator
 
aggregateAverages(List<Map<String, Map<K, Double>>>, List<Map<String, Map<K, Long>>>) - Static method in class org.apache.storm.stats.StatsUtil
compute an weighted average from a list of average maps and a corresponding count maps extracted from a list of ExecutorSummary.
aggregateAvgStreams(Map<String, Map<K, Double>>, Map<String, Map<K, Long>>) - Static method in class org.apache.storm.stats.StatsUtil
aggregate weighted average of all streams.
aggregateBoltStats(List<ExecutorSummary>, boolean) - Static method in class org.apache.storm.stats.StatsUtil
aggregate bolt stats.
aggregateBoltStreams(Map<String, Map>) - Static method in class org.apache.storm.stats.StatsUtil
aggregate all bolt streams.
aggregateByKey(R, BiFunction<? super R, ? super V, ? extends R>, BiFunction<? super R, ? super R, ? extends R>) - Method in class org.apache.storm.streams.PairStream
Aggregates the values for each key of this stream using the given initial value, accumulator and combiner.
aggregateByKey(CombinerAggregator<? super V, A, ? extends R>) - Method in class org.apache.storm.streams.PairStream
Aggregates the values for each key of this stream using the given CombinerAggregator.
AggregateByKeyProcessor<K,V,A,R> - Class in org.apache.storm.streams.processors
 
AggregateByKeyProcessor(CombinerAggregator<V, A, R>) - Constructor for class org.apache.storm.streams.processors.AggregateByKeyProcessor
 
AggregateByKeyProcessor(CombinerAggregator<V, A, R>, boolean) - Constructor for class org.apache.storm.streams.processors.AggregateByKeyProcessor
 
aggregateCommonStats(List<ExecutorSummary>) - Static method in class org.apache.storm.stats.StatsUtil
aggregate common stats from a spout/bolt, called in aggregateSpoutStats/aggregateBoltStats.
aggregateCompStats(String, boolean, List<Map<String, Object>>, String) - Static method in class org.apache.storm.stats.StatsUtil
Aggregate the stats for a component over a given window of time.
aggregateCounts(List<Map<String, Map<T, Long>>>) - Static method in class org.apache.storm.stats.StatsUtil
aggregate a list of count maps into one map.
aggregateCountStreams(Map<String, Map<K, V>>) - Static method in class org.apache.storm.stats.StatsUtil
aggregate count streams by window.
AggregateExample - Class in org.apache.storm.starter.streams
An example that illustrates the global aggregate.
AggregateExample() - Constructor for class org.apache.storm.starter.streams.AggregateExample
 
AggregateProcessor<T,A,R> - Class in org.apache.storm.streams.processors
 
AggregateProcessor(CombinerAggregator<T, A, R>) - Constructor for class org.apache.storm.streams.processors.AggregateProcessor
 
AggregateProcessor(CombinerAggregator<T, A, R>, boolean) - Constructor for class org.apache.storm.streams.processors.AggregateProcessor
 
AggregateProcessor - Class in org.apache.storm.trident.planner.processor
 
AggregateProcessor(Fields, Aggregator) - Constructor for class org.apache.storm.trident.planner.processor.AggregateProcessor
 
aggregateSpoutStats(List<ExecutorSummary>, boolean) - Static method in class org.apache.storm.stats.StatsUtil
aggregate spout stats.
aggregateSpoutStreams(Map<String, Map>) - Static method in class org.apache.storm.stats.StatsUtil
aggregate all spout streams.
aggregator - Variable in class org.apache.storm.streams.processors.MergeAggregateByKeyProcessor
 
Aggregator<T> - Interface in org.apache.storm.trident.operation
 
aggregator - Variable in class org.apache.storm.trident.windowing.AbstractTridentWindowManager
 
aggSpoutExecWinStats(Map<String, Object>, Map<String, Object>, boolean) - Static method in class org.apache.storm.stats.StatsUtil
aggregate windowed stats from a spout executor stats with a Map of accumulated stats.
aggSpoutLatAndCount(Map<String, Double>, Map<String, Long>) - Static method in class org.apache.storm.stats.StatsUtil
aggregate number acked and complete latencies across all streams.
aggSpoutStreamsLatAndCount(Map<K, Double>, Map<K, Long>) - Static method in class org.apache.storm.stats.StatsUtil
Aggregates number acked and complete latencies.
aggTopoExecsStats(String, Map, Map, Map<List<Integer>, Map<String, Object>>, StormTopology, String, boolean, IStormClusterState) - Static method in class org.apache.storm.stats.StatsUtil
aggregate topo executors stats.
aggTopoExecStats(String, boolean, Map<String, Object>, Map<String, Object>, String) - Static method in class org.apache.storm.stats.StatsUtil
A helper function that does the common work to aggregate stats of one executor with the given map for the topology page.
aggWorkerStats(String, String, Map<Integer, String>, Map<List<Integer>, Map<String, Object>>, Map<List<Long>, List<Object>>, Map<String, String>, Map<WorkerSlot, WorkerResources>, boolean, boolean, String, String) - Static method in class org.apache.storm.stats.StatsUtil
aggregate statistics per worker for a topology.
all() - Static method in class org.apache.storm.cassandra.DynamicStatementBuilder
Includes all tuple fields.
all() - Static method in class org.apache.storm.coordination.CoordinatedBolt.SourceArgs
 
all(NullStruct) - Static method in class org.apache.storm.generated.Grouping
 
ALL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
all() - Static method in class org.apache.storm.trident.topology.TridentBoltExecutor.CoordType
 
allComponents(StormTopology) - Static method in class org.apache.storm.daemon.StormCommon
 
AllGrouper() - Constructor for class org.apache.storm.daemon.GrouperFactory.AllGrouper
 
allGrouping() - Method in interface org.apache.storm.drpc.LinearDRPCInputDeclarer
 
allGrouping(String) - Method in interface org.apache.storm.drpc.LinearDRPCInputDeclarer
 
allGrouping(String) - Method in interface org.apache.storm.topology.InputDeclarer
The stream is replicated across all the bolt’s tasks.
allGrouping(String, String) - Method in interface org.apache.storm.topology.InputDeclarer
The stream is replicated across all the bolt’s tasks.
allGrouping(String) - Method in class org.apache.storm.topology.TopologyBuilder.BoltGetter
 
allGrouping(String, String) - Method in class org.apache.storm.topology.TopologyBuilder.BoltGetter
 
ALLOCATE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
allocateBuffer(ChannelHandlerContext, INettySerializable, boolean) - Method in class org.apache.storm.messaging.netty.NettySerializableMessageEncoder
 
allOutputFields - Variable in class org.apache.storm.trident.planner.Node
 
ALLOW - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
AllResources(String) - Constructor for class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy.AllResources
 
AllResources(BaseResourceAwareStrategy.AllResources) - Constructor for class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy.AllResources
 
AllResources(List<BaseResourceAwareStrategy.ObjectResources>, NormalizedResourceOffer, NormalizedResourceOffer, String) - Constructor for class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy.AllResources
 
allSlotsAvailableForScheduling(Collection<SupervisorDetails>, Topologies, Set<String>) - Method in class org.apache.storm.daemon.nimbus.Nimbus.StandaloneINimbus
 
allSlotsAvailableForScheduling(Collection<SupervisorDetails>, Topologies, Set<String>) - Method in interface org.apache.storm.scheduler.INimbus
Returns all slots that are available for the next round of scheduling.
allSupervisorInfo() - Method in interface org.apache.storm.cluster.IStormClusterState
Get all of the supervisors with the ID as the key.
allSupervisorInfo(Runnable) - Method in interface org.apache.storm.cluster.IStormClusterState
Get all supervisor info.
AlreadyAliveException - Exception in org.apache.storm.generated
 
AlreadyAliveException() - Constructor for exception org.apache.storm.generated.AlreadyAliveException
 
AlreadyAliveException(String) - Constructor for exception org.apache.storm.generated.AlreadyAliveException
 
AlreadyAliveException(AlreadyAliveException) - Constructor for exception org.apache.storm.generated.AlreadyAliveException
Performs a deep copy on other.
AlreadyAliveException._Fields - Enum in org.apache.storm.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ALTER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
AlternateRackDNSToSwitchMapping - Class in org.apache.storm.testing
This class implements the DNSToSwitchMapping interface It alternates bewteen RACK1 and RACK2 for the hosts.
AlternateRackDNSToSwitchMapping() - Constructor for class org.apache.storm.testing.AlternateRackDNSToSwitchMapping
 
ALWAYS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
AnchoredWordCount - Class in org.apache.storm.starter
 
AnchoredWordCount() - Constructor for class org.apache.storm.starter.AnchoredWordCount
 
AnchoredWordCount.RandomSentenceSpout - Class in org.apache.storm.starter
 
AnchoredWordCount.SplitSentence - Class in org.apache.storm.starter
 
AnchoredWordCount.WordCount - Class in org.apache.storm.starter
 
AND - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
anonymize() - Method in class org.apache.storm.loadgen.TopologyLoadConf
Create a new version of this topology with identifiable information removed.
ANOTHER_BOLT - Static variable in class org.apache.storm.jms.example.ExampleJmsTopology
 
ANY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
anyNonCpuOverZero() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
Are any of the non cpu resources positive.
AppendCollector - Class in org.apache.storm.trident.planner.processor
 
AppendCollector(TridentContext) - Constructor for class org.apache.storm.trident.planner.processor.AppendCollector
 
apply(PreparedStatement, List<Column>) - Method in interface org.apache.storm.cassandra.query.impl.PreparedStatementBinder
 
apply(PreparedStatement, List<Column>) - Method in class org.apache.storm.cassandra.query.impl.PreparedStatementBinder.CQL3NamedSettersBinder
apply(PreparedStatement, List<Column>) - Method in class org.apache.storm.cassandra.query.impl.PreparedStatementBinder.DefaultBinder
apply(ConsumerRecord<K, V>) - Method in class org.apache.storm.flux.examples.OnlyValueRecordTranslator
 
apply(ConsumerRecord<K, V>) - Method in class org.apache.storm.kafka.spout.ByTopicRecordTranslator
 
apply(ConsumerRecord<K, V>) - Method in class org.apache.storm.kafka.spout.DefaultRecordTranslator
 
apply(V) - Method in interface org.apache.storm.kafka.spout.Func
 
apply(ConsumerRecord<K, V>) - Method in interface org.apache.storm.kafka.spout.RecordTranslator
Translate the ConsumerRecord into a list of objects that can be emitted.
apply(ConsumerRecord<K, V>) - Method in class org.apache.storm.kafka.spout.SimpleRecordTranslator
 
apply(T) - Method in interface org.apache.storm.localizer.IOFunction
 
apply(IMetricsConsumer.DataPoint) - Method in class org.apache.storm.metric.filter.FilterByMetricName
 
apply(ConsumerRecord<ByteBuffer, ByteBuffer>) - Method in class org.apache.storm.sql.kafka.RecordTranslatorSchemeAdapter
 
APPLY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
apply(Values) - Method in class org.apache.storm.sql.runtime.streams.functions.EvaluationCalc
 
apply(Values) - Method in class org.apache.storm.sql.runtime.streams.functions.EvaluationFunction
 
apply(Values) - Method in class org.apache.storm.sql.runtime.streams.functions.StreamInsertMapToPairFunction
 
apply(Tuple) - Method in class org.apache.storm.sql.runtime.streams.functions.StreamsScanTupleValueMapper
 
apply(Long, T) - Method in class org.apache.storm.streams.operations.aggregators.Count
 
apply(Long, Number) - Method in class org.apache.storm.streams.operations.aggregators.LongSum
 
apply(T, U) - Method in interface org.apache.storm.streams.operations.BiFunction
Applies this function to the given arguments.
apply(A, T) - Method in interface org.apache.storm.streams.operations.CombinerAggregator
Updates the accumulator by applying the current accumulator with the value.
apply(T) - Method in interface org.apache.storm.streams.operations.Function
Applies this function to the given argument.
apply(T) - Method in class org.apache.storm.streams.operations.IdentityFunction
 
apply(Tuple) - Method in class org.apache.storm.streams.operations.mappers.PairValueMapper
 
apply(Tuple) - Method in class org.apache.storm.streams.operations.mappers.ValueMapper
 
apply(Tuple) - Method in class org.apache.storm.streams.operations.mappers.ValuesMapper
 
apply(V1, V2) - Method in class org.apache.storm.streams.operations.PairValueJoiner
Joins two values and produces a Pair of the values as the result.
apply(T, T) - Method in interface org.apache.storm.streams.operations.Reducer
Applies this function to the given arguments.
apply(S, T) - Method in interface org.apache.storm.streams.operations.StateUpdater
Returns a new state by applying the value on the current state.
apply(V1, V2) - Method in interface org.apache.storm.streams.operations.ValueJoiner
Joins two values and produces a result.
apply(Stream) - Method in interface org.apache.storm.trident.operation.Assembly
Applies the Assembly to a given Stream.
apply(Stream) - Method in class org.apache.storm.trident.operation.builtin.FirstN
 
applyAssembly(Assembly) - Method in class org.apache.storm.trident.Stream
Applies an Assembly to this Stream.
applyOn(TopologyContext) - Method in class org.apache.storm.hooks.info.BoltAckInfo
 
applyOn(TopologyContext) - Method in class org.apache.storm.hooks.info.BoltExecuteInfo
 
applyOn(TopologyContext) - Method in class org.apache.storm.hooks.info.BoltFailInfo
 
applyOn(TopologyContext) - Method in class org.apache.storm.hooks.info.EmitInfo
 
applyOn(TopologyContext) - Method in class org.apache.storm.hooks.info.SpoutAckInfo
 
applyOn(TopologyContext) - Method in class org.apache.storm.hooks.info.SpoutFailInfo
 
applyTo(ISeq) - Method in class org.apache.storm.clojure.ClojureTuple
 
applyUUIDToFileName(String) - Static method in class org.apache.storm.dependency.DependencyBlobStoreUtils
 
APPROX_NUMERIC_LITERAL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
ARCHIVE_DIR - Static variable in class org.apache.storm.hdfs.spout.Configs
Deprecated.
ARE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
areAllConnectionsReady() - Method in class org.apache.storm.daemon.worker.WorkerState
 
areAllExecsScheduled() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.ConstraintSolverStrategy.SearcherState
 
areAllProcessesDead() - Method in class org.apache.storm.daemon.supervisor.Container
 
areAllProcessesDead() - Method in interface org.apache.storm.daemon.supervisor.Killable
Check whether all processes are dead.
areAllProcessesDead() - Method in class org.apache.storm.daemon.supervisor.LocalContainer
 
areAnyOverZero() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceOffer
 
areAnyOverZero() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
 
areAnyOverZero() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
Are any of the resources positive.
areAnyOverZero() - Method in interface org.apache.storm.scheduler.resource.normalization.NormalizedResourcesWithMemory
Return true if any of the resources are > 0.
areKeysSkewed - Variable in class org.apache.storm.loadgen.OutputStream
 
areSearchLimitsExceeded() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.ConstraintSolverStrategy.SearcherState
 
areTaskIdsNeeded() - Method in class org.apache.storm.multilang.ShellMsg
 
areWorkerTokensEnabledServer(ThriftServer, Map<String, Object>) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
Check if worker tokens should be enabled on the server side or not.
areWorkerTokensEnabledServer(ThriftConnectionType, Map<String, Object>) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
Check if worker tokens should be enabled on the server side or not (for a given server).
areWorkerTokensSupported() - Method in class org.apache.storm.security.auth.digest.DigestSaslTransportPlugin
 
areWorkerTokensSupported() - Method in interface org.apache.storm.security.auth.ITransportPlugin
Check if worker tokens are supported by this transport.
areWorkerTokensSupported() - Method in class org.apache.storm.security.auth.kerberos.KerberosSaslTransportPlugin
 
arg(String) - Static method in class org.apache.storm.command.CLI
Add a named argument.
arg(String, CLI.Assoc) - Static method in class org.apache.storm.command.CLI
Add a named argument.
arg(String, CLI.Parse) - Static method in class org.apache.storm.command.CLI
Add a named argument.
arg(String, CLI.Parse, CLI.Assoc) - Static method in class org.apache.storm.command.CLI
Add a named argument.
arg(String) - Method in class org.apache.storm.command.CLI.CLIBuilder
Add a named argument.
arg(String, CLI.Assoc) - Method in class org.apache.storm.command.CLI.CLIBuilder
Add a named argument.
arg(String, CLI.Parse) - Method in class org.apache.storm.command.CLI.CLIBuilder
Add a named argument.
arg(String, CLI.Parse, CLI.Assoc) - Method in class org.apache.storm.command.CLI.CLIBuilder
Add a named argument.
Arg(List, SqlAbstractParserImpl.ExprContext) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
 
Arg0(List, SqlAbstractParserImpl.ExprContext) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
 
ARGS_STREAM - Static variable in class org.apache.storm.drpc.PrepareRequest
 
ARRAY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
ARRAY_MAX_CARDINALITY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
ArrayConstructor() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
Parses an ARRAY constructor
ArrayListSerializer - Class in org.apache.storm.serialization.types
 
ArrayListSerializer() - Constructor for class org.apache.storm.serialization.types.ArrayListSerializer
 
ArtifactoryConfigLoader - Class in org.apache.storm.scheduler.utils
A dynamic loader that can load scheduler configurations for user resource guarantees from Artifactory (an artifact repository manager).
ArtifactoryConfigLoader(Map<String, Object>) - Constructor for class org.apache.storm.scheduler.utils.ArtifactoryConfigLoader
 
ArtifactoryConfigLoaderFactory - Class in org.apache.storm.scheduler.utils
Factory class for ArtifactoryConfigLoader.
ArtifactoryConfigLoaderFactory() - Constructor for class org.apache.storm.scheduler.utils.ArtifactoryConfigLoaderFactory
 
artifactToString(Artifact) - Static method in class org.apache.storm.submit.dependency.AetherUtils
Convert Artifact object to String for printing.
as(String) - Method in class org.apache.storm.cassandra.query.selector.FieldSelector
Sets an alias for this field.
AS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
AS_INT - Static variable in class org.apache.storm.command.CLI
Parse function to return an Integer.
AS_STRING - Static variable in class org.apache.storm.command.CLI
Noop parse function, returns the String.
ASC - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
ASENSITIVE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
asMap() - Method in class org.apache.storm.windowing.persistence.SimpleWindowPartitionCache
 
asMap() - Method in interface org.apache.storm.windowing.persistence.WindowPartitionCache
Return a ConcurrentMap view of the current entries in the cache.
asSchedulingResult() - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.ConstraintSolverStrategy.SolverResult
 
Assembly - Interface in org.apache.storm.trident.operation
The Assembly interface provides a means to encapsulate logic applied to a Stream.
assertFull() - Method in enum org.apache.storm.daemon.supervisor.Container.ContainerType
 
ASSERTION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
assertValidTopologyForModification(String) - Method in class org.apache.storm.scheduler.Cluster
Check if the given topology is allowed for modification right now.
assertValidTopologyForModification(String) - Method in class org.apache.storm.scheduler.SingleTopologyCluster
 
assign(BoltDeclarer, InputStream) - Method in enum org.apache.storm.loadgen.GroupingType
 
assign(WorkerSlot, String, Collection<ExecutorDetails>) - Method in class org.apache.storm.scheduler.Cluster
Assign the slot to the executors for this topology.
assign(SchedulerAssignment, boolean) - Method in class org.apache.storm.scheduler.Cluster
Assign everything for the given topology.
assign(String, Collection<ExecutorDetails>, Cluster) - Method in class org.apache.storm.scheduler.multitenant.Node
Assign a free slot on the node to the following topology and executors.
assign(WorkerSlot, TopologyDetails, Collection<ExecutorDetails>) - Method in class org.apache.storm.scheduler.resource.RasNode
Assigns a worker to a node.
assign(WorkerSlot, Collection<ExecutorDetails>) - Method in class org.apache.storm.scheduler.SchedulerAssignmentImpl
Deprecated.
assign(WorkerSlot, Collection<ExecutorDetails>, WorkerResources) - Method in class org.apache.storm.scheduler.SchedulerAssignmentImpl
Assign the slot to executors.
AssignableMetric - Class in org.apache.storm.metric.api
 
AssignableMetric(Object) - Constructor for class org.apache.storm.metric.api.AssignableMetric
 
AssignableShellMetric - Class in org.apache.storm.metric.api.rpc
 
AssignableShellMetric(Object) - Constructor for class org.apache.storm.metric.api.rpc.AssignableShellMetric
 
assigned(Collection<Integer>) - Method in class org.apache.storm.daemon.supervisor.StandaloneSupervisor
 
assigned(Collection<Integer>) - Method in interface org.apache.storm.scheduler.ISupervisor
 
assignedCpu - Variable in class org.apache.storm.scheduler.resource.strategies.priority.DefaultSchedulingPriorityStrategy.SimulatedUser
 
assignedMemory - Variable in class org.apache.storm.scheduler.resource.strategies.priority.DefaultSchedulingPriorityStrategy.SimulatedUser
 
assignment - Variable in class org.apache.storm.daemon.supervisor.Container
 
Assignment - Class in org.apache.storm.generated
 
Assignment() - Constructor for class org.apache.storm.generated.Assignment
 
Assignment(String) - Constructor for class org.apache.storm.generated.Assignment
 
Assignment(Assignment) - Constructor for class org.apache.storm.generated.Assignment
Performs a deep copy on other.
ASSIGNMENT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
Assignment._Fields - Enum in org.apache.storm.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
AssignmentDistributionService - Class in org.apache.storm.nimbus
A service for distributing master assignments to supervisors, this service makes the assignments notification asynchronous.
AssignmentDistributionService() - Constructor for class org.apache.storm.nimbus.AssignmentDistributionService
 
assignmentInfo(String, Runnable) - Method in interface org.apache.storm.cluster.IStormClusterState
Get the assignment based on storm id from local backend.
assignmentInfo(String, Runnable) - Method in class org.apache.storm.cluster.StormClusterStateImpl
 
assignmentInfoWithVersion(String, Runnable) - Method in interface org.apache.storm.cluster.IStormClusterState
 
assignmentInfoWithVersion(String, Runnable) - Method in class org.apache.storm.cluster.StormClusterStateImpl
 
assignmentPath(String) - Static method in class org.apache.storm.cluster.ClusterUtils
 
assignments() - Method in interface org.apache.storm.assignments.ILocalAssignmentsBackend
List all the storm runtime ids of local assignments.
assignments() - Method in class org.apache.storm.assignments.InMemoryAssignmentBackend
 
assignments(Runnable) - Method in interface org.apache.storm.cluster.IStormClusterState
 
assignments(Runnable) - Method in class org.apache.storm.cluster.StormClusterStateImpl
 
ASSIGNMENTS_ROOT - Static variable in class org.apache.storm.cluster.ClusterUtils
 
ASSIGNMENTS_SUBTREE - Static variable in class org.apache.storm.cluster.ClusterUtils
 
assignmentsInfo() - Method in interface org.apache.storm.assignments.ILocalAssignmentsBackend
Get all the local assignments of local state.
assignmentsInfo() - Method in class org.apache.storm.assignments.InMemoryAssignmentBackend
 
assignmentsInfo() - Method in interface org.apache.storm.cluster.IStormClusterState
Get all the topologies assignments mapping stormId -> Assignment from local backend.
assignmentsInfo() - Method in class org.apache.storm.cluster.StormClusterStateImpl
 
assignmentVersion(String, Runnable) - Method in interface org.apache.storm.cluster.IStormClusterState
 
assignmentVersion(String, Runnable) - Method in class org.apache.storm.cluster.StormClusterStateImpl
 
assignPartitions(Consumer<K, V>, Set<TopicPartition>, ConsumerRebalanceListener) - Method in class org.apache.storm.kafka.spout.subscription.TopicAssigner
Assign partitions to the KafkaConsumer.
assignSingleExecutor(WorkerSlot, ExecutorDetails, TopologyDetails) - Method in class org.apache.storm.scheduler.resource.RasNode
Assign a single executor to a slot, even if other things are in the slot.
assignSlots(Topologies, Map<String, Collection<WorkerSlot>>) - Method in class org.apache.storm.daemon.nimbus.Nimbus.StandaloneINimbus
 
assignSlots(Topologies, Map<String, Collection<WorkerSlot>>) - Method in interface org.apache.storm.scheduler.INimbus
this is called after the assignment is changed in ZK.
assignSlotTo(Node) - Method in class org.apache.storm.scheduler.multitenant.NodePool.RoundRobinSlotScheduler
Assign a slot to the given node.
assoc(Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
 
assoc(Object, Object) - Method in class org.apache.storm.clojure.IndifferentAccessMap
 
assoc(Object, Object) - Method in interface org.apache.storm.command.CLI.Assoc
Associate a value into something else.
assocEx(Object, Object) - Method in class org.apache.storm.clojure.ClojureTuple
 
assocEx(Object, Object) - Method in class org.apache.storm.clojure.IndifferentAccessMap
 
ASYMMETRIC - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
async(CQLStatementBuilder...) - Static method in class org.apache.storm.cassandra.DynamicStatementBuilder
Builds multiple statements which will be executed asynchronously.
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.storm.generated.DistributedRPC.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Supervisor.AsyncClient
 
AsyncExecutor<T> - Class in org.apache.storm.cassandra.executor
Service to asynchronously executes cassandra statements.
AsyncExecutor(Session, AsyncResultHandler<T>) - Constructor for class org.apache.storm.cassandra.executor.AsyncExecutor
Creates a new AsyncExecutor instance.
AsyncExecutor.MultiFailedException - Exception in org.apache.storm.cassandra.executor
 
AsyncExecutorProvider - Class in org.apache.storm.cassandra.executor
This class must be used to obtain a single instance of AsyncExecutor per storm executor.
AsyncExecutorProvider() - Constructor for class org.apache.storm.cassandra.executor.AsyncExecutorProvider
 
AsyncLocalizer - Class in org.apache.storm.localizer
Downloads and caches blobs locally.
AsyncLocalizer(Map<String, Object>, StormMetricsRegistry) - Constructor for class org.apache.storm.localizer.AsyncLocalizer
 
asyncLoop(Callable, boolean, Thread.UncaughtExceptionHandler, int, boolean, boolean, String) - Static method in class org.apache.storm.utils.Utils
Creates a thread that calls the given code repeatedly, sleeping for an interval of seconds equal to the return value of the previous call.
asyncLoop(Callable, String, Thread.UncaughtExceptionHandler) - Static method in class org.apache.storm.utils.Utils
Convenience method used when only the function and name suffix are given.
asyncLoop(Callable) - Static method in class org.apache.storm.utils.Utils
Convenience method used when only the function is given.
AsyncProcessor(I) - Constructor for class org.apache.storm.generated.DistributedRPC.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.storm.generated.DistributedRPC.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class org.apache.storm.generated.Supervisor.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.storm.generated.Supervisor.AsyncProcessor
 
AsyncResultHandler<T> - Interface in org.apache.storm.cassandra.executor
Default handler for batch asynchronous execution.
AsyncResultSetHandler<T> - Interface in org.apache.storm.cassandra.executor
Default handler for batch asynchronous execution.
AT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
ATOMIC - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
AtomicOutputStream - Class in org.apache.storm.blobstore
An output stream where all of the data is committed on close, or can be canceled with cancel.
AtomicOutputStream() - Constructor for class org.apache.storm.blobstore.AtomicOutputStream
 
AtomicRowExpression() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
Parses an atomic row expression.
ATTRIBUTE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
ATTRIBUTES - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
authenticate(boolean, String, String) - Static method in class org.apache.storm.hive.common.HiveUtils
 
authenticated(Channel) - Method in interface org.apache.storm.messaging.netty.ISaslServer
 
AuthenticationFailed(String, Exception) - Constructor for exception org.apache.storm.hive.common.HiveUtils.AuthenticationFailed
 
AuthNimbusOp - Annotation Type in org.apache.storm.daemon.ui.resources
 
AUTHORIZATION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
AuthorizationException - Exception in org.apache.storm.generated
 
AuthorizationException() - Constructor for exception org.apache.storm.generated.AuthorizationException
 
AuthorizationException(String) - Constructor for exception org.apache.storm.generated.AuthorizationException
 
AuthorizationException(AuthorizationException) - Constructor for exception org.apache.storm.generated.AuthorizationException
Performs a deep copy on other.
AuthorizationException._Fields - Enum in org.apache.storm.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
AuthorizationExceptionMapper - Class in org.apache.storm.daemon.common
 
AuthorizationExceptionMapper() - Constructor for class org.apache.storm.daemon.common.AuthorizationExceptionMapper
 
AuthorizationExceptionMapper - Class in org.apache.storm.daemon.ui.exceptionmappers
 
AuthorizationExceptionMapper() - Constructor for class org.apache.storm.daemon.ui.exceptionmappers.AuthorizationExceptionMapper
 
authorizedGroups - Variable in class org.apache.storm.security.auth.authorizer.ImpersonationAuthorizer.ImpersonationACL
 
authorizedHosts - Variable in class org.apache.storm.security.auth.authorizer.ImpersonationAuthorizer.ImpersonationACL
 
AuthorizedUserFilter - Class in org.apache.storm.daemon.ui.filters
 
AuthorizedUserFilter() - Constructor for class org.apache.storm.daemon.ui.filters.AuthorizedUserFilter
 
autoCreatePartitions - Variable in class org.apache.storm.hive.common.HiveOptions
 
AutoHBase - Class in org.apache.storm.hbase.security
Auto credentials plugin for HBase implementation.
AutoHBase() - Constructor for class org.apache.storm.hbase.security.AutoHBase
 
AutoHBaseCommand - Class in org.apache.storm.hbase.security
Command tool of Hive credential renewer.
AutoHBaseNimbus - Class in org.apache.storm.hbase.security
Auto credentials nimbus plugin for HBase implementation.
AutoHBaseNimbus() - Constructor for class org.apache.storm.hbase.security.AutoHBaseNimbus
 
AutoHDFS - Class in org.apache.storm.hdfs.security
Auto credentials plugin for HDFS implementation.
AutoHDFS() - Constructor for class org.apache.storm.hdfs.security.AutoHDFS
 
AutoHDFSCommand - Class in org.apache.storm.hdfs.security
Command tool of HDFS credential renewer.
AutoHDFSNimbus - Class in org.apache.storm.hdfs.security
Auto credentials nimbus plugin for HDFS implementation.
AutoHDFSNimbus() - Constructor for class org.apache.storm.hdfs.security.AutoHDFSNimbus
 
AutoHive - Class in org.apache.storm.hive.security
Auto credentials plugin for Hive implementation.
AutoHive() - Constructor for class org.apache.storm.hive.security.AutoHive
 
AutoHiveCommand - Class in org.apache.storm.hive.security
Command tool of Hive credential renewer.
AutoHiveNimbus - Class in org.apache.storm.hive.security
Auto credentials nimbus plugin for Hive implementation.
AutoHiveNimbus() - Constructor for class org.apache.storm.hive.security.AutoHiveNimbus
 
AutoSSL - Class in org.apache.storm.security.auth
This plugin is intended to be used for user topologies to send SSL keystore/truststore files to the remote workers.
AutoSSL() - Constructor for class org.apache.storm.security.auth.AutoSSL
 
AutoTGT - Class in org.apache.storm.security.auth.kerberos
Automatically take a user’s TGT, and push it, and renew it in Nimbus.
AutoTGT() - Constructor for class org.apache.storm.security.auth.kerberos.AutoTGT
 
AutoTGTKrb5LoginModule - Class in org.apache.storm.security.auth.kerberos
Custom LoginModule to enable Auto Login based on cached ticket.
AutoTGTKrb5LoginModule() - Constructor for class org.apache.storm.security.auth.kerberos.AutoTGTKrb5LoginModule
 
AutoTGTKrb5LoginModuleTest - Class in org.apache.storm.security.auth.kerberos
Custom LoginModule extended for testing.
AutoTGTKrb5LoginModuleTest() - Constructor for class org.apache.storm.security.auth.kerberos.AutoTGTKrb5LoginModuleTest
 
available() - Method in class org.apache.storm.blobstore.BlobStore.BlobStoreFileInputStream
 
available() - Method in class org.apache.storm.blobstore.NimbusBlobStore.NimbusDownloadInputStream
 
availableResources - Variable in class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy.ObjectResources
 
AVG - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
AvroGenericRecordBolt - Class in org.apache.storm.hdfs.bolt
 
AvroGenericRecordBolt() - Constructor for class org.apache.storm.hdfs.bolt.AvroGenericRecordBolt
 
AvroGenericRecordHDFSWriter - Class in org.apache.storm.hdfs.common
 
AvroGenericRecordHDFSWriter(FileRotationPolicy, Path, FSDataOutputStream, Schema) - Constructor for class org.apache.storm.hdfs.common.AvroGenericRecordHDFSWriter
 
AvroSchemaRegistry - Interface in org.apache.storm.hdfs.avro
 
AvroScheme - Class in org.apache.storm.sql.runtime.serde.avro
AvroScheme uses generic(without code generation) instead of specific(with code generation) readers.
AvroScheme(String, List<String>) - Constructor for class org.apache.storm.sql.runtime.serde.avro.AvroScheme
AvroScheme Constructor.
AvroSerializer - Class in org.apache.storm.sql.runtime.serde.avro
AvroSerializer uses generic(without code generation) instead of specific(with code generation) writers.
AvroSerializer(String, List<String>) - Constructor for class org.apache.storm.sql.runtime.serde.avro.AvroSerializer
AvroSerializer Constructor.
AvroUtils - Class in org.apache.storm.hdfs.avro
 
AvroUtils() - Constructor for class org.apache.storm.hdfs.avro.AvroUtils
 
awaitLeadership(long, TimeUnit) - Method in class org.apache.storm.daemon.nimbus.Nimbus
 
awaitLeadership(long, TimeUnit) - Method in interface org.apache.storm.nimbus.ILeaderElector
Wait for the caller to gain leadership.
awaitLeadership(long, TimeUnit) - Method in class org.apache.storm.testing.MockLeaderElector
 
awaitLeadership(long, TimeUnit) - Method in class org.apache.storm.zookeeper.LeaderElectorImp
 
AyncCQLResultSetValuesMapper - Interface in org.apache.storm.cassandra.query
A resultset mapper that.

B

BACK_QUOTED_IDENTIFIER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
BACKPRESSURE_ROOT - Static variable in class org.apache.storm.cluster.ClusterUtils
 
BACKPRESSURE_SUBTREE - Static variable in class org.apache.storm.cluster.ClusterUtils
 
backpressurePath(String, String, Long) - Static method in class org.apache.storm.cluster.ClusterUtils
 
backpressurePath(String, String) - Static method in class org.apache.storm.cluster.ClusterUtils
Get the backpressure znode full path.
BackPressureStatus - Class in org.apache.storm.messaging.netty
 
BackPressureStatus() - Constructor for class org.apache.storm.messaging.netty.BackPressureStatus
 
BackPressureStatus(String, Collection<Integer>, Collection<Integer>) - Constructor for class org.apache.storm.messaging.netty.BackPressureStatus
Constructor.
BackPressureStatusEncoder - Class in org.apache.storm.messaging.netty
 
BackPressureStatusEncoder(KryoValuesSerializer) - Constructor for class org.apache.storm.messaging.netty.BackPressureStatusEncoder
 
backpressureStormRoot(String) - Static method in class org.apache.storm.cluster.ClusterUtils
 
BackPressureTopo - Class in org.apache.storm.perf
 
BackPressureTopo() - Constructor for class org.apache.storm.perf.BackPressureTopo
 
backpressureTopologies() - Method in interface org.apache.storm.cluster.IStormClusterState
Deprecated.
backpressureTopologies() - Method in class org.apache.storm.cluster.StormClusterStateImpl
 
BackPressureTracker - Class in org.apache.storm.daemon.worker
Tracks the BackPressure status.
BackPressureTracker(String, Map<Integer, JCQueue>) - Constructor for class org.apache.storm.daemon.worker.BackPressureTracker
 
BackPressureTracker.BackpressureState - Class in org.apache.storm.daemon.worker
 
backtrack(Map<ExecutorDetails, String>, RasNode, WorkerSlot) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.ConstraintSolverStrategy.SearcherState
 
backtrackSearch(ConstraintSolverStrategy.SearcherState) - Method in class org.apache.storm.scheduler.resource.strategies.scheduling.ConstraintSolverStrategy
Try to schedule till successful or till limits (backtrack count or time) have been exceeded.
backup(int) - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
 
BAD_DIR - Static variable in class org.apache.storm.hdfs.spout.Configs
Deprecated.
badSupervisorsToleranceSlidingWindow - Variable in class org.apache.storm.scheduler.blacklist.BlacklistScheduler
 
BalancedTargetSelector() - Constructor for class org.apache.storm.grouping.PartialKeyGrouping.BalancedTargetSelector
 
Base64ToBinaryStateMigrationUtil - Class in org.apache.storm.redis.tools
 
Base64ToBinaryStateMigrationUtil(JedisPoolConfig) - Constructor for class org.apache.storm.redis.tools.Base64ToBinaryStateMigrationUtil
 
Base64ToBinaryStateMigrationUtil(RedisCommandsInstanceContainer) - Constructor for class org.apache.storm.redis.tools.Base64ToBinaryStateMigrationUtil
 
BASE_BLOBS_DIR_NAME - Static variable in class org.apache.storm.blobstore.BlobStore
 
BaseAggregator<T> - Class in org.apache.storm.trident.operation
 
BaseAggregator() - Constructor for class org.apache.storm.trident.operation.BaseAggregator
 
BaseBasicBolt - Class in org.apache.storm.topology.base
 
BaseBasicBolt() - Constructor for class org.apache.storm.topology.base.BaseBasicBolt
 
BaseBatchBolt<T> - Class in org.apache.storm.topology.base
 
BaseBatchBolt() - Constructor for class org.apache.storm.topology.base.BaseBatchBolt
 
BaseBeanFactory<T> - Class in org.apache.storm.cassandra.context
Base BeanProvider implementation.
BaseBeanFactory() - Constructor for class org.apache.storm.cassandra.context.BaseBeanFactory
 
BaseBinaryStateIterator<K,V> - Class in org.apache.storm.state
Base implementation of iterator over KeyValueState which encoded types of key and value are both binary type.
BaseBinaryStateIterator(Iterator<Map.Entry<byte[], byte[]>>, Iterator<Map.Entry<byte[], byte[]>>) - Constructor for class org.apache.storm.state.BaseBinaryStateIterator
Constructor.
BaseCassandraBolt<T> - Class in org.apache.storm.cassandra.bolt
A base cassandra bolt.
BaseCassandraBolt(CQLStatementTupleMapper, SimpleClientProvider) - Constructor for class org.apache.storm.cassandra.bolt.BaseCassandraBolt
Creates a new CassandraWriterBolt instance.
BaseCassandraBolt(CQLStatementTupleMapper) - Constructor for class org.apache.storm.cassandra.bolt.BaseCassandraBolt
Creates a new CassandraWriterBolt instance.
BaseComponent - Class in org.apache.storm.topology.base
 
BaseComponent() - Constructor for class org.apache.storm.topology.base.BaseComponent
 
BaseConfigurationDeclarer<T extends ComponentConfigurationDeclarer> - Class in org.apache.storm.topology
 
BaseConfigurationDeclarer() - Constructor for class org.apache.storm.topology.BaseConfigurationDeclarer
 
BaseCQLStatementTupleMapper - Class in org.apache.storm.cassandra.query
Default interface to map a ITuple to a CQL Statement.
BaseCQLStatementTupleMapper() - Constructor for class org.apache.storm.cassandra.query.BaseCQLStatementTupleMapper
 
BaseExecutionResultHandler - Class in org.apache.storm.cassandra
Simple ExecutionResultHandler which fail the incoming tuple when an DriverException is thrown.
BaseExecutionResultHandler() - Constructor for class org.apache.storm.cassandra.BaseExecutionResultHandler
 
BaseFilter - Class in org.apache.storm.trident.operation
 
BaseFilter() - Constructor for class org.apache.storm.trident.operation.BaseFilter
 
BaseFunction - Class in org.apache.storm.trident.operation
 
BaseFunction() - Constructor for class org.apache.storm.trident.operation.BaseFunction
 
BaseMultiReducer<T> - Class in org.apache.storm.trident.operation
 
BaseMultiReducer() - Constructor for class org.apache.storm.trident.operation.BaseMultiReducer
 
BaseOperation - Class in org.apache.storm.trident.operation
Convenience implementation of the Operation interface.
BaseOperation() - Constructor for class org.apache.storm.trident.operation.BaseOperation
 
BaseQueryFunction<S extends State,T> - Class in org.apache.storm.trident.state
 
BaseQueryFunction() - Constructor for class org.apache.storm.trident.state.BaseQueryFunction
 
BaseResourceAwareStrategy - Class in org.apache.storm.scheduler.resource.strategies.scheduling
 
BaseResourceAwareStrategy() - Constructor for class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy
 
BaseResourceAwareStrategy.AllResources - Class in org.apache.storm.scheduler.resource.strategies.scheduling
a class to contain individual object resources as well as cumulative stats.
BaseResourceAwareStrategy.ExistingScheduleFunc - Interface in org.apache.storm.scheduler.resource.strategies.scheduling
interface for calculating the number of existing executors scheduled on a object (rack or node).
BaseResourceAwareStrategy.ObjectResources - Class in org.apache.storm.scheduler.resource.strategies.scheduling
class to keep track of resources on a rack or node.
BaseRichBolt - Class in org.apache.storm.topology.base
 
BaseRichBolt() - Constructor for class org.apache.storm.topology.base.BaseRichBolt
 
BaseRichSpout - Class in org.apache.storm.topology.base
 
BaseRichSpout() - Constructor for class org.apache.storm.topology.base.BaseRichSpout
 
BaseStatefulBolt<T extends State> - Class in org.apache.storm.topology.base
 
BaseStatefulBolt() - Constructor for class org.apache.storm.topology.base.BaseStatefulBolt
 
BaseStatefulBoltExecutor - Class in org.apache.storm.topology
Base class that abstracts the common logic for executing bolts in a stateful topology.
BaseStatefulBoltExecutor() - Constructor for class org.apache.storm.topology.BaseStatefulBoltExecutor
 
BaseStatefulBoltExecutor.AnchoringOutputCollector - Class in org.apache.storm.topology
 
BaseStatefulWindowedBolt<T extends State> - Class in org.apache.storm.topology.base
 
BaseStatefulWindowedBolt() - Constructor for class org.apache.storm.topology.base.BaseStatefulWindowedBolt
 
BaseStateIterator<K,V,KENCODEDT,VENCODEDT> - Class in org.apache.storm.state
Base implementation of iterator over KeyValueState.
BaseStateIterator(Iterator<Map.Entry<KENCODEDT, VENCODEDT>>, Iterator<Map.Entry<KENCODEDT, VENCODEDT>>, Set<KENCODEDT>) - Constructor for class org.apache.storm.state.BaseStateIterator
Constructor.
BaseStateUpdater<S extends State> - Class in org.apache.storm.trident.state
 
BaseStateUpdater() - Constructor for class org.apache.storm.trident.state.BaseStateUpdater
 
BaseTaskHook - Class in org.apache.storm.hooks
 
BaseTaskHook() - Constructor for class org.apache.storm.hooks.BaseTaskHook
 
BaseTickTupleAwareRichBolt - Class in org.apache.storm.topology.base
This class is based on BaseRichBolt, but is aware of tick tuple.
BaseTickTupleAwareRichBolt() - Constructor for class org.apache.storm.topology.base.BaseTickTupleAwareRichBolt
 
BaseWindow<L,I> - Class in org.apache.storm.streams.windowing
 
BaseWindow() - Constructor for class org.apache.storm.streams.windowing.BaseWindow
 
BaseWindowConfig - Class in org.apache.storm.trident.windowing.config
 
BaseWindowConfig(int, int) - Constructor for class org.apache.storm.trident.windowing.config.BaseWindowConfig
 
BaseWindowedBolt - Class in org.apache.storm.topology.base
 
BaseWindowedBolt() - Constructor for class org.apache.storm.topology.base.BaseWindowedBolt
 
BaseWindowedBolt.Count - Class in org.apache.storm.topology.base
Holds a count value for count based windows and sliding intervals.
BaseWindowedBolt.Duration - Class in org.apache.storm.topology.base
Holds a Time duration for time based windows and sliding intervals.
BaseWindowStrategy<T> - Class in org.apache.storm.trident.windowing.strategy
 
BaseWindowStrategy(WindowConfig) - Constructor for class org.apache.storm.trident.windowing.strategy.BaseWindowStrategy
 
BaseWorkerHook - Class in org.apache.storm.hooks
A BaseWorkerHook is a noop implementation of IWorkerHook.
BaseWorkerHook() - Constructor for class org.apache.storm.hooks.BaseWorkerHook
 
BasicBoltExecutor - Class in org.apache.storm.topology
 
BasicBoltExecutor(IBasicBolt) - Constructor for class org.apache.storm.topology.BasicBoltExecutor
 
BasicContainer - Class in org.apache.storm.daemon.supervisor
A container that runs processes on the local box.
BasicContainer(Container.ContainerType, Map<String, Object>, String, int, int, LocalAssignment, ResourceIsolationInterface, LocalState, String, StormMetricsRegistry, ContainerMemoryTracker) - Constructor for class org.apache.storm.daemon.supervisor.BasicContainer
Create a new BasicContainer.
BasicContainerLauncher - Class in org.apache.storm.daemon.supervisor
Launch containers with no security using standard java commands.
BasicContainerLauncher(Map<String, Object>, String, int, ResourceIsolationInterface, StormMetricsRegistry, ContainerMemoryTracker) - Constructor for class org.apache.storm.daemon.supervisor.BasicContainerLauncher
 
BasicDrpcClient - Class in org.apache.storm.command
A simple client for connecting to DRPC.
BasicDrpcClient() - Constructor for class org.apache.storm.command.BasicDrpcClient
 
BasicDRPCTopology - Class in org.apache.storm.starter
This topology is a basic example of doing distributed RPC on top of Storm.
BasicDRPCTopology() - Constructor for class org.apache.storm.starter.BasicDRPCTopology
 
BasicDRPCTopology.ExclaimBolt - Class in org.apache.storm.starter
 
BasicLoadAwareCustomStreamGrouping(CustomStreamGrouping) - Constructor for class org.apache.storm.daemon.GrouperFactory.BasicLoadAwareCustomStreamGrouping
 
BasicMetricsCollector - Class in org.apache.storm.perf.utils
 
BasicMetricsCollector(String, Map<String, Object>) - Constructor for class org.apache.storm.perf.utils.BasicMetricsCollector
 
BasicMetricsCollector.MetricsCollectorConfig - Class in org.apache.storm.perf.utils
 
BasicMetricsCollector.MetricsItem - Enum in org.apache.storm.perf.utils
 
BasicOutputCollector - Class in org.apache.storm.topology
 
BasicOutputCollector(OutputCollector) - Constructor for class org.apache.storm.topology.BasicOutputCollector
 
BATCH_STREAM_ID - Static variable in class org.apache.storm.trident.topology.MasterBatchCoordinator
 
BatchAsyncResultHandler - Class in org.apache.storm.cassandra.executor.impl
 
BatchAsyncResultHandler(ExecutionResultHandler) - Constructor for class org.apache.storm.cassandra.executor.impl.BatchAsyncResultHandler
Creates a new BatchAsyncResultHandler instance.
BatchBoltExecutor - Class in org.apache.storm.coordination
 
BatchBoltExecutor(IBatchBolt) - Constructor for class org.apache.storm.coordination.BatchBoltExecutor
 
BatchCassandraWriterBolt - Class in org.apache.storm.cassandra.bolt
 
BatchCassandraWriterBolt(CQLStatementTupleMapper) - Constructor for class org.apache.storm.cassandra.bolt.BatchCassandraWriterBolt
Creates a new CassandraWriterBolt instance.
BatchCassandraWriterBolt(CQLStatementTupleMapper, int) - Constructor for class org.apache.storm.cassandra.bolt.BatchCassandraWriterBolt
Creates a new CassandraWriterBolt instance.
BatchCQLStatementTupleMapper - Class in org.apache.storm.cassandra.query.impl
 
BatchCQLStatementTupleMapper(BatchStatement.Type, List<CQLStatementTupleMapper>) - Constructor for class org.apache.storm.cassandra.query.impl.BatchCQLStatementTupleMapper
Creates a new BatchCQLStatementTupleMapper instance.
batchGet(List<Get>) - Method in class org.apache.storm.hbase.common.HBaseClient
 
batchGlobal() - Method in class org.apache.storm.trident.Stream
Repartitioning Operation.
batchGroup - Variable in class org.apache.storm.trident.topology.BatchInfo
 
BatchHelper - Class in org.apache.storm.utils
 
BatchHelper(int, OutputCollector) - Constructor for class org.apache.storm.utils.BatchHelper
 
batchId - Variable in class org.apache.storm.trident.planner.ProcessorContext
 
batchId - Variable in class org.apache.storm.trident.topology.BatchInfo
 
BatchInfo - Class in org.apache.storm.trident.topology
 
BatchInfo(String, IBatchID, Object) - Constructor for class org.apache.storm.trident.topology.BatchInfo
 
batchMutate(List<Mutation>) - Method in class org.apache.storm.hbase.common.HBaseClient
 
BatchOutputCollector - Class in org.apache.storm.coordination
 
BatchOutputCollector() - Constructor for class org.apache.storm.coordination.BatchOutputCollector
 
BatchOutputCollectorImpl - Class in org.apache.storm.coordination
 
BatchOutputCollectorImpl(OutputCollector) - Constructor for class org.apache.storm.coordination.BatchOutputCollectorImpl
 
BatchProcessor - Interface in org.apache.storm.streams.processors
Top level marker interface for processors that computes results for a batch of tuples like Aggregate, Join etc.
batchRetrieve(CassandraState, List<TridentTuple>) - Method in class org.apache.storm.cassandra.trident.state.CassandraQuery
 
batchRetrieve(List<TridentTuple>) - Method in class org.apache.storm.cassandra.trident.state.CassandraState
 
batchRetrieve(HBaseState, List<TridentTuple>) - Method in class org.apache.storm.hbase.trident.state.HBaseQuery
 
batchRetrieve(List<TridentTuple>) - Method in class org.apache.storm.hbase.trident.state.HBaseState
 
batchRetrieve(JdbcState, List<TridentTuple>) - Method in class org.apache.storm.jdbc.trident.state.JdbcQuery
 
batchRetrieve(List<TridentTuple>) - Method in class org.apache.storm.jdbc.trident.state.JdbcState
 
batchRetrieve(List<TridentTuple>) - Method in class org.apache.storm.mongodb.trident.state.MongoState
Batch retrieve values.
batchRetrieve(MongoState, List<TridentTuple>) - Method in class org.apache.storm.mongodb.trident.state.MongoStateQuery
 
batchRetrieve(T, List<TridentTuple>) - Method in class org.apache.storm.redis.trident.state.AbstractRedisStateQuerier
batchRetrieve(ReadOnlyMapState, List<TridentTuple>) - Method in class org.apache.storm.trident.operation.builtin.MapGet
 
batchRetrieve(ReadOnlySnapshottable, List<TridentTuple>) - Method in class org.apache.storm.trident.operation.builtin.SnapshotGet
 
batchRetrieve(State, List<TridentTuple>) - Method in class org.apache.storm.trident.operation.builtin.TupleCollectionGet
 
batchRetrieve(S, List<TridentTuple>) - Method in interface org.apache.storm.trident.state.QueryFunction
 
batchSize - Variable in class org.apache.storm.hive.common.HiveOptions
 
BatchSpoutEmitter() - Constructor for class org.apache.storm.trident.spout.BatchSpoutExecutor.BatchSpoutEmitter
 
BatchSpoutExecutor - Class in org.apache.storm.trident.spout
 
BatchSpoutExecutor(IBatchSpout) - Constructor for class org.apache.storm.trident.spout.BatchSpoutExecutor
 
BatchSpoutExecutor.BatchSpoutEmitter - Class in org.apache.storm.trident.spout
 
BatchSpoutExecutor.EmptyCoordinator - Class in org.apache.storm.trident.spout
 
BatchSubtopologyBuilder - Class in org.apache.storm.coordination
 
BatchSubtopologyBuilder(String, IBasicBolt, Number) - Constructor for class org.apache.storm.coordination.BatchSubtopologyBuilder
 
BatchSubtopologyBuilder(String, IBasicBolt) - Constructor for class org.apache.storm.coordination.BatchSubtopologyBuilder
 
BeanDef - Class in org.apache.storm.flux.model
A representation of a Java object that is uniquely identifyable, and given a className, constructor arguments, and properties, can be instantiated.
BeanDef() - Constructor for class org.apache.storm.flux.model.BeanDef
 
BeanFactory<T> - Interface in org.apache.storm.cassandra.context
Simple interface used for providing services based on the storm configuration.
BeanListReference - Class in org.apache.storm.flux.model
A bean list reference is a list of bean reference.
BeanListReference() - Constructor for class org.apache.storm.flux.model.BeanListReference
 
BeanListReference(List<String>) - Constructor for class org.apache.storm.flux.model.BeanListReference
 
BeanReference - Class in org.apache.storm.flux.model
A bean reference is simply a string pointer to another id.
BeanReference() - Constructor for class org.apache.storm.flux.model.BeanReference
 
BeanReference(String) - Constructor for class org.apache.storm.flux.model.BeanReference
 
BEFORE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
BEGIN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
BEGIN_FRAME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
BEGIN_PARTITION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
beginBlobDownload(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
 
beginBlobDownload(String, AsyncMethodCallback<BeginDownloadResult>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
 
beginBlobDownload(String, AsyncMethodCallback<BeginDownloadResult>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
 
beginBlobDownload() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.beginBlobDownload
 
beginBlobDownload(String) - Method in class org.apache.storm.generated.Nimbus.Client
 
beginBlobDownload(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
 
beginBlobDownload() - Constructor for class org.apache.storm.generated.Nimbus.Processor.beginBlobDownload
 
beginBlobDownload(String) - Method in class org.apache.storm.LocalCluster
 
beginBlobDownload_args() - Constructor for class org.apache.storm.generated.Nimbus.beginBlobDownload_args
 
beginBlobDownload_args(String) - Constructor for class org.apache.storm.generated.Nimbus.beginBlobDownload_args
 
beginBlobDownload_args(Nimbus.beginBlobDownload_args) - Constructor for class org.apache.storm.generated.Nimbus.beginBlobDownload_args
Performs a deep copy on other.
beginBlobDownload_call(String, AsyncMethodCallback<BeginDownloadResult>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.beginBlobDownload_call
 
beginBlobDownload_result() - Constructor for class org.apache.storm.generated.Nimbus.beginBlobDownload_result
 
beginBlobDownload_result(BeginDownloadResult, AuthorizationException, KeyNotFoundException) - Constructor for class org.apache.storm.generated.Nimbus.beginBlobDownload_result
 
beginBlobDownload_result(Nimbus.beginBlobDownload_result) - Constructor for class org.apache.storm.generated.Nimbus.beginBlobDownload_result
Performs a deep copy on other.
beginColumn - Variable in class org.apache.storm.sql.parser.impl.Token
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
beginCommit(Long) - Method in class org.apache.storm.cassandra.trident.state.CassandraState
 
beginCommit(Long) - Method in class org.apache.storm.hbase.trident.state.HBaseState
 
beginCommit(Long) - Method in class org.apache.storm.hdfs.trident.HdfsState
 
beginCommit(Long) - Method in class org.apache.storm.hive.trident.HiveState
 
beginCommit(Long) - Method in class org.apache.storm.jdbc.trident.state.JdbcState
 
beginCommit(Long) - Method in class org.apache.storm.jms.trident.JmsState
 
beginCommit(Long) - Method in class org.apache.storm.kafka.trident.TridentKafkaState
 
beginCommit(Long) - Method in class org.apache.storm.mongodb.trident.state.MongoState
 
beginCommit(Long) - Method in class org.apache.storm.opentsdb.trident.OpenTsdbState
 
beginCommit(Long) - Method in class org.apache.storm.redis.trident.state.RedisClusterState
beginCommit(Long) - Method in class org.apache.storm.redis.trident.state.RedisState
beginCommit(Long) - Method in class org.apache.storm.rocketmq.trident.state.RocketMqState
 
beginCommit(Long) - Method in class org.apache.storm.solr.trident.SolrState
 
beginCommit(Long) - Method in class org.apache.storm.trident.state.map.NonTransactionalMap
 
beginCommit(Long) - Method in class org.apache.storm.trident.state.map.OpaqueMap
 
beginCommit(Long) - Method in class org.apache.storm.trident.state.map.SnapshottableMap
 
beginCommit(Long) - Method in class org.apache.storm.trident.state.map.TransactionalMap
 
beginCommit(Long) - Method in class org.apache.storm.trident.state.ReadOnlyState
 
beginCommit(Long) - Method in interface org.apache.storm.trident.state.State
 
beginCommit(Long) - Method in class org.apache.storm.trident.testing.LRUMemoryMapState
 
beginCommit(Long) - Method in class org.apache.storm.trident.testing.MemoryMapState
 
beginCommit(Long) - Method in class org.apache.storm.trident.windowing.WindowsState
 
beginCreateBlob(String, SettableBlobMeta) - Method in class org.apache.storm.daemon.nimbus.Nimbus
 
beginCreateBlob(String, SettableBlobMeta, AsyncMethodCallback<String>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
 
beginCreateBlob(String, SettableBlobMeta, AsyncMethodCallback<String>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
 
beginCreateBlob() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.beginCreateBlob
 
beginCreateBlob(String, SettableBlobMeta) - Method in class org.apache.storm.generated.Nimbus.Client
 
beginCreateBlob(String, SettableBlobMeta) - Method in interface org.apache.storm.generated.Nimbus.Iface
 
beginCreateBlob() - Constructor for class org.apache.storm.generated.Nimbus.Processor.beginCreateBlob
 
beginCreateBlob(String, SettableBlobMeta) - Method in class org.apache.storm.LocalCluster
 
beginCreateBlob_args() - Constructor for class org.apache.storm.generated.Nimbus.beginCreateBlob_args
 
beginCreateBlob_args(String, SettableBlobMeta) - Constructor for class org.apache.storm.generated.Nimbus.beginCreateBlob_args
 
beginCreateBlob_args(Nimbus.beginCreateBlob_args) - Constructor for class org.apache.storm.generated.Nimbus.beginCreateBlob_args
Performs a deep copy on other.
beginCreateBlob_call(String, SettableBlobMeta, AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.beginCreateBlob_call
 
beginCreateBlob_result() - Constructor for class org.apache.storm.generated.Nimbus.beginCreateBlob_result
 
beginCreateBlob_result(String, AuthorizationException, KeyAlreadyExistsException) - Constructor for class org.apache.storm.generated.Nimbus.beginCreateBlob_result
 
beginCreateBlob_result(Nimbus.beginCreateBlob_result) - Constructor for class org.apache.storm.generated.Nimbus.beginCreateBlob_result
Performs a deep copy on other.
BeginDownloadResult - Class in org.apache.storm.generated
 
BeginDownloadResult() - Constructor for class org.apache.storm.generated.BeginDownloadResult
 
BeginDownloadResult(long, String) - Constructor for class org.apache.storm.generated.BeginDownloadResult
 
BeginDownloadResult(BeginDownloadResult) - Constructor for class org.apache.storm.generated.BeginDownloadResult
Performs a deep copy on other.
BeginDownloadResult._Fields - Enum in org.apache.storm.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
beginFileUpload() - Method in class org.apache.storm.daemon.nimbus.Nimbus
 
beginFileUpload(AsyncMethodCallback<String>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
 
beginFileUpload(AsyncMethodCallback<String>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
 
beginFileUpload() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.beginFileUpload
 
beginFileUpload() - Method in class org.apache.storm.generated.Nimbus.Client
 
beginFileUpload() - Method in interface org.apache.storm.generated.Nimbus.Iface
 
beginFileUpload() - Constructor for class org.apache.storm.generated.Nimbus.Processor.beginFileUpload
 
beginFileUpload() - Method in class org.apache.storm.LocalCluster
 
beginFileUpload_args() - Constructor for class org.apache.storm.generated.Nimbus.beginFileUpload_args
 
beginFileUpload_args(Nimbus.beginFileUpload_args) - Constructor for class org.apache.storm.generated.Nimbus.beginFileUpload_args
Performs a deep copy on other.
beginFileUpload_call(AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.beginFileUpload_call
 
beginFileUpload_result() - Constructor for class org.apache.storm.generated.Nimbus.beginFileUpload_result
 
beginFileUpload_result(String, AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.beginFileUpload_result
 
beginFileUpload_result(Nimbus.beginFileUpload_result) - Constructor for class org.apache.storm.generated.Nimbus.beginFileUpload_result
Performs a deep copy on other.
beginLine - Variable in class org.apache.storm.sql.parser.impl.Token
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
BeginToken() - Method in class org.apache.storm.sql.parser.impl.SimpleCharStream
 
beginUpdateBlob(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
 
beginUpdateBlob(String, AsyncMethodCallback<String>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
 
beginUpdateBlob(String, AsyncMethodCallback<String>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
 
beginUpdateBlob() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.beginUpdateBlob
 
beginUpdateBlob(String) - Method in class org.apache.storm.generated.Nimbus.Client
 
beginUpdateBlob(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
 
beginUpdateBlob() - Constructor for class org.apache.storm.generated.Nimbus.Processor.beginUpdateBlob
 
beginUpdateBlob(String) - Method in class org.apache.storm.LocalCluster
 
beginUpdateBlob_args() - Constructor for class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
 
beginUpdateBlob_args(String) - Constructor for class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
 
beginUpdateBlob_args(Nimbus.beginUpdateBlob_args) - Constructor for class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
Performs a deep copy on other.
beginUpdateBlob_call(String, AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.beginUpdateBlob_call
 
beginUpdateBlob_result() - Constructor for class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
 
beginUpdateBlob_result(String, AuthorizationException, KeyNotFoundException) - Constructor for class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
 
beginUpdateBlob_result(Nimbus.beginUpdateBlob_result) - Constructor for class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
Performs a deep copy on other.
BEL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
BERNOULLI - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
BETWEEN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
BiFunction<T,U,R> - Interface in org.apache.storm.streams.operations
a function that accepts two arguments and produces a result.
BIGINT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
BINARY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
binary_arg(ByteBuffer) - Static method in class org.apache.storm.generated.JavaObjectArg
 
binary_arg(byte[]) - Static method in class org.apache.storm.generated.JavaObjectArg
 
BINARY_STRING_LITERAL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
BinaryEventDataScheme - Class in org.apache.storm.eventhubs.spout
An Event Data Scheme which deserializes message payload into the raw bytes.
BinaryEventDataScheme() - Constructor for class org.apache.storm.eventhubs.spout.BinaryEventDataScheme
 
BinaryMultisetOperator() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
Parses a binary multiset operator.
BinaryQueryOperator() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
Parses a binary query operator like UNION.
BinaryRowOperator() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
Parses a binary row operator like AND.
bind(FieldSelector...) - Method in class org.apache.storm.cassandra.query.builder.BoundCQLStatementMapperBuilder
Includes only the specified tuple fields.
bind(CqlMapper) - Method in class org.apache.storm.cassandra.query.builder.BoundCQLStatementMapperBuilder
Includes only the specified tuple fields.
bind(String, int, IConnectionCallback, Supplier<Object>) - Method in interface org.apache.storm.messaging.IContext
This method establishes a server side connection.
bind(String, int, IConnectionCallback, Supplier<Object>) - Method in class org.apache.storm.messaging.local.Context
 
bind(String, int, IConnectionCallback, Supplier<Object>) - Method in class org.apache.storm.messaging.netty.Context
establish a server with a binding port.
BIT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
bitXor(Long, Long) - Static method in class org.apache.storm.utils.Utils
 
bitXorVals(List<Long>) - Static method in class org.apache.storm.utils.Utils
 
BLACKLIST_SCHEDULER_ASSUME_SUPERVISOR_BAD_BASED_ON_BAD_SLOT - Static variable in class org.apache.storm.DaemonConfig
Whether BlacklistScheduler will assume the supervisor is bad based on bad slots or not.
BLACKLIST_SCHEDULER_ENABLE_SEND_ASSIGNMENT_FAILURES - Static variable in class org.apache.storm.DaemonConfig
Enables blacklisting support for supervisors with failed send assignment calls.
BLACKLIST_SCHEDULER_REPORTER - Static variable in class org.apache.storm.DaemonConfig
The class that the blacklist scheduler will report the blacklist.
BLACKLIST_SCHEDULER_RESUME_TIME - Static variable in class org.apache.storm.DaemonConfig
The number of seconds that the blacklisted slots or supervisor will be resumed.
BLACKLIST_SCHEDULER_STRATEGY - Static variable in class org.apache.storm.DaemonConfig
The class that specifies the eviction strategy to use in blacklist scheduler.
BLACKLIST_SCHEDULER_TOLERANCE_COUNT - Static variable in class org.apache.storm.DaemonConfig
The number of hit count that will trigger blacklist in tolerance time.
BLACKLIST_SCHEDULER_TOLERANCE_TIME - Static variable in class org.apache.storm.DaemonConfig
The number of seconds that the blacklist scheduler will concern of bad slots or supervisors.
blacklistedSupervisorIds - Variable in class org.apache.storm.scheduler.blacklist.BlacklistScheduler
 
blacklistHost(String) - Method in class org.apache.storm.scheduler.Cluster
 
BlacklistScheduler - Class in org.apache.storm.scheduler.blacklist
 
BlacklistScheduler(IScheduler) - Constructor for class org.apache.storm.scheduler.blacklist.BlacklistScheduler
 
blacklistStrategy - Variable in class org.apache.storm.scheduler.blacklist.BlacklistScheduler
 
BLKIO_IO_MERGED - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BLKIO_IO_QUEUED - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BLKIO_IO_SERVICE_BYTES - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BLKIO_IO_SERVICE_TIME - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BLKIO_IO_SERVICED - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BLKIO_IO_WAIT_TIME - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BLKIO_RESET_STATS - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BLKIO_SECTORS - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BLKIO_THROTTLE_IO_SERVICE_BYTES - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BLKIO_THROTTLE_IO_SERVICED - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BLKIO_THROTTLE_READ_BPS_DEVICE - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BLKIO_THROTTLE_READ_IOPS_DEVICE - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BLKIO_THROTTLE_WRITE_BPS_DEVICE - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BLKIO_THROTTLE_WRITE_IOPS_DEVICE - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BLKIO_TIME - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BLKIO_WEIGHT - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BLKIO_WEIGHT_DEVICE - Static variable in class org.apache.storm.container.cgroup.core.BlkioCore
 
BlkioCore - Class in org.apache.storm.container.cgroup.core
 
BlkioCore(String) - Constructor for class org.apache.storm.container.cgroup.core.BlkioCore
 
BlkioCore.RecordType - Enum in org.apache.storm.container.cgroup.core
 
BLOB - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
BLOB_KEY_PATTERN - Static variable in class org.apache.storm.utils.Utils
 
blobChanging(LocalAssignment, int, LocallyCachedBlob, GoodToGo) - Method in class org.apache.storm.daemon.supervisor.Slot
 
blobChanging(LocalAssignment, int, LocallyCachedBlob, GoodToGo) - Method in interface org.apache.storm.localizer.BlobChangingCallback
Informs the listener that a blob has changed and is ready to update and replace a localized blob that has been marked as tied to the life cycle of the worker process.
BlobChangingCallback - Interface in org.apache.storm.localizer
Callback for when a localized blob is going to change.
blobExists(String, Subject) - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStore
Checks if a blob exists.
BlobKeySequenceInfo - Class in org.apache.storm.blobstore
 
BlobKeySequenceInfo() - Constructor for class org.apache.storm.blobstore.BlobKeySequenceInfo
 
blobNeedsWorkerRestart(Map<String, Object>) - Static method in class org.apache.storm.daemon.supervisor.SupervisorUtils
Given the blob information returns the value of the workerRestart field, handling it either being a string or a boolean value, or if it’s not specified then returns false.
BlobStore - Class in org.apache.storm.blobstore
Provides a way to store blobs that can be downloaded.
BlobStore() - Constructor for class org.apache.storm.blobstore.BlobStore
 
blobstore(Runnable) - Method in interface org.apache.storm.cluster.IStormClusterState
 
blobstore(Runnable) - Method in class org.apache.storm.cluster.StormClusterStateImpl
 
Blobstore - Class in org.apache.storm.command
 
Blobstore() - Constructor for class org.apache.storm.command.Blobstore
 
BlobStore.BlobStoreFileInputStream - Class in org.apache.storm.blobstore
Input stream implementation used for writing both the metadata containing the acl information and the blob data.
BlobStore.BlobStoreFileOutputStream - Class in org.apache.storm.blobstore
Output stream implementation used for reading the metadata and data information.
BlobStore.KeyTranslationIterator - Class in org.apache.storm.blobstore
Blob store implements its own version of iterator to list the blobs.
BLOBSTORE_CLEANUP_ENABLE - Static variable in class org.apache.storm.Config
Enable the blobstore cleaner.
BLOBSTORE_DATA_FILE - Static variable in class org.apache.storm.blobstore.BlobStoreFile
 
BLOBSTORE_DIR - Static variable in class org.apache.storm.Config
What directory to use for the blobstore.
BLOBSTORE_DIR_PERMISSION - Static variable in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreImpl
 
BLOBSTORE_FILE_PERMISSION - Static variable in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreFile
 
BLOBSTORE_HDFS_KEYTAB - Static variable in class org.apache.storm.Config
Deprecated.
BLOBSTORE_HDFS_PRINCIPAL - Static variable in class org.apache.storm.Config
Deprecated.
BLOBSTORE_MAX_KEY_SEQUENCE_NUMBER_ROOT - Static variable in class org.apache.storm.cluster.ClusterUtils
 
BLOBSTORE_MAX_KEY_SEQUENCE_NUMBER_SUBTREE - Static variable in class org.apache.storm.cluster.ClusterUtils
 
BLOBSTORE_ROOT - Static variable in class org.apache.storm.cluster.ClusterUtils
 
BLOBSTORE_SUBTREE - Static variable in class org.apache.storm.cluster.ClusterUtils
 
BlobStoreAclHandler - Class in org.apache.storm.blobstore
Provides common handling of acls for Blobstores.
BlobStoreAclHandler(Map<String, Object>) - Constructor for class org.apache.storm.blobstore.BlobStoreAclHandler
 
BlobStoreAPIWordCountTopology - Class in org.apache.storm.starter
 
BlobStoreAPIWordCountTopology() - Constructor for class org.apache.storm.starter.BlobStoreAPIWordCountTopology
 
BlobStoreAPIWordCountTopology.FilterWords - Class in org.apache.storm.starter
 
BlobStoreAPIWordCountTopology.RandomSentenceSpout - Class in org.apache.storm.starter
 
BlobStoreAPIWordCountTopology.SplitSentence - Class in org.apache.storm.starter
 
BlobStoreFile - Class in org.apache.storm.blobstore
Provides an base implementation for creating a blobstore based on file backed storage.
BlobStoreFile() - Constructor for class org.apache.storm.blobstore.BlobStoreFile
 
BlobStoreFileInputStream(BlobStoreFile) - Constructor for class org.apache.storm.blobstore.BlobStore.BlobStoreFileInputStream
 
BlobStoreFileOutputStream(BlobStoreFile) - Constructor for class org.apache.storm.blobstore.BlobStore.BlobStoreFileOutputStream
 
blobstoreInfo(String) - Method in interface org.apache.storm.cluster.IStormClusterState
 
blobstoreInfo(String) - Method in class org.apache.storm.cluster.StormClusterStateImpl
 
blobstoreMapToLocalresources(Map<String, Map<String, Object>>) - Static method in class org.apache.storm.daemon.supervisor.SupervisorUtils
Returns a list of LocalResources based on the blobstore-map passed in.
blobstoreMaxKeySequenceNumberPath(String) - Static method in class org.apache.storm.cluster.ClusterUtils
 
blobstorePath(String) - Static method in class org.apache.storm.cluster.ClusterUtils
 
BlobStoreUtils - Class in org.apache.storm.blobstore
 
BlobStoreUtils() - Constructor for class org.apache.storm.blobstore.BlobStoreUtils
 
BlockingOutstandingRequest - Class in org.apache.storm.daemon.drpc
 
BlockingOutstandingRequest(String, DRPCRequest) - Constructor for class org.apache.storm.daemon.drpc.BlockingOutstandingRequest
 
BlowfishTupleSerializer - Class in org.apache.storm.security.serialization
Apply Blowfish encryption for tuple communication to bolts.
BlowfishTupleSerializer(Kryo, Map<String, Object>) - Constructor for class org.apache.storm.security.serialization.BlowfishTupleSerializer
 
Bolt - Class in org.apache.storm.generated
 
Bolt() - Constructor for class org.apache.storm.generated.Bolt
 
Bolt(ComponentObject, ComponentCommon) - Constructor for class org.apache.storm.generated.Bolt
 
Bolt(Bolt) - Constructor for class org.apache.storm.generated.Bolt
Performs a deep copy on other.
bolt(BoltStats) - Static method in class org.apache.storm.generated.ExecutorSpecificStats
 
bolt(BoltAggregateStats) - Static method in class org.apache.storm.generated.SpecificAggregateStats
 
BOLT - Static variable in class org.apache.storm.stats.ClientStatsUtil
 
Bolt._Fields - Enum in org.apache.storm.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BOLT1_COUNT - Static variable in class org.apache.storm.perf.ConstSpoutIdBoltNullBoltTopo
 
BOLT1_ID - Static variable in class org.apache.storm.perf.ConstSpoutIdBoltNullBoltTopo
 
BOLT2_COUNT - Static variable in class org.apache.storm.perf.ConstSpoutIdBoltNullBoltTopo
 
BOLT2_ID - Static variable in class org.apache.storm.perf.ConstSpoutIdBoltNullBoltTopo
 
BOLT_COUNT - Static variable in class org.apache.storm.perf.ConstSpoutNullBoltTopo
 
BOLT_ID - Static variable in class org.apache.storm.hdfs.spout.HdfsSpoutTopology
 
BOLT_ID - Static variable in class org.apache.storm.perf.ConstSpoutNullBoltTopo
 
BOLT_ID - Static variable in class org.apache.storm.perf.KafkaClientHdfsTopo
 
BOLT_ID - Static variable in class org.apache.storm.perf.KafkaClientSpoutNullBoltTopo
 
BOLT_ID - Static variable in class org.apache.storm.perf.StrGenSpoutHdfsBoltTopo
 
BOLT_KEY - Static variable in class org.apache.storm.kafka.bolt.mapper.FieldNameBasedTupleToKafkaMapper
 
BOLT_KEY - Static variable in class org.apache.storm.rocketmq.common.mapper.FieldNameBasedTupleToMessageMapper
 
BOLT_MESSAGE - Static variable in class org.apache.storm.kafka.bolt.mapper.FieldNameBasedTupleToKafkaMapper
 
BOLT_MESSAGE - Static variable in class org.apache.storm.rocketmq.common.mapper.FieldNameBasedTupleToMessageMapper
 
BOLT_NUM - Static variable in class org.apache.storm.perf.KafkaClientHdfsTopo
 
BOLT_NUM - Static variable in class org.apache.storm.perf.KafkaClientSpoutNullBoltTopo
 
BOLT_NUM - Static variable in class org.apache.storm.perf.SimplifiedWordCountTopo
 
BOLT_NUM - Static variable in class org.apache.storm.perf.StrGenSpoutHdfsBoltTopo
 
boltAck(BoltAckInfo) - Method in class org.apache.storm.hooks.BaseTaskHook
 
boltAck(BoltAckInfo) - Method in interface org.apache.storm.hooks.ITaskHook
 
boltAckedTuple(String, String, long, Counter) - Method in class org.apache.storm.stats.BoltExecutorStats
 
BoltAckInfo - Class in org.apache.storm.hooks.info
 
BoltAckInfo(Tuple, int, Long) - Constructor for class org.apache.storm.hooks.info.BoltAckInfo
 
BoltAggregateStats - Class in org.apache.storm.generated
 
BoltAggregateStats() - Constructor for class org.apache.storm.generated.BoltAggregateStats
 
BoltAggregateStats(BoltAggregateStats) - Constructor for class org.apache.storm.generated.BoltAggregateStats
Performs a deep copy on other.
BoltAggregateStats._Fields - Enum in org.apache.storm.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
boltConfig - Variable in class org.apache.storm.eventhubs.bolt.EventHubBolt
 
BoltDeclarer - Interface in org.apache.storm.topology
BoltDeclarer includes grouping APIs for storm topology.
BoltDef - Class in org.apache.storm.flux.model
Bean representation of a Storm bolt.
BoltDef() - Constructor for class org.apache.storm.flux.model.BoltDef
 
BoltDetails(Object, Map<String, Object>, Integer, Map<GlobalStreamId, Grouping>) - Constructor for class org.apache.storm.Thrift.BoltDetails
 
boltExecute(BoltExecuteInfo) - Method in class org.apache.storm.hooks.BaseTaskHook
 
boltExecute(BoltExecuteInfo) - Method in interface org.apache.storm.hooks.ITaskHook
 
boltExecute(List<Tuple>, List<Tuple>, List<Tuple>, Long) - Method in class org.apache.storm.topology.WindowedBoltExecutor
 
boltExecute(Supplier<Iterator<Tuple>>, Supplier<Iterator<Tuple>>, Supplier<Iterator<Tuple>>, Long) - Method in class org.apache.storm.topology.WindowedBoltExecutor
 
BoltExecuteInfo - Class in org.apache.storm.hooks.info
 
BoltExecuteInfo(Tuple, int, Long) - Constructor for class org.apache.storm.hooks.info.BoltExecuteInfo
 
boltExecuteTuple(String, String, long) - Method in class org.apache.storm.stats.BoltExecutorStats
 
BoltExecutor - Class in org.apache.storm.executor.bolt
 
BoltExecutor(WorkerState, List<Long>, Map<String, String>) - Constructor for class org.apache.storm.executor.bolt.BoltExecutor
 
BoltExecutorStats - Class in org.apache.storm.stats
 
BoltExecutorStats(int, int) - Constructor for class org.apache.storm.stats.BoltExecutorStats
 
boltFail(BoltFailInfo) - Method in class org.apache.storm.hooks.BaseTaskHook
 
boltFail(BoltFailInfo) - Method in interface org.apache.storm.hooks.ITaskHook
 
boltFailedTuple(String, String, long, Counter) - Method in class org.apache.storm.stats.BoltExecutorStats
 
BoltFailInfo - Class in org.apache.storm.hooks.info
 
BoltFailInfo(Tuple, int, Long) - Constructor for class org.apache.storm.hooks.info.BoltFailInfo
 
BoltGetter(String) - Constructor for class org.apache.storm.topology.TopologyBuilder.BoltGetter
 
boltKeyField - Variable in class org.apache.storm.kafka.bolt.mapper.FieldNameBasedTupleToKafkaMapper
 
boltKeyField - Variable in class org.apache.storm.rocketmq.common.mapper.FieldNameBasedTupleToMessageMapper
 
boltMessageField - Variable in class org.apache.storm.kafka.bolt.mapper.FieldNameBasedTupleToKafkaMapper
 
boltMessageField - Variable in class org.apache.storm.rocketmq.common.mapper.FieldNameBasedTupleToMessageMapper
 
BoltMsg - Class in org.apache.storm.multilang
BoltMsg is an object that represents the data sent from a shell component to a bolt process that implements a multi-language protocol.
BoltMsg() - Constructor for class org.apache.storm.multilang.BoltMsg
 
BoltOutputCollectorImpl - Class in org.apache.storm.executor.bolt
 
BoltOutputCollectorImpl(BoltExecutor, Task, Random, boolean, boolean, boolean) - Constructor for class org.apache.storm.executor.bolt.BoltOutputCollectorImpl
 
bolts - Variable in class org.apache.storm.loadgen.TopologyLoadConf
 
BoltStats - Class in org.apache.storm.generated
 
BoltStats() - Constructor for class org.apache.storm.generated.BoltStats
 
BoltStats(Map<String, Map<GlobalStreamId, Long>>, Map<String, Map<GlobalStreamId, Long>>, Map<String, Map<GlobalStreamId, Double>>, Map<String, Map<GlobalStreamId, Long>>, Map<String, Map<GlobalStreamId, Double>>) - Constructor for class org.apache.storm.generated.BoltStats
 
BoltStats(BoltStats) - Constructor for class org.apache.storm.generated.BoltStats
Performs a deep copy on other.
BoltStats._Fields - Enum in org.apache.storm.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
boltStreamsStats(List<ExecutorSummary>, boolean) - Static method in class org.apache.storm.stats.StatsUtil
aggregates bolt stream stats, returns a Map of {metric -> win -> aggregated value}.
BoltTracker - Class in org.apache.storm.testing
 
BoltTracker(IRichBolt, String) - Constructor for class org.apache.storm.testing.BoltTracker
 
bool_arg(boolean) - Static method in class org.apache.storm.generated.JavaObjectArg
 
BOOLEAN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
BooleanValidator() - Constructor for class org.apache.storm.validation.ConfigValidation.BooleanValidator
 
boolOpt(String, String) - Static method in class org.apache.storm.command.CLI
Add a boolean option that enables something.
boolOpt(String, String) - Method in class org.apache.storm.command.CLI.CLIBuilder
Add a boolean option that enables something.
boolval(boolean) - Static method in class org.apache.storm.generated.HBMessageData
 
Booter - Class in org.apache.storm.submit.dependency
Manage mvn repository.
Booter() - Constructor for class org.apache.storm.submit.dependency.Booter
 
BOOTSTRAP_SERVERS - Static variable in class org.apache.storm.perf.KafkaClientSpoutNullBoltTopo
 
BOTH - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
BoundCQLStatementMapperBuilder - Class in org.apache.storm.cassandra.query.builder
 
BoundCQLStatementMapperBuilder(String) - Constructor for class org.apache.storm.cassandra.query.builder.BoundCQLStatementMapperBuilder
Creates a new BoundCQLStatementMapperBuilder instance.
BoundCQLStatementMapperBuilder(ContextQuery) - Constructor for class org.apache.storm.cassandra.query.builder.BoundCQLStatementMapperBuilder
Creates a new BoundCQLStatementMapperBuilder instance.
BoundCQLStatementTupleMapper - Class in org.apache.storm.cassandra.query.impl
 
BoundCQLStatementTupleMapper(ContextQuery, CqlMapper, RoutingKeyGenerator, PreparedStatementBinder) - Constructor for class org.apache.storm.cassandra.query.impl.BoundCQLStatementTupleMapper
Creates a new BoundCQLStatementTupleMapper instance.
boundQuery(String) - Static method in class org.apache.storm.cassandra.DynamicStatementBuilder
Builds a new bound statement based on the specified query.
boundQuery(ContextQuery) - Static method in class org.apache.storm.cassandra.DynamicStatementBuilder
Builds a new bound statement identified by the given field.
BoundQueryContext(String) - Constructor for class org.apache.storm.cassandra.query.ContextQuery.BoundQueryContext
 
BoundQueryNamedByFieldContext(String) - Constructor for class org.apache.storm.cassandra.query.ContextQuery.BoundQueryNamedByFieldContext
 
bpTasks - Variable in class org.apache.storm.messaging.netty.BackPressureStatus
 
BRACKET_QUOTED_IDENTIFIER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
branch(Predicate<? super Pair<K, V>>...) - Method in class org.apache.storm.streams.PairStream
Returns an array of streams by splitting the given stream into multiple branches based on the given predicates.
branch(Predicate<? super T>...) - Method in class org.apache.storm.streams.Stream
Returns an array of streams by splitting the given stream into multiple branches based on the given predicates.
BranchExample - Class in org.apache.storm.starter.streams
An example that demonstrates the usage of Stream.branch(Predicate[]) to split a stream into multiple branches based on predicates.
BranchExample() - Constructor for class org.apache.storm.starter.streams.BranchExample
 
BranchProcessor<T> - Class in org.apache.storm.streams.processors
 
BranchProcessor() - Constructor for class org.apache.storm.streams.processors.BranchProcessor
 
BREADTH - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
BridgeReceiver - Class in org.apache.storm.trident.planner
 
BridgeReceiver(BatchOutputCollector) - Constructor for class org.apache.storm.trident.planner.BridgeReceiver
 
broadcast() - Method in class org.apache.storm.trident.Stream
Repartitioning Operation.
BROADCAST_DEST - Static variable in class org.apache.storm.tuple.AddressedTuple
Destination used when broadcasting a tuple.
BROKER_HEART_BEAT_INTERVAL - Static variable in class org.apache.storm.rocketmq.RocketMqConfig
 
BTID - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
BucketTestHiveTopology - Class in org.apache.storm.hive.bolt
 
BucketTestHiveTopology() - Constructor for class org.apache.storm.hive.bolt.BucketTestHiveTopology
 
BucketTestHiveTopology.UserDataSpout - Class in org.apache.storm.hive.bolt
 
bufcolumn - Variable in class org.apache.storm.sql.parser.impl.SimpleCharStream
 
buffer(ByteBufAllocator, KryoValuesSerializer) - Method in class org.apache.storm.messaging.netty.BackPressureStatus
Encoded as -600 … short(2) len … int(4) payload … byte[] *
buffer - Variable in class org.apache.storm.sql.parser.impl.SimpleCharStream
 
buffer_for_binary_arg() - Method in class org.apache.storm.generated.JavaObjectArg
 
buffer_for_bits() - Method in class org.apache.storm.generated.ThriftSerializedObject
 
buffer_for_chunk() - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_args
 
buffer_for_chunk() - Method in class org.apache.storm.generated.Nimbus.uploadChunk_args
 
buffer_for_custom_serialized() - Method in class org.apache.storm.generated.Grouping
 
buffer_for_details() - Method in class org.apache.storm.generated.HBPulse
 
buffer_for_info() - Method in class org.apache.storm.generated.WorkerToken
 
buffer_for_key() - Method in class org.apache.storm.generated.PrivateWorkerKey
 
buffer_for_message_blob() - Method in class org.apache.storm.generated.HBMessageData
 
buffer_for_serialized_java() - Method in class org.apache.storm.generated.ComponentObject
 
buffer_for_signature() - Method in class org.apache.storm.generated.WorkerToken
 
buffer_for_success() - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
 
buffer_for_success() - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
 
BUFFER_SIZE - Static variable in class org.apache.storm.hdfs.spout.SequenceFileReader
 
BUFFER_SIZE - Static variable in class org.apache.storm.hdfs.spout.TextFileReader
 
BufferFileInputStream - Class in org.apache.storm.utils
 
BufferFileInputStream(String, int) - Constructor for class org.apache.storm.utils.BufferFileInputStream
 
BufferFileInputStream(String) - Constructor for class org.apache.storm.utils.BufferFileInputStream
 
BufferInputStream - Class in org.apache.storm.utils
 
BufferInputStream(InputStream, int) - Constructor for class org.apache.storm.utils.BufferInputStream
 
BufferInputStream(InputStream) - Constructor for class org.apache.storm.utils.BufferInputStream
 
bufline - Variable in class org.apache.storm.sql.parser.impl.SimpleCharStream
 
bufpos - Variable in class org.apache.storm.sql.parser.impl.SimpleCharStream
 
build() - Method in class org.apache.storm.cassandra.query.builder.BoundCQLStatementMapperBuilder
Builds a new CQLStatementTupleMapper instance.
build() - Method in class org.apache.storm.cassandra.query.builder.ObjectMapperCqlStatementMapperBuilder
Builds an ObjectMapperCqlStatementMapper.
build() - Method in class org.apache.storm.cassandra.query.builder.SimpleCQLStatementMapperBuilder
Builds a new CQLStatementTupleMapper instance.
build() - Method in interface org.apache.storm.cassandra.query.CQLStatementBuilder
Builds a new CQLStatementTupleMapper instance.
build() - Method in class org.apache.storm.cassandra.trident.state.MapStateFactoryBuilder
 
build() - Method in class org.apache.storm.daemon.common.JsonResponseBuilder
Build a Response based on given parameters.
build(String, Map<String, Object>) - Static method in class org.apache.storm.daemon.utils.UrlBuilder
Build the URL.
build() - Method in class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig.Builder
 
build() - Method in class org.apache.storm.kafka.spout.KafkaSpoutConfig.Builder
 
build() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig.Builder
 
build() - Method in class org.apache.storm.loadgen.InputStream.Builder
 
build() - Method in class org.apache.storm.loadgen.LoadCompConf.Builder
 
build() - Method in class org.apache.storm.loadgen.OutputStream.Builder
 
build() - Method in class org.apache.storm.LocalCluster.Builder
Builds a new LocalCluster.
build() - Method in class org.apache.storm.mqtt.common.MqttOptions.Builder
 
build() - Method in class org.apache.storm.opentsdb.client.OpenTsdbClient.Builder
 
build() - Method in class org.apache.storm.redis.common.config.JedisClusterConfig.Builder
Builds JedisClusterConfig.
build() - Method in class org.apache.storm.redis.common.config.JedisPoolConfig.Builder
Builds JedisPoolConfig.
build(JedisPoolConfig) - Static method in class org.apache.storm.redis.common.container.JedisCommandsContainerBuilder
Builds container for single Redis environment.
build(JedisClusterConfig) - Static method in class org.apache.storm.redis.common.container.JedisCommandsContainerBuilder
Builds container for Redis Cluster environment.
build(JedisPoolConfig) - Static method in class org.apache.storm.redis.common.container.RedisCommandsContainerBuilder
Builds container for single Redis environment.
build(JedisClusterConfig) - Static method in class org.apache.storm.redis.common.container.RedisCommandsContainerBuilder
Builds container for Redis Cluster environment.
build(List<Object>) - Method in interface org.apache.storm.redis.trident.state.KeyFactory
Converts state key to Redis key.
build(List<Object>) - Method in class org.apache.storm.redis.trident.state.KeyFactory.DefaultKeyFactory
Converts state key to Redis key.
build() - Method in class org.apache.storm.solr.mapper.SolrFieldsMapper.Builder
 
build() - Method in class org.apache.storm.solr.mapper.SolrJsonMapper.Builder
 
build() - Method in class org.apache.storm.sql.AbstractStreamsProcessor
Construct the Storm topology based on the SQL.
build() - Method in class org.apache.storm.sql.compiler.CompilerUtil.TableBuilderInfo
 
build() - Method in class org.apache.storm.streams.StreamBuilder
Builds a new StormTopology for the computation expressed via the stream api.
build(IBackingMap<T>) - Static method in class org.apache.storm.trident.state.map.NonTransactionalMap
 
build(IBackingMap<OpaqueValue>) - Static method in class org.apache.storm.trident.state.map.OpaqueMap
 
build(IBackingMap<TransactionalValue>) - Static method in class org.apache.storm.trident.state.map.TransactionalMap
 
build() - Method in class org.apache.storm.trident.TridentTopology
 
build(WindowPartitionCache.CacheLoader<K, V>) - Method in class org.apache.storm.windowing.persistence.SimpleWindowPartitionCache.SimpleWindowPartitionCacheBuilder
 
build(WindowPartitionCache.CacheLoader<K, V>) - Method in interface org.apache.storm.windowing.persistence.WindowPartitionCache.Builder
Build the cache.
buildAndLaunchWordCountTopology(String[]) - Method in class org.apache.storm.starter.BlobStoreAPIWordCountTopology
 
buildCommonConfigs(Properties, ClientConfig) - Static method in class org.apache.storm.rocketmq.RocketMqConfig
Build Common Configs.
buildConfig(TopologyDef) - Static method in class org.apache.storm.flux.FluxBuilder
Given a topology definition, return a populated org.apache.storm.Config instance.
buildConsumerConfigs(Properties, DefaultMQPushConsumer) - Static method in class org.apache.storm.rocketmq.RocketMqConfig
Build Consumer Configs.
buildDevicesTopology() - Static method in class org.apache.storm.starter.trident.TridentMinMaxOfDevicesTopology
Creates a topology with device-id and count (which are whole numbers) as tuple fields in a stream and it finally generates result stream based on min amd max with device-id and count values.
buildDownloadFile(String, File, Meter) - Static method in class org.apache.storm.daemon.logviewer.utils.LogviewerResponseBuilder
Build a Response object representing download a file.
Builder(String, String...) - Constructor for class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig.Builder
 
Builder(String, Set<String>) - Constructor for class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig.Builder
 
Builder(String, Pattern) - Constructor for class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig.Builder
 
Builder(String, TopicFilter, ManualPartitioner) - Constructor for class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig.Builder
Create a KafkaSpoutConfig builder with default property values and no key/value deserializers.
builder(String, String...) - Static method in class org.apache.storm.kafka.spout.KafkaSpoutConfig
Factory method that creates a Builder with String key/value deserializers.
builder(String, Set<String>) - Static method in class org.apache.storm.kafka.spout.KafkaSpoutConfig
Factory method that creates a Builder with String key/value deserializers.
builder(String, Pattern) - Static method in class org.apache.storm.kafka.spout.KafkaSpoutConfig
Factory method that creates a Builder with String key/value deserializers.
Builder(String, String...) - Constructor for class org.apache.storm.kafka.spout.KafkaSpoutConfig.Builder
 
Builder(String, Set<String>) - Constructor for class org.apache.storm.kafka.spout.KafkaSpoutConfig.Builder
 
Builder(String, Pattern) - Constructor for class org.apache.storm.kafka.spout.KafkaSpoutConfig.Builder
 
Builder(String, TopicFilter, ManualPartitioner) - Constructor for class org.apache.storm.kafka.spout.KafkaSpoutConfig.Builder
Create a KafkaSpoutConfig builder with default property values and no key/value deserializers.
builder(String, String...) - Static method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig
Factory method that creates a Builder with String key/value deserializers.
builder(String, Set<String>) - Static method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig
Factory method that creates a Builder with String key/value deserializers.
builder(String, Pattern) - Static method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig
Factory method that creates a Builder with String key/value deserializers.
Builder(String, String...) - Constructor for class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig.Builder
 
Builder(String, Set<String>) - Constructor for class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig.Builder
 
Builder(String, Pattern) - Constructor for class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig.Builder
 
Builder(String, TopicFilter, ManualPartitioner) - Constructor for class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutConfig.Builder
 
Builder() - Constructor for class org.apache.storm.loadgen.InputStream.Builder
 
Builder() - Constructor for class org.apache.storm.loadgen.LoadCompConf.Builder
 
Builder() - Constructor for class org.apache.storm.loadgen.OutputStream.Builder
 
Builder() - Constructor for class org.apache.storm.LocalCluster.Builder
 
Builder() - Constructor for class org.apache.storm.mqtt.common.MqttOptions.Builder
 
Builder(String) - Constructor for class org.apache.storm.opentsdb.client.OpenTsdbClient.Builder
 
Builder() - Constructor for class org.apache.storm.redis.common.config.JedisClusterConfig.Builder
 
Builder() - Constructor for class org.apache.storm.redis.common.config.JedisPoolConfig.Builder
 
Builder(SchemaBuilder, String) - Constructor for class org.apache.storm.solr.mapper.SolrFieldsMapper.Builder
SolrFieldsMapper builder class.
Builder(SchemaBuilder, SolrClient) - Constructor for class org.apache.storm.solr.mapper.SolrFieldsMapper.Builder
SolrFieldsMapper builder class.
Builder(String, String) - Constructor for class org.apache.storm.solr.mapper.SolrJsonMapper.Builder
SolrJsonMapper builder class.
Builder(SolrClient, String) - Constructor for class org.apache.storm.solr.mapper.SolrJsonMapper.Builder
SolrJsonMapper builder class.
buildExceptionJsonResponse(Exception, String) - Static method in class org.apache.storm.daemon.logviewer.utils.LogviewerResponseBuilder
Build a Response object representing exception, with JSON response.
buildFieldIndex(ValuePointer[]) - Static method in class org.apache.storm.trident.tuple.ValuePointer
 
buildFrameWorkConfig() - Method in class org.apache.storm.sql.StormSqlContext
 
buildIndex(Fields, Map<String, ValuePointer>) - Static method in class org.apache.storm.trident.tuple.ValuePointer
 
buildLogMessage(IEventLogger.EventInfo) - Method in class org.apache.storm.metric.FileBasedEventLogger
 
buildProducerConfigs(Properties, DefaultMQProducer) - Static method in class org.apache.storm.rocketmq.RocketMqConfig
Build Producer Configs.
buildResponsePageNotFound() - Static method in class org.apache.storm.daemon.logviewer.utils.LogviewerResponseBuilder
Build a Response object representing page not found.
buildResponseUnauthorizedUser(String) - Static method in class org.apache.storm.daemon.logviewer.utils.LogviewerResponseBuilder
Build a Response object representing unauthorized user, with HTML response.
buildSchema() - Method in class org.apache.storm.solr.schema.builder.RestJsonSchemaBuilder
Deprecated.
 
buildSchema() - Method in class org.apache.storm.solr.schema.builder.RestJsonSchemaBuilderV2
 
buildSchema() - Method in interface org.apache.storm.solr.schema.builder.SchemaBuilder
 
buildSuccessHtmlResponse(String) - Static method in class org.apache.storm.daemon.logviewer.utils.LogviewerResponseBuilder
Build a Response object representing success response with HTML entity.
buildSuccessJsonResponse(Object, String, String) - Static method in class org.apache.storm.daemon.logviewer.utils.LogviewerResponseBuilder
Build a Response object representing success response with JSON entity.
buildTopology(ExecutionContext) - Static method in class org.apache.storm.flux.FluxBuilder
Given a topology definition, return a Storm topology that can be run either locally or remotely.
buildTopology(String) - Static method in class org.apache.storm.hbase.trident.WordCountTrident
 
buildTopology(String) - Static method in class org.apache.storm.hdfs.trident.TridentFileTopology
 
buildTopology(String) - Static method in class org.apache.storm.hdfs.trident.TridentSequenceTopology
 
buildTopology(String, String, String, Object, Object) - Static method in class org.apache.storm.hive.trident.TridentHiveTopology
 
buildTopology(String, String) - Static method in class org.apache.storm.mongodb.trident.WordCountTrident
 
buildTopology(String, String) - Static method in class org.apache.storm.mongodb.trident.WordCountTridentMap
 
buildTopology(String, Integer) - Static method in class org.apache.storm.redis.trident.WordCountTridentRedis
 
buildTopology(String) - Static method in class org.apache.storm.redis.trident.WordCountTridentRedisCluster
 
buildTopology(String) - Static method in class org.apache.storm.redis.trident.WordCountTridentRedisClusterMap
 
buildTopology(String, Integer) - Static method in class org.apache.storm.redis.trident.WordCountTridentRedisMap
 
buildTopology(String, String) - Static method in class org.apache.storm.rocketmq.topology.WordCountTopology
 
buildTopology(String, String) - Static method in class org.apache.storm.rocketmq.trident.WordCountTrident
 
buildTopology(WindowsStoreFactory) - Static method in class org.apache.storm.starter.trident.TridentHBaseWindowingStoreTopology
 
buildTopology() - Static method in class org.apache.storm.starter.trident.TridentMapExample
 
buildTopology() - Static method in class org.apache.storm.starter.trident.TridentReach
 
buildTopology(WindowsStoreFactory, WindowConfig) - Static method in class org.apache.storm.starter.trident.TridentWindowingInmemoryStoreTopology
 
buildTopology() - Static method in class org.apache.storm.starter.trident.TridentWordCount
 
buildTopology(HashMap<String, Thrift.SpoutDetails>, HashMap<String, Thrift.BoltDetails>, HashMap<String, StateSpoutSpec>) - Static method in class org.apache.storm.Thrift
 
buildTopology(Map<String, Thrift.SpoutDetails>, Map<String, Thrift.BoltDetails>) - Static method in class org.apache.storm.Thrift
 
buildTopology(Map<String, Number>) - Method in class org.apache.storm.trident.topology.TridentTopologyBuilder
 
buildUnauthorizedUserJsonResponse(String, String) - Static method in class org.apache.storm.daemon.logviewer.utils.LogviewerResponseBuilder
Build a Response object representing unauthorized user, with JSON response.
buildVehiclesTopology() - Static method in class org.apache.storm.starter.trident.TridentMinMaxOfDevicesTopology
Creates a topology which demonstrates min/max operations on tuples of stream which contain vehicle and driver fields with values TridentMinMaxOfDevicesTopology.Vehicle and TridentMinMaxOfDevicesTopology.Driver respectively.
buildVehiclesTopology() - Static method in class org.apache.storm.starter.trident.TridentMinMaxOfVehiclesTopology
Creates a topology which demonstrates min/max operations on tuples of stream which contain vehicle and driver fields with values TridentMinMaxOfVehiclesTopology.Vehicle and TridentMinMaxOfVehiclesTopology.Driver respectively.
BuiltinBoltMetrics - Class in org.apache.storm.daemon.metrics
 
BuiltinBoltMetrics(BoltExecutorStats) - Constructor for class org.apache.storm.daemon.metrics.BuiltinBoltMetrics
 
BuiltinFunctionCall() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
Parses a call to a builtin function with special syntax.
BuiltinMetrics - Class in org.apache.storm.daemon.metrics
 
BuiltinMetrics() - Constructor for class org.apache.storm.daemon.metrics.BuiltinMetrics
 
BuiltinMetricsUtil - Class in org.apache.storm.daemon.metrics
 
BuiltinMetricsUtil() - Constructor for class org.apache.storm.daemon.metrics.BuiltinMetricsUtil
 
BuiltinSpoutMetrics - Class in org.apache.storm.daemon.metrics
 
BuiltinSpoutMetrics(SpoutExecutorStats) - Constructor for class org.apache.storm.daemon.metrics.BuiltinSpoutMetrics
 
BulkIndexResponse - Class in org.apache.storm.elasticsearch.response
Mapped response for bulk index.
BulkIndexResponse() - Constructor for class org.apache.storm.elasticsearch.response.BulkIndexResponse
 
BY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
byNamedSetters() - Method in class org.apache.storm.cassandra.query.builder.BoundCQLStatementMapperBuilder
 
ByteArrayMessageMapper - Class in org.apache.storm.mqtt.mappers
 
ByteArrayMessageMapper() - Constructor for class org.apache.storm.mqtt.mappers.ByteArrayMessageMapper
 
ByTopicRecordTranslator<K,V> - Class in org.apache.storm.kafka.spout
Based off of a given Kafka topic a ConsumerRecord came from it will be translated to a Storm tuple and emitted to a given stream.
ByTopicRecordTranslator(Func<ConsumerRecord<K, V>, List<Object>>, Fields, String) - Constructor for class org.apache.storm.kafka.spout.ByTopicRecordTranslator
Create a simple record translator that will use func to extract the fields of the tuple, named by fields, and emit them to stream.
ByTopicRecordTranslator(Func<ConsumerRecord<K, V>, List<Object>>, Fields) - Constructor for class org.apache.storm.kafka.spout.ByTopicRecordTranslator
Create a simple record translator that will use func to extract the fields of the tuple, named by fields, and emit them to the default stream.
ByTopicRecordTranslator(RecordTranslator<K, V>) - Constructor for class org.apache.storm.kafka.spout.ByTopicRecordTranslator
Create a record translator with the given default translator.

C

C - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
cached - Variable in class org.apache.storm.trident.state.map.CachedBatchReadsMap.RetVal
 
CachedBatchReadsMap<T> - Class in org.apache.storm.trident.state.map
 
CachedBatchReadsMap(IBackingMap<T>) - Constructor for class org.apache.storm.trident.state.map.CachedBatchReadsMap
 
CachedBatchReadsMap.RetVal<T> - Class in org.apache.storm.trident.state.map
 
cachedGroups - Variable in class org.apache.storm.security.auth.FixedGroupsMapping
 
cachedGroups - Variable in class org.apache.storm.security.auth.ShellBasedGroupsMapping
 
CachedMap<T> - Class in org.apache.storm.trident.state.map
Useful to layer over a map that communicates with a database.
CachedMap(IBackingMap<T>, int) - Constructor for class org.apache.storm.trident.state.map.CachedMap
 
CachedSchemas - Class in org.apache.storm.sql.runtime.serde.avro
 
CachedSchemas() - Constructor for class org.apache.storm.sql.runtime.serde.avro.CachedSchemas
 
cachedSupervisors - Variable in class org.apache.storm.scheduler.blacklist.BlacklistScheduler
 
cacheSize - Variable in class org.apache.storm.container.cgroup.core.MemoryCore.Stat
 
cacheSize - Variable in class org.apache.storm.hbase.trident.state.HBaseMapState.Options
 
cacheSize - Variable in class org.apache.storm.mongodb.trident.state.MongoMapState.Options
 
cacheTargetSize - Variable in class org.apache.storm.localizer.AsyncLocalizer
 
calculateAveragePercentageUsedBy(NormalizedResourceOffer) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceOffer
Calculate the average percentage used.
calculateAveragePercentageUsedBy(NormalizedResources, double, double) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
Calculate the average resource usage percentage with this being the total resources and used being the amounts used.
calculateMinPercentageUsedBy(NormalizedResourceOffer) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceOffer
Calculate the min percentage used of the resource.
calculateMinPercentageUsedBy(NormalizedResources, double, double) - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
Calculate the minimum resource usage percentage with this being the total resources and used being the amounts used.
calculateParititionIdsToOwn() - Method in class org.apache.storm.eventhubs.spout.StaticPartitionCoordinator
 
call() - Method in class org.apache.storm.clojure.ClojureTuple
 
call(int) - Method in interface org.apache.storm.daemon.supervisor.ExitCodeCallback
The process finished.
call(T) - Method in interface org.apache.storm.daemon.supervisor.UniFunc
 
call() - Method in class org.apache.storm.executor.bolt.BoltExecutor
 
call() - Method in class org.apache.storm.executor.spout.SpoutExecutor
 
CALL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
callbackHandler - Variable in class org.apache.storm.messaging.netty.Login
 
callbackParameterName - Static variable in class org.apache.storm.daemon.ui.resources.StormApiResource
 
CALLED - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
callTimeout - Variable in class org.apache.storm.hive.common.HiveOptions
 
canAdd(TopologyDetails) - Method in class org.apache.storm.scheduler.multitenant.DefaultPool
 
canAdd(TopologyDetails) - Method in class org.apache.storm.scheduler.multitenant.FreePool
 
canAdd(TopologyDetails) - Method in class org.apache.storm.scheduler.multitenant.IsolatedPool
 
canAdd(TopologyDetails) - Method in class org.apache.storm.scheduler.multitenant.NodePool
Check if this topology can be added to this pool.
cancel() - Method in class org.apache.storm.blobstore.AtomicOutputStream
Cancel all of the writes associated with this stream and close it.
cancel() - Method in class org.apache.storm.blobstore.BlobStore.BlobStoreFileOutputStream
 
cancel() - Method in class org.apache.storm.blobstore.BlobStoreFile
 
cancel() - Method in class org.apache.storm.blobstore.LocalFsBlobStoreFile
 
cancel() - Method in class org.apache.storm.blobstore.NimbusBlobStore.NimbusUploadAtomicOutputStream
 
cancel() - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreFile
 
cancelBlobUpload(String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
 
cancelBlobUpload(String, AsyncMethodCallback<Void>) - Method in class org.apache.storm.generated.Nimbus.AsyncClient
 
cancelBlobUpload(String, AsyncMethodCallback<Void>) - Method in interface org.apache.storm.generated.Nimbus.AsyncIface
 
cancelBlobUpload() - Constructor for class org.apache.storm.generated.Nimbus.AsyncProcessor.cancelBlobUpload
 
cancelBlobUpload(String) - Method in class org.apache.storm.generated.Nimbus.Client
 
cancelBlobUpload(String) - Method in interface org.apache.storm.generated.Nimbus.Iface
 
cancelBlobUpload() - Constructor for class org.apache.storm.generated.Nimbus.Processor.cancelBlobUpload
 
cancelBlobUpload(String) - Method in class org.apache.storm.LocalCluster
 
cancelBlobUpload_args() - Constructor for class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
 
cancelBlobUpload_args(String) - Constructor for class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
 
cancelBlobUpload_args(Nimbus.cancelBlobUpload_args) - Constructor for class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
Performs a deep copy on other.
cancelBlobUpload_call(String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.storm.generated.Nimbus.AsyncClient.cancelBlobUpload_call
 
cancelBlobUpload_result() - Constructor for class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
 
cancelBlobUpload_result(AuthorizationException) - Constructor for class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
 
cancelBlobUpload_result(Nimbus.cancelBlobUpload_result) - Constructor for class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
Performs a deep copy on other.
canConvertConvention(Convention) - Method in enum org.apache.storm.sql.planner.streams.rel.StreamsLogicalConvention
 
canTransformResource(String) - Method in class org.apache.storm.maven.shade.clojure.ClojureTransformer
 
canUserReadBlob(ReadableBlobMeta, String, Map<String, Object>) - Static method in class org.apache.storm.utils.ServerUtils
 
capacity() - Method in class org.apache.storm.utils.JCQueue.QueueMetrics
 
CaptureCollector - Class in org.apache.storm.trident.operation.impl
 
CaptureCollector() - Constructor for class org.apache.storm.trident.operation.impl.CaptureCollector
 
captured - Variable in class org.apache.storm.trident.operation.impl.CaptureCollector
 
CapturedTopology(T, TupleCaptureBolt) - Constructor for class org.apache.storm.Testing.CapturedTopology
 
CaptureLoad - Class in org.apache.storm.loadgen
Capture running topologies for load gen later on.
CaptureLoad() - Constructor for class org.apache.storm.loadgen.CaptureLoad
 
capturer - Variable in class org.apache.storm.Testing.CapturedTopology
a Bolt that will hold all of the captured data.
captureTopology(StormTopology) - Static method in class org.apache.storm.Testing
Rewrites a topology so that all the tuples flowing through it are captured.
CARDINALITY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CARET - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CASCADE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CASCADED - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CASE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CaseExpression() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
 
CASSANDRA_BATCH_SIZE_ROWS - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_CONSISTENCY_LEVEL - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_DATACENTER_NAME - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_HEARTBEAT_INTERVAL_SEC - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_IDLE_TIMEOUT_SEC - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_KEYSPACE - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_LOAD_BALANCING_POLICY - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_MAX_REQUESTS_PER_CON_LOCAL - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_MAX_REQUESTS_PER_CON_REMOTE - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_NODES - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_PASSWORD - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_POOL_MAX_SIZE - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_PORT - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_RECONNECT_POLICY_BASE_MS - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_RECONNECT_POLICY_MAX_MS - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_RETRY_POLICY - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_SOCKET_CONNECT_TIMEOUT_MS - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_SOCKET_READ_TIMEOUT_MS - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CASSANDRA_USERNAME - Static variable in class org.apache.storm.cassandra.client.CassandraConf
 
CassandraBackingMap<T> - Class in org.apache.storm.cassandra.trident.state
An IBackingState implementation for Cassandra.
CassandraBackingMap(Map<String, Object>, CassandraBackingMap.Options<T>) - Constructor for class org.apache.storm.cassandra.trident.state.CassandraBackingMap
 
CassandraBackingMap.Options<T> - Class in org.apache.storm.cassandra.trident.state
 
cassandraConf - Variable in class org.apache.storm.cassandra.bolt.BaseCassandraBolt
 
CassandraConf - Class in org.apache.storm.cassandra.client
Configuration used by cassandra storm components.
CassandraConf() - Constructor for class org.apache.storm.cassandra.client.CassandraConf
Creates a new CassandraConf instance.
CassandraConf(Map<String, Object>) - Constructor for class org.apache.storm.cassandra.client.CassandraConf
Creates a new CassandraConf instance.
CassandraConfFactory() - Constructor for class org.apache.storm.cassandra.CassandraContext.CassandraConfFactory
 
CassandraContext - Class in org.apache.storm.cassandra
 
CassandraContext() - Constructor for class org.apache.storm.cassandra.CassandraContext
Creates a new CassandraContext instance.
CassandraContext.CassandraConfFactory - Class in org.apache.storm.cassandra
Simple class to make CassandraConf from a Storm topology configuration.
CassandraContext.ClientFactory - Class in org.apache.storm.cassandra
Simple class to make CassandraContext.ClientFactory from a Storm topology configuration.
CassandraMapStateFactory - Class in org.apache.storm.cassandra.trident.state
A StateFactory implementation that creates a MapState backed by CassandraBackingMap.
CassandraQuery - Class in org.apache.storm.cassandra.trident.state
 
CassandraQuery() - Constructor for class org.apache.storm.cassandra.trident.state.CassandraQuery
 
CassandraState - Class in org.apache.storm.cassandra.trident.state
 
CassandraState(Map<String, Object>, CassandraState.Options) - Constructor for class org.apache.storm.cassandra.trident.state.CassandraState
 
CassandraState.Options - Class in org.apache.storm.cassandra.trident.state
 
CassandraStateFactory - Class in org.apache.storm.cassandra.trident.state
 
CassandraStateFactory(CassandraState.Options) - Constructor for class org.apache.storm.cassandra.trident.state.CassandraStateFactory
 
CassandraStateFactory(CQLStatementTupleMapper, CQLResultSetValuesMapper) - Constructor for class org.apache.storm.cassandra.trident.state.CassandraStateFactory
 
CassandraStateUpdater - Class in org.apache.storm.cassandra.trident.state
 
CassandraStateUpdater() - Constructor for class org.apache.storm.cassandra.trident.state.CassandraStateUpdater
 
CassandraWriterBolt - Class in org.apache.storm.cassandra.bolt
 
CassandraWriterBolt(CQLStatementTupleMapper) - Constructor for class org.apache.storm.cassandra.bolt.CassandraWriterBolt
Creates a new CassandraWriterBolt instance.
CAST - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CATALOG - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CATALOG_NAME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
cb(Metric) - Method in interface org.apache.storm.metricstore.MetricStore.ScanCallback
 
CEIL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
ceil(DateTime, int) - Static method in class org.apache.storm.st.utils.TimeUtil
 
CEILING - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CENTURY - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CGROUP_CLONE_CHILDREN - Static variable in class org.apache.storm.container.cgroup.CgroupCommon
 
CGROUP_EVENT_CONTROL - Static variable in class org.apache.storm.container.cgroup.CgroupCommon
 
CGROUP_PROCS - Static variable in class org.apache.storm.container.cgroup.CgroupCommon
 
CGROUP_STATUS_FILE - Static variable in class org.apache.storm.container.cgroup.CgroupUtils
 
CgroupCenter - Class in org.apache.storm.container.cgroup
 
CgroupCommon - Class in org.apache.storm.container.cgroup
 
CgroupCommon(String, Hierarchy, CgroupCommon) - Constructor for class org.apache.storm.container.cgroup.CgroupCommon
 
CgroupCommon(Hierarchy, String) - Constructor for class org.apache.storm.container.cgroup.CgroupCommon
 
CgroupCommonOperation - Interface in org.apache.storm.container.cgroup
 
CgroupCore - Interface in org.apache.storm.container.cgroup.core
 
CgroupCoreFactory - Class in org.apache.storm.container.cgroup
 
CgroupCoreFactory() - Constructor for class org.apache.storm.container.cgroup.CgroupCoreFactory
 
CGroupCpu - Class in org.apache.storm.metric.cgroup
Report CPU used in the cgroup.
CGroupCpu(Map<String, Object>) - Constructor for class org.apache.storm.metric.cgroup.CGroupCpu
 
CGroupCpuGuarantee - Class in org.apache.storm.metric.cgroup
Report the guaranteed number of ms this worker has requested.
CGroupCpuGuarantee(Map<String, Object>) - Constructor for class org.apache.storm.metric.cgroup.CGroupCpuGuarantee
 
CgroupManager - Class in org.apache.storm.container.cgroup
Class that implements ResourceIsolationInterface that manages cgroups.
CgroupManager() - Constructor for class org.apache.storm.container.cgroup.CgroupManager
 
CGroupMemoryLimit - Class in org.apache.storm.metric.cgroup
Reports the current memory limit of the cgroup for this worker.
CGroupMemoryLimit(Map<String, Object>) - Constructor for class org.apache.storm.metric.cgroup.CGroupMemoryLimit
 
CGroupMemoryUsage - Class in org.apache.storm.metric.cgroup
Reports the current memory usage of the cgroup for this worker.
CGroupMemoryUsage(Map<String, Object>) - Constructor for class org.apache.storm.metric.cgroup.CGroupMemoryUsage
 
CGroupMetricsBase<T> - Class in org.apache.storm.metric.cgroup
Base class for checking if CGroups are enabled, etc.
CGroupMetricsBase(Map<String, Object>, SubSystemType) - Constructor for class org.apache.storm.metric.cgroup.CGroupMetricsBase
 
CgroupOperation - Interface in org.apache.storm.container.cgroup
An interface to implement the basic functions to manage cgroups such as mount and mounting a hiearchy and creating cgroups.
CgroupUtils - Class in org.apache.storm.container.cgroup
 
CgroupUtils() - Constructor for class org.apache.storm.container.cgroup.CgroupUtils
 
CHAIN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
chainedAgg() - Method in class org.apache.storm.trident.fluent.GroupedStream
 
chainedAgg() - Method in class org.apache.storm.trident.Stream
 
ChainedAggregatorDeclarer - Class in org.apache.storm.trident.fluent
 
ChainedAggregatorDeclarer(IAggregatableStream, GlobalAggregationScheme) - Constructor for class org.apache.storm.trident.fluent.ChainedAggregatorDeclarer
 
ChainedAggregatorDeclarer.AggregationPartition - Interface in org.apache.storm.trident.fluent
 
ChainedAggregatorImpl - Class in org.apache.storm.trident.operation.impl
 
ChainedAggregatorImpl(Aggregator[], Fields[], ComboList.Factory) - Constructor for class org.apache.storm.trident.operation.impl.ChainedAggregatorImpl
 
ChainedFullAggregatorDeclarer - Interface in org.apache.storm.trident.fluent
 
ChainedPartitionAggregatorDeclarer - Interface in org.apache.storm.trident.fluent
 
ChainedProcessorContext - Class in org.apache.storm.streams.processors
A composite context that holds a chain of ProcessorContext.
ChainedProcessorContext(ProcessorNode, List<? extends ProcessorContext>) - Constructor for class org.apache.storm.streams.processors.ChainedProcessorContext
 
ChainedProcessorContext(ProcessorNode, ProcessorContext...) - Constructor for class org.apache.storm.streams.processors.ChainedProcessorContext
 
ChainedResult - Class in org.apache.storm.trident.operation.impl
 
ChainedResult(TridentCollector, int) - Constructor for class org.apache.storm.trident.operation.impl.ChainedResult
 
chainEnd() - Method in class org.apache.storm.trident.fluent.ChainedAggregatorDeclarer
 
chainEnd() - Method in interface org.apache.storm.trident.fluent.IChainedAggregatorDeclarer
 
changeChildCWD(boolean) - Method in class org.apache.storm.spout.ShellSpout
 
changeChildCWD(boolean) - Method in class org.apache.storm.task.ShellBolt
Set if the current working directory of the child process should change to the resources dir from extracted from the jar, or if it should stay the same as the worker process to access things from the blob store.
changed(Watcher.Event.EventType, String) - Method in interface org.apache.storm.callback.ZKStateChangedCallback
 
channelActive(Channel) - Method in interface org.apache.storm.messaging.netty.IServer
 
channelActive(ChannelHandlerContext) - Method in class org.apache.storm.messaging.netty.KerberosSaslClientHandler
 
channelActive(ChannelHandlerContext) - Method in class org.apache.storm.messaging.netty.SaslStormClientHandler
 
channelActive(ChannelHandlerContext) - Method in class org.apache.storm.messaging.netty.StormServerHandler
 
channelActive(ChannelHandlerContext) - Method in class org.apache.storm.pacemaker.PacemakerClientHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.storm.messaging.netty.KerberosSaslClientHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.storm.messaging.netty.KerberosSaslServerHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.storm.messaging.netty.SaslStormClientHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.storm.messaging.netty.SaslStormServerAuthorizeHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.storm.messaging.netty.SaslStormServerHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.storm.messaging.netty.StormClientHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.storm.messaging.netty.StormServerHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.storm.pacemaker.PacemakerClientHandler
 
channelReady(Channel) - Method in class org.apache.storm.messaging.netty.Client
 
channelReady(Channel) - Method in interface org.apache.storm.messaging.netty.ISaslClient
 
channelReady(Channel) - Method in class org.apache.storm.pacemaker.PacemakerClient
 
channelRegistered(ChannelHandlerContext) - Method in class org.apache.storm.messaging.netty.KerberosSaslClientHandler
 
channelUnregistered(ChannelHandlerContext) - Method in class org.apache.storm.messaging.netty.KerberosSaslClientHandler
 
CHAR - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CHAR_LENGTH - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CHARACTER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CHARACTER_LENGTH - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CHARACTER_SET_CATALOG - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CHARACTER_SET_NAME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CHARACTER_SET_SCHEMA - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CHARACTERISTICS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CHARACTERS - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CHARSET - Static variable in class org.apache.storm.hdfs.spout.TextFileReader
 
CHARSETNAME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CHECK - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
Check() - Constructor for class org.apache.storm.starter.InOrderDeliveryTest.Check
 
checkAuthorization(String, Map<String, Object>, String) - Method in class org.apache.storm.daemon.nimbus.Nimbus
 
checkAuthorization(String, Map<String, Object>, String, ReqContext) - Method in class org.apache.storm.daemon.nimbus.Nimbus
 
checkAuthorization(String) - Method in class org.apache.storm.daemon.supervisor.Supervisor
 
checkAuthorization(String, Map<String, Object>, String) - Method in class org.apache.storm.daemon.supervisor.Supervisor
 
checkAuthorization(String, Map<String, Object>, String, ReqContext) - Method in class org.apache.storm.daemon.supervisor.Supervisor
 
checkCredentialsChanged() - Method in class org.apache.storm.daemon.worker.Worker
 
checkDirExists(String) - Static method in class org.apache.storm.utils.Utils
 
checkFileExists(String) - Static method in class org.apache.storm.utils.Utils
 
checkForBlobOrDownload(String) - Method in class org.apache.storm.blobstore.LocalFsBlobStore
 
checkForBlobUpdate(String) - Method in class org.apache.storm.blobstore.LocalFsBlobStore
 
checkForValidUsers(Subject, int) - Method in class org.apache.storm.blobstore.BlobStoreAclHandler
 
checkInitialization(Map<String, Double>, String, Map<String, Object>) - Static method in class org.apache.storm.loadgen.CaptureLoad
Checks if the topology’s resource requirements are initialized.
checkLogConfigChanged() - Method in class org.apache.storm.daemon.worker.Worker
 
checkpoint() - Method in interface org.apache.storm.eventhubs.spout.IPartitionManager
 
checkpoint() - Method in class org.apache.storm.eventhubs.spout.SimplePartitionManager
 
CHECKPOINT_COMPONENT_ID - Static variable in class org.apache.storm.spout.CheckpointSpout
 
CHECKPOINT_FIELD_ACTION - Static variable in class org.apache.storm.spout.CheckpointSpout
 
CHECKPOINT_FIELD_TXID - Static variable in class org.apache.storm.spout.CheckpointSpout
 
CHECKPOINT_STREAM_ID - Static variable in class org.apache.storm.spout.CheckpointSpout
 
CheckpointSpout - Class in org.apache.storm.spout
Emits checkpoint tuples which is used to save the state of the IStatefulComponent across the topology.
CheckpointSpout() - Constructor for class org.apache.storm.spout.CheckpointSpout
 
CheckPointState - Class in org.apache.storm.spout
Captures the current state of the transaction in CheckpointSpout.
CheckPointState(long, CheckPointState.State) - Constructor for class org.apache.storm.spout.CheckPointState
 
CheckPointState() - Constructor for class org.apache.storm.spout.CheckPointState
 
CheckPointState.Action - Enum in org.apache.storm.spout
 
CheckPointState.State - Enum in org.apache.storm.spout
 
CheckpointTupleForwarder - Class in org.apache.storm.topology
Wraps IRichBolt and forwards checkpoint tuples in a stateful topology.
CheckpointTupleForwarder(IRichBolt) - Constructor for class org.apache.storm.topology.CheckpointTupleForwarder
 
checkSerialize(KryoTupleSerializer, AddressedTuple) - Method in class org.apache.storm.daemon.worker.WorkerState
 
checkSslConfig(String, KeyStoreLoader) - Static method in class org.apache.storm.mqtt.common.SslUtils
 
checkType(ComponentObject._Fields, Object) - Method in class org.apache.storm.generated.ComponentObject
 
checkType(ExecutorSpecificStats._Fields, Object) - Method in class org.apache.storm.generated.ExecutorSpecificStats
 
checkType(Grouping._Fields, Object) - Method in class org.apache.storm.generated.Grouping
 
checkType(HBMessageData._Fields, Object) - Method in class org.apache.storm.generated.HBMessageData
 
checkType(JavaObjectArg._Fields, Object) - Method in class org.apache.storm.generated.JavaObjectArg
 
checkType(SpecificAggregateStats._Fields, Object) - Method in class org.apache.storm.generated.SpecificAggregateStats
 
checkType(TopologyActionOptions._Fields, Object) - Method in class org.apache.storm.generated.TopologyActionOptions
 
chooseTask(int[]) - Method in class org.apache.storm.grouping.PartialKeyGrouping.BalancedTargetSelector
Chooses one of the incoming tasks and selects the one that has been selected the fewest times so far.
chooseTask(int[]) - Method in interface org.apache.storm.grouping.PartialKeyGrouping.TargetSelector
 
chooseTaskIndex(List<T>, int) - Static method in class org.apache.storm.utils.TupleUtils
 
chooseTasks(int, List<Object>) - Method in class org.apache.storm.cassandra.Murmur3StreamGrouping
This function implements a custom stream grouping.
chooseTasks(int, List<Object>) - Method in class org.apache.storm.daemon.GrouperFactory.AllGrouper
 
chooseTasks(int, List<Object>) - Method in class org.apache.storm.daemon.GrouperFactory.BasicLoadAwareCustomStreamGrouping
 
chooseTasks(int, List<Object>) - Method in class org.apache.storm.daemon.GrouperFactory.FieldsGrouper
 
chooseTasks(int, List<Object>) - Method in class org.apache.storm.daemon.GrouperFactory.GlobalGrouper
 
chooseTasks(int, List<Object>) - Method in class org.apache.storm.daemon.GrouperFactory.NoneGrouper
 
chooseTasks(int, List<Object>) - Method in interface org.apache.storm.grouping.CustomStreamGrouping
This function implements a custom stream grouping.
chooseTasks(int, List<Object>) - Method in class org.apache.storm.grouping.LoadAwareShuffleGrouping
 
chooseTasks(int, List<Object>) - Method in class org.apache.storm.grouping.PartialKeyGrouping
 
chooseTasks(int, List<Object>) - Method in class org.apache.storm.grouping.ShuffleGrouping
 
chooseTasks(int, List<Object>) - Method in class org.apache.storm.testing.NGrouping
 
chooseTasks(int, List<Object>) - Method in class org.apache.storm.trident.partition.GlobalGrouping
 
chooseTasks(int, List<Object>) - Method in class org.apache.storm.trident.partition.IdentityGrouping
 
chooseTasks(int, List<Object>) - Method in class org.apache.storm.trident.partition.IndexHashGrouping
 
CLASS_ORIGIN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CLASSIFIER - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
classLoaders - Variable in class org.apache.storm.sql.AbstractStreamsProcessor
 
className() - Method in class org.apache.storm.sql.parser.SqlCreateFunction
 
clean() - Method in interface org.apache.storm.testing.CompletableSpout
Cleanup any global state kept.
cleanConnection(boolean) - Method in class org.apache.storm.mqtt.common.MqttOptions.Builder
 
cleanInbox(String, int) - Static method in class org.apache.storm.daemon.nimbus.Nimbus
Deletes jar files in dirLoc older than seconds.
cleanup() - Method in class org.apache.storm.cassandra.bolt.BaseCassandraBolt
Called when an IBolt is going to be shutdown.
cleanup() - Method in class org.apache.storm.cassandra.trident.state.CassandraState
 
cleanup() - Method in class org.apache.storm.clojure.ClojureBolt
 
cleanup() - Method in class org.apache.storm.coordination.BatchBoltExecutor
 
cleanup() - Method in class org.apache.storm.coordination.CoordinatedBolt
 
cleanup() - Method in class org.apache.storm.daemon.Acker
 
cleanUp() - Method in class org.apache.storm.daemon.supervisor.Container
 
cleanUp() - Method in interface org.apache.storm.daemon.supervisor.Killable
Clean up the container.
cleanup() - Method in class org.apache.storm.drpc.KeyedFairBolt
 
cleanup() - Method in class org.apache.storm.drpc.ReturnResults
 
cleanup() - Method in class org.apache.storm.eventhubs.bolt.EventHubBolt
 
cleanup() - Method in class org.apache.storm.flux.examples.WordCounter
 
cleanup() - Method in class org.apache.storm.hbase.bolt.AbstractHBaseBolt
 
cleanup() - Method in class org.apache.storm.hbase.topology.TotalWordCounter
 
cleanup() - Method in class org.apache.storm.hbase.topology.WordCounter
 
cleanup() - Method in class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
 
cleanup() - Method in class org.apache.storm.hdfs.bolt.HdfsFileTopology.MyBolt
 
cleanup() - Method in class org.apache.storm.hdfs.bolt.SequenceFileTopology.MyBolt
 
cleanup() - Method in class org.apache.storm.hive.bolt.HiveBolt
 
cleanup() - Method in class org.apache.storm.hive.trident.HiveState
 
cleanup() - Method in class org.apache.storm.hooks.BaseTaskHook
 
cleanup() - Method in interface org.apache.storm.hooks.ITaskHook
 
cleanup() - Method in class org.apache.storm.jdbc.bolt.AbstractJdbcBolt
Cleanup.
cleanup() - Method in interface org.apache.storm.jdbc.common.ConnectionProvider
called once when the system is shutting down, should be idempotent.
cleanup() - Method in class org.apache.storm.jdbc.common.HikariCPConnectionProvider
 
cleanup() - Method in class org.apache.storm.jms.bolt.JmsBolt
Releases JMS resources.
cleanup() - Method in class org.apache.storm.jms.example.GenericBolt
 
cleanup() - Method in class org.apache.storm.kafka.bolt.KafkaBolt
 
cleanup() - Method in class org.apache.storm.loadgen.HttpForwardingMetricsConsumer
 
cleanup(ClientBlobStore) - Method in class org.apache.storm.localizer.LocalizedResourceRetentionSet
Actually cleanup the blobs to try and get below the target cache size.
cleanup() - Method in interface org.apache.storm.metric.api.IClusterMetricsConsumer
 
cleanup() - Method in interface org.apache.storm.metric.api.IMetricsConsumer
 
cleanup() - Method in class org.apache.storm.metric.ClusterMetricsConsumerExecutor
 
cleanup() - Method in class org.apache.storm.metric.EventLoggerBolt
 
cleanup() - Method in class org.apache.storm.metric.LoggingClusterMetricsConsumer
 
cleanup() - Method in class org.apache.storm.metric.LoggingMetricsConsumer
 
cleanup() - Method in class org.apache.storm.metric.MetricsConsumerBolt
 
cleanup() - Method in class org.apache.storm.metric.SystemBolt
 
cleanup() - Method in class org.apache.storm.mongodb.bolt.AbstractMongoBolt
 
cleanup() - Method in class org.apache.storm.mongodb.topology.TotalWordCounter
 
cleanup() - Method in class org.apache.storm.mongodb.topology.WordCounter
 
cleanup() - Method in interface org.apache.storm.nimbus.ITopologyActionNotifierPlugin
Called during shutdown.
cleanup() - Method in class org.apache.storm.opentsdb.bolt.OpenTsdbBolt
 
cleanup() - Method in class org.apache.storm.opentsdb.client.OpenTsdbClient
 
cleanup() - Method in class org.apache.storm.redis.bolt.AbstractRedisBolt
 
cleanup() - Method in class org.apache.storm.redis.topology.WordCounter
 
cleanup() - Method in class org.apache.storm.rocketmq.bolt.RocketMqBolt
 
cleanup() - Method in class org.apache.storm.rocketmq.topology.WordCounter
 
cleanup() - Method in class org.apache.storm.scheduler.blacklist.BlacklistScheduler
 
cleanup() - Method in interface org.apache.storm.scheduler.IScheduler
called once when the system is shutting down, should be idempotent.
cleanup() - Method in class org.apache.storm.scheduler.resource.ResourceAwareScheduler
 
cleanup() - Method in class org.apache.storm.solr.bolt.SolrUpdateBolt
 
cleanup() - Method in class org.apache.storm.sql.runtime.datasource.socket.bolt.SocketBolt
 
cleanup() - Method in class org.apache.storm.starter.MultiThreadWordCountTopology.MultiThreadedSplitSentence
 
cleanup() - Method in interface org.apache.storm.task.IBolt
Called when an IBolt is going to be shutdown.
cleanup() - Method in class org.apache.storm.task.ShellBolt
 
cleanup() - Method in class org.apache.storm.testing.FixedTupleSpout
 
cleanup() - Method in class org.apache.storm.testing.ForwardingMetricsConsumer
 
cleanup() - Method in class org.apache.storm.testing.NonRichBoltTracker
 
cleanup() - Method in class org.apache.storm.testing.TestAggregatesCounter
 
cleanup() - Method in class org.apache.storm.testing.TestEventLogSpout
 
cleanup() - Method in class org.apache.storm.testing.TestEventOrderCheckBolt
 
cleanup() - Method in class org.apache.storm.testing.TestGlobalCount
 
cleanup() - Method in class org.apache.storm.testing.TestWordCounter
 
cleanup() - Method in class org.apache.storm.testing.TupleCaptureBolt
 
cleanup() - Method in class org.apache.storm.topology.base.BaseBasicBolt
 
cleanup() - Method in class org.apache.storm.topology.base.BaseRichBolt
 
cleanup() - Method in class org.apache.storm.topology.base.BaseStatefulBolt
 
cleanup() - Method in class org.apache.storm.topology.base.BaseWindowedBolt
 
cleanup() - Method in class org.apache.storm.topology.BasicBoltExecutor
 
cleanup() - Method in class org.apache.storm.topology.CheckpointTupleForwarder
 
cleanup() - Method in interface org.apache.storm.topology.IBasicBolt
 
cleanup() - Method in interface org.apache.storm.topology.IStatefulBolt
Analogue to bolt function.
cleanup() - Method in interface org.apache.storm.topology.IWindowedBolt
 
cleanup() - Method in class org.apache.storm.topology.StatefulBoltExecutor
 
cleanup() - Method in class org.apache.storm.topology.WindowedBoltExecutor
 
cleanup() - Method in class org.apache.storm.trident.drpc.ReturnResultsReducer
 
cleanup() - Method in class org.apache.storm.trident.operation.BaseMultiReducer
 
cleanup() - Method in class org.apache.storm.trident.operation.BaseOperation
No-op implemnation.
cleanup() - Method in class org.apache.storm.trident.operation.builtin.Negate
 
cleanup() - Method in interface org.apache.storm.trident.operation.GroupedMultiReducer
 
cleanup() - Method in class org.apache.storm.trident.operation.impl.ChainedAggregatorImpl
 
cleanup() - Method in class org.apache.storm.trident.operation.impl.CombinerAggregatorCombineImpl
 
cleanup() - Method in class org.apache.storm.trident.operation.impl.CombinerAggregatorInitImpl
 
cleanup() - Method in class org.apache.storm.trident.operation.impl.CombinerAggStateUpdater
 
cleanup() - Method in class org.apache.storm.trident.operation.impl.FilterExecutor
 
cleanup() - Method in class org.apache.storm.trident.operation.impl.FlatMapFunctionExecutor
 
cleanup() - Method in class org.apache.storm.trident.operation.impl.GroupedAggregator
 
cleanup() - Method in class org.apache.storm.trident.operation.impl.GroupedMultiReducerExecutor
 
cleanup() - Method in class org.apache.storm.trident.operation.impl.IdentityMultiReducer
 
cleanup() - Method in class org.apache.storm.trident.operation.impl.JoinerMultiReducer
 
cleanup() - Method in class org.apache.storm.trident.operation.impl.MapFunctionExecutor
 
cleanup() - Method in class org.apache.storm.trident.operation.impl.PreservingFieldsOrderJoinerMultiReducer
 
cleanup() - Method in class org.apache.storm.trident.operation.impl.ReducerAggregatorImpl
 
cleanup() - Method in class org.apache.storm.trident.operation.impl.ReducerAggStateUpdater
 
cleanup() - Method in class org.apache.storm.trident.operation.impl.SingleEmitAggregator
 
cleanup() - Method in class org.apache.storm.trident.operation.impl.TrueFilter
 
cleanup() - Method in interface org.apache.storm.trident.operation.MultiReducer
 
cleanup() - Method in interface org.apache.storm.trident.operation.Operation
When running in local mode, called when the local cluster is being shut down.
cleanup() - Method in class org.apache.storm.trident.planner.processor.AggregateProcessor
 
cleanup() - Method in class org.apache.storm.trident.planner.processor.EachProcessor
 
cleanup() - Method in class org.apache.storm.trident.planner.processor.MapProcessor
 
cleanup() - Method in class org.apache.storm.trident.planner.processor.MultiReducerProcessor
 
cleanup() - Method in class org.apache.storm.trident.planner.processor.PartitionPersistProcessor
 
cleanup() - Method in class org.apache.storm.trident.planner.processor.ProjectedProcessor
 
cleanup() - Method in class org.apache.storm.trident.planner.processor.StateQueryProcessor
 
cleanup() - Method in class org.apache.storm.trident.planner.SubtopologyBolt
 
cleanup() - Method in interface org.apache.storm.trident.planner.TridentProcessor
 
cleanup() - Method in class org.apache.storm.trident.spout.TridentSpoutCoordinator
 
cleanup() - Method in class org.apache.storm.trident.spout.TridentSpoutExecutor
 
cleanup() - Method in class org.apache.storm.trident.state.map.MapCombinerAggStateUpdater
 
cleanup() - Method in class org.apache.storm.trident.state.map.MapReducerAggStateUpdater
 
cleanup() - Method in interface org.apache.storm.trident.topology.ITridentBatchBolt
 
cleanup() - Method in class org.apache.storm.trident.topology.TridentBoltExecutor
 
cleanup() - Method in class org.apache.storm.trident.windowing.WindowsStateUpdater
 
cleanup() - Method in class org.apache.storm.trident.windowing.WindowTridentProcessor
 
cleanup(int) - Method in class org.apache.storm.utils.LocalState
 
cleanup() - Method in class org.apache.storm.utils.TimeCacheMap
Deprecated.
 
cleanup() - Method in class org.apache.storm.utils.VersionedStore
 
cleanup(int) - Method in class org.apache.storm.utils.VersionedStore
 
cleanupBefore(long) - Method in class org.apache.storm.trident.topology.state.RotatingTransactionalState
 
cleanUpForRestart() - Method in class org.apache.storm.daemon.supervisor.BasicContainer
 
cleanUpForRestart() - Method in class org.apache.storm.daemon.supervisor.Container
Clean up the container partly preparing for restart.
cleanupOrphanedData() - Method in class org.apache.storm.localizer.LocalizedResource
 
cleanupOrphanedData() - Method in class org.apache.storm.localizer.LocallyCachedBlob
Clean up any temporary files.
cleanupOrphanedData() - Method in class org.apache.storm.localizer.LocallyCachedTopologyBlob
 
cleanupStats() - Method in class org.apache.storm.stats.BoltExecutorStats
 
cleanupStats() - Method in class org.apache.storm.stats.CommonStats
 
cleanupStats() - Method in class org.apache.storm.stats.SpoutExecutorStats
 
clear() - Method in class org.apache.storm.clojure.ClojureTuple
 
clear() - Method in class org.apache.storm.clojure.IndifferentAccessMap
 
clear() - Method in class org.apache.storm.daemon.nimbus.TopoCache
Clear all entries from the Cache.
clear() - Method in class org.apache.storm.executor.TupleInfo
 
clear() - Method in class org.apache.storm.generated.AccessControl
 
clear() - Method in exception org.apache.storm.generated.AlreadyAliveException
 
clear() - Method in class org.apache.storm.generated.Assignment
 
clear() - Method in exception org.apache.storm.generated.AuthorizationException
 
clear() - Method in class org.apache.storm.generated.BeginDownloadResult
 
clear() - Method in class org.apache.storm.generated.Bolt
 
clear() - Method in class org.apache.storm.generated.BoltAggregateStats
 
clear() - Method in class org.apache.storm.generated.BoltStats
 
clear() - Method in class org.apache.storm.generated.ClusterSummary
 
clear() - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
 
clear() - Method in class org.apache.storm.generated.CommonAggregateStats
 
clear() - Method in class org.apache.storm.generated.ComponentAggregateStats
 
clear() - Method in class org.apache.storm.generated.ComponentCommon
 
clear() - Method in class org.apache.storm.generated.ComponentPageInfo
 
clear() - Method in class org.apache.storm.generated.Credentials
 
clear() - Method in class org.apache.storm.generated.DebugOptions
 
clear() - Method in class org.apache.storm.generated.DistributedRPC.execute_args
 
clear() - Method in class org.apache.storm.generated.DistributedRPC.execute_result
 
clear() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args
 
clear() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result
 
clear() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
 
clear() - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result
 
clear() - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args
 
clear() - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
 
clear() - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_args
 
clear() - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_result
 
clear() - Method in exception org.apache.storm.generated.DRPCExecutionException
 
clear() - Method in class org.apache.storm.generated.DRPCRequest
 
clear() - Method in class org.apache.storm.generated.ErrorInfo
 
clear() - Method in class org.apache.storm.generated.ExecutorAggregateStats
 
clear() - Method in class org.apache.storm.generated.ExecutorInfo
 
clear() - Method in class org.apache.storm.generated.ExecutorStats
 
clear() - Method in class org.apache.storm.generated.ExecutorSummary
 
clear() - Method in class org.apache.storm.generated.GetInfoOptions
 
clear() - Method in class org.apache.storm.generated.GlobalStreamId
 
clear() - Method in exception org.apache.storm.generated.HBAuthorizationException
 
clear() - Method in exception org.apache.storm.generated.HBExecutionException
 
clear() - Method in class org.apache.storm.generated.HBMessage
 
clear() - Method in class org.apache.storm.generated.HBNodes
 
clear() - Method in class org.apache.storm.generated.HBPulse
 
clear() - Method in class org.apache.storm.generated.HBRecords
 
clear() - Method in exception org.apache.storm.generated.IllegalStateException
 
clear() - Method in exception org.apache.storm.generated.InvalidTopologyException
 
clear() - Method in class org.apache.storm.generated.JavaObject
 
clear() - Method in exception org.apache.storm.generated.KeyAlreadyExistsException
 
clear() - Method in exception org.apache.storm.generated.KeyNotFoundException
 
clear() - Method in class org.apache.storm.generated.KillOptions
 
clear() - Method in class org.apache.storm.generated.ListBlobsResult
 
clear() - Method in class org.apache.storm.generated.LocalAssignment
 
clear() - Method in class org.apache.storm.generated.LocalStateData
 
clear() - Method in class org.apache.storm.generated.LogConfig
 
clear() - Method in class org.apache.storm.generated.LogLevel
 
clear() - Method in class org.apache.storm.generated.LSApprovedWorkers
 
clear() - Method in class org.apache.storm.generated.LSSupervisorAssignments
 
clear() - Method in class org.apache.storm.generated.LSSupervisorId
 
clear() - Method in class org.apache.storm.generated.LSTopoHistory
 
clear() - Method in class org.apache.storm.generated.LSTopoHistoryList
 
clear() - Method in class org.apache.storm.generated.LSWorkerHeartbeat
 
clear() - Method in class org.apache.storm.generated.Nimbus.activate_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.activate_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.deactivate_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.deactivate_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.debug_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.debug_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.deleteBlob_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.downloadChunk_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getLeader_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getLeader_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getLogConfig_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getLogConfig_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getTopology_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getTopology_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.getUserTopology_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.killTopology_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.killTopology_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.listBlobs_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.listBlobs_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.rebalance_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.rebalance_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.setLogConfig_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.setLogConfig_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.submitTopology_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.uploadChunk_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.uploadChunk_result
 
clear() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_args
 
clear() - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_result
 
clear() - Method in class org.apache.storm.generated.NimbusSummary
 
clear() - Method in class org.apache.storm.generated.NodeInfo
 
clear() - Method in exception org.apache.storm.generated.NotAliveException
 
clear() - Method in class org.apache.storm.generated.NullStruct
 
clear() - Method in class org.apache.storm.generated.OwnerResourceSummary
 
clear() - Method in class org.apache.storm.generated.PrivateWorkerKey
 
clear() - Method in class org.apache.storm.generated.ProfileRequest
 
clear() - Method in class org.apache.storm.generated.ReadableBlobMeta
 
clear() - Method in class org.apache.storm.generated.RebalanceOptions
 
clear() - Method in class org.apache.storm.generated.SettableBlobMeta
 
clear() - Method in class org.apache.storm.generated.SharedMemory
 
clear() - Method in class org.apache.storm.generated.ShellComponent
 
clear() - Method in class org.apache.storm.generated.SpoutAggregateStats
 
clear() - Method in class org.apache.storm.generated.SpoutSpec
 
clear() - Method in class org.apache.storm.generated.SpoutStats
 
clear() - Method in class org.apache.storm.generated.StateSpoutSpec
 
clear() - Method in class org.apache.storm.generated.StormBase
 
clear() - Method in class org.apache.storm.generated.StormTopology
 
clear() - Method in class org.apache.storm.generated.StreamInfo
 
clear() - Method in class org.apache.storm.generated.SubmitOptions
 
clear() - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args
 
clear() - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
 
clear() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args
 
clear() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result
 
clear() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args
 
clear() - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result
 
clear() - Method in class org.apache.storm.generated.SupervisorAssignments
 
clear() - Method in class org.apache.storm.generated.SupervisorInfo
 
clear() - Method in class org.apache.storm.generated.SupervisorPageInfo
 
clear() - Method in class org.apache.storm.generated.SupervisorSummary
 
clear() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
 
clear() - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
 
clear() - Method in class org.apache.storm.generated.ThriftSerializedObject
 
clear() - Method in class org.apache.storm.generated.TopologyHistoryInfo
 
clear() - Method in class org.apache.storm.generated.TopologyInfo
 
clear() - Method in class org.apache.storm.generated.TopologyPageInfo
 
clear() - Method in class org.apache.storm.generated.TopologyStats
 
clear() - Method in class org.apache.storm.generated.TopologySummary
 
clear() - Method in class org.apache.storm.generated.WorkerMetricList
 
clear() - Method in class org.apache.storm.generated.WorkerMetricPoint
 
clear() - Method in class org.apache.storm.generated.WorkerMetrics
 
clear() - Method in class org.apache.storm.generated.WorkerResources
 
clear() - Method in class org.apache.storm.generated.WorkerSummary
 
clear() - Method in class org.apache.storm.generated.WorkerToken
 
clear() - Method in class org.apache.storm.generated.WorkerTokenInfo
 
clear() - Method in class org.apache.storm.loadgen.ScopedTopologySet
 
clear() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceOffer
 
clear() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResourceRequest
 
clear() - Method in class org.apache.storm.scheduler.resource.normalization.NormalizedResources
Set all resources to 0.
clear() - Method in interface org.apache.storm.scheduler.resource.normalization.NormalizedResourcesWithMemory
Set all resources to 0.
clear(String) - Static method in class org.apache.storm.testing.FixedTupleSpout
 
clear() - Method in class org.apache.storm.utils.ListDelegate
 
clear() - Method in class org.apache.storm.utils.TransferDrainer
 
clearCredentials(Subject, KerberosTicket) - Static method in class org.apache.storm.security.auth.kerberos.AutoTGT
 
clearForceEmpty() - Method in class org.apache.storm.container.cgroup.core.MemoryCore
 
clearIteratorPins() - Method in class org.apache.storm.windowing.persistence.WindowState
 
clearState(String) - Static method in class org.apache.storm.utils.RegisteredGlobalState
 
clearStateForStorm(String) - Method in interface org.apache.storm.assignments.ILocalAssignmentsBackend
Clear all the state for a storm.
clearStateForStorm(String) - Method in class org.apache.storm.assignments.InMemoryAssignmentBackend
 
clearTrackId() - Static method in class org.apache.storm.executor.LocalExecutor
 
CLI - Class in org.apache.storm.command
 
CLI() - Constructor for class org.apache.storm.command.CLI
 
CLI.Assoc - Interface in org.apache.storm.command
 
CLI.CLIBuilder - Class in org.apache.storm.command
 
CLI.Parse - Interface in org.apache.storm.command
 
CLIBuilder() - Constructor for class org.apache.storm.command.CLI.CLIBuilder
 
client - Variable in class org.apache.storm.cassandra.bolt.BaseCassandraBolt
 
client - Static variable in class org.apache.storm.elasticsearch.bolt.AbstractEsBolt
 
Client(TProtocol) - Constructor for class org.apache.storm.generated.DistributedRPC.Client
 
Client(TProtocol, TProtocol) - Constructor for class org.apache.storm.generated.DistributedRPC.Client
 
Client(TProtocol) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.Client
 
Client(TProtocol, TProtocol) - Constructor for class org.apache.storm.generated.DistributedRPCInvocations.Client
 
Client(TProtocol) - Constructor for class org.apache.storm.generated.Nimbus.Client
 
Client(TProtocol, TProtocol) - Constructor for class org.apache.storm.generated.Nimbus.Client
 
Client(TProtocol) - Constructor for class org.apache.storm.generated.Supervisor.Client
 
Client(TProtocol, TProtocol) - Constructor for class org.apache.storm.generated.Supervisor.Client
 
Client - Class in org.apache.storm.messaging.netty
A Netty client for sending task messages to a remote destination (Netty server).
client - Variable in class org.apache.storm.security.auth.kerberos.AutoTGTKrb5LoginModuleTest
 
CLIENT_BLOBSTORE - Static variable in class org.apache.storm.Config
What blobstore implementation the storm client should use.
CLIENT_USERS_KEY - Static variable in class org.apache.storm.security.auth.authorizer.DRPCSimpleACLAuthorizer
 
ClientAuthUtils - Class in org.apache.storm.security.auth
 
ClientAuthUtils() - Constructor for class org.apache.storm.security.auth.ClientAuthUtils
 
ClientBlobStore - Class in org.apache.storm.blobstore
The ClientBlobStore has two concrete implementations 1.
ClientBlobStore() - Constructor for class org.apache.storm.blobstore.ClientBlobStore
 
ClientBlobStore.WithBlobstore - Interface in org.apache.storm.blobstore
 
ClientCallbackHandler - Class in org.apache.storm.security.auth.kerberos
SASL client side callback handler.
ClientCallbackHandler(Map<String, Object>) - Constructor for class org.apache.storm.security.auth.kerberos.ClientCallbackHandler
Constructor based on a JAAS configuration.
ClientFactory() - Constructor for class org.apache.storm.cassandra.CassandraContext.ClientFactory
 
ClientMetricsUtils - Class in org.apache.storm.daemon.metrics
 
ClientMetricsUtils() - Constructor for class org.apache.storm.daemon.metrics.ClientMetricsUtils
 
clientProvider - Variable in class org.apache.storm.cassandra.bolt.BaseCassandraBolt
 
ClientResponse - Interface in org.apache.storm.opentsdb.client
This class represents the response from OpenTsdb for a request sent.
ClientResponse.Details - Class in org.apache.storm.opentsdb.client
 
ClientResponse.Details.Error - Class in org.apache.storm.opentsdb.client
 
ClientResponse.Summary - Class in org.apache.storm.opentsdb.client
 
ClientStatsUtil - Class in org.apache.storm.stats
Stats calculations needed by storm client code.
ClientStatsUtil() - Constructor for class org.apache.storm.stats.ClientStatsUtil
 
ClientSupervisorUtils - Class in org.apache.storm.daemon.supervisor
 
ClientSupervisorUtils() - Constructor for class org.apache.storm.daemon.supervisor.ClientSupervisorUtils
 
clientUsers - Variable in class org.apache.storm.security.auth.authorizer.DRPCSimpleACLAuthorizer.AclFunctionEntry
 
ClientZookeeper - Class in org.apache.storm.zookeeper
 
ClientZookeeper() - Constructor for class org.apache.storm.zookeeper.ClientZookeeper
 
CLOB - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CLOCKS_INSYNC - Static variable in class org.apache.storm.hdfs.spout.Configs
Deprecated.
ClojureBolt - Class in org.apache.storm.clojure
 
ClojureBolt(List, List, List<Object>, Map<String, StreamInfo>) - Constructor for class org.apache.storm.clojure.ClojureBolt
 
ClojureSerializationRegister - Class in org.apache.storm.clojure
 
ClojureSerializationRegister() - Constructor for class org.apache.storm.clojure.ClojureSerializationRegister
 
ClojureSpout - Class in org.apache.storm.clojure
 
ClojureSpout(List, List, List<Object>, Map<String, StreamInfo>) - Constructor for class org.apache.storm.clojure.ClojureSpout
 
ClojureTransformer - Class in org.apache.storm.maven.shade.clojure
 
ClojureTransformer() - Constructor for class org.apache.storm.maven.shade.clojure.ClojureTransformer
 
ClojureTuple - Class in org.apache.storm.clojure
 
ClojureTuple(Tuple) - Constructor for class org.apache.storm.clojure.ClojureTuple
 
ClojureUtil - Class in org.apache.storm.clojure
 
ClojureUtil() - Constructor for class org.apache.storm.clojure.ClojureUtil
 
clone() - Method in class org.apache.storm.hdfs.spout.SequenceFileReader.Offset
 
clone() - Method in class org.apache.storm.hdfs.spout.TextFileReader.Offset
 
cloneKerberosTicket(KerberosTicket) - Static method in class org.apache.storm.security.auth.ClientAuthUtils
 
close() - Method in interface org.apache.storm.assignments.ILocalAssignmentsBackend
Function to release resource.
close() - Method in class org.apache.storm.assignments.InMemoryAssignmentBackend
 
close() - Method in class org.apache.storm.blobstore.BlobStore.BlobStoreFileInputStream
 
close() - Method in class org.apache.storm.blobstore.BlobStore.BlobStoreFileOutputStream
 
close() - Method in class org.apache.storm.blobstore.BlobStore
 
close() - Method in class org.apache.storm.blobstore.ClientBlobStore
 
close() - Method in class org.apache.storm.blobstore.LocalModeClientBlobStore
 
close() - Method in class org.apache.storm.blobstore.NimbusBlobStore
 
close() - Method in class org.apache.storm.blobstore.NimbusBlobStore.NimbusUploadAtomicOutputStream
 
close() - Method in class org.apache.storm.cassandra.client.impl.DefaultClient
Close the underlying Cluster instance.
close() - Method in interface org.apache.storm.cassandra.client.SimpleClient
Close the underlying Cluster instance.
close() - Method in class org.apache.storm.clojure.ClojureSpout
 
close() - Method in interface org.apache.storm.cluster.IStateStorage
Close the connection to the data store.
close() - Method in class org.apache.storm.cluster.PaceMakerStateStorage
 
close() - Method in class org.apache.storm.cluster.ZKStateStorage
 
close() - Method in class org.apache.storm.daemon.drpc.DRPC
 
close() - Method in class org.apache.storm.daemon.drpc.DRPCServer
 
close() - Method in class org.apache.storm.daemon.logviewer.LogviewerServer
 
close() - Method in class org.apache.storm.daemon.logviewer.utils.LogCleaner
 
close() - Method in class org.apache.storm.daemon.nimbus.TimedWritableByteChannel
 
close() - Method in class org.apache.storm.daemon.supervisor.ReadClusterState
 
close() - Method in class org.apache.storm.daemon.supervisor.Slot
 
close() - Method in class org.apache.storm.daemon.supervisor.Supervisor
 
close() - Method in class org.apache.storm.drpc.DRPCSpout
 
close() - Method in class org.apache.storm.elasticsearch.trident.TridentEsTopology.FixedBatchSpout
Closes the spout.
close() - Method in class org.apache.storm.event.EventManagerImp
 
close() - Method in class org.apache.storm.eventhubs.spout.EventHubReceiverImpl
 
close() - Method in class org.apache.storm.eventhubs.spout.EventHubSpout
 
close() - Method in interface org.apache.storm.eventhubs.spout.IEventHubReceiver
 
close() - Method in interface org.apache.storm.eventhubs.spout.IPartitionManager
 
close() - Method in interface org.apache.storm.eventhubs.spout.IStateStore
 
close() - Method in class org.apache.storm.eventhubs.spout.SimplePartitionManager
 
close() - Method in class org.apache.storm.eventhubs.spout.ZookeeperStateStore
 
close() - Method in class org.apache.storm.eventhubs.trident.Coordinator
 
close() - Method in interface org.apache.storm.eventhubs.trident.ITridentPartitionManager
 
close() - Method in class org.apache.storm.eventhubs.trident.OpaqueTridentEventHubEmitter
 
close() - Method in class org.apache.storm.eventhubs.trident.TransactionalTridentEventHubEmitter
 
close() - Method in class org.apache.storm.eventhubs.trident.TridentPartitionManager
 
close() - Method in class org.apache.storm.hbase.common.HBaseClient
 
close() - Method in class org.apache.storm.hbase.topology.WordSpout
 
close() - Method in class org.apache.storm.hdfs.blobstore.HdfsClientBlobStore
 
close() - Method in interface org.apache.storm.hdfs.bolt.Writer
 
close() - Method in class org.apache.storm.hdfs.common.AbstractHDFSWriter
 
close() - Method in class org.apache.storm.hdfs.spout.HdfsSpout
 
close() - Method in class org.apache.storm.hdfs.spout.SequenceFileReader
 
close() - Method in class org.apache.storm.hdfs.spout.TextFileReader
 
close() - Method in class org.apache.storm.hdfs.trident.FixedBatchSpout
 
close() - Method in class org.apache.storm.hive.common.HiveWriter
Close the Transaction Batch and connection.
close() - Method in class org.apache.storm.hive.trident.TridentHiveTopology.FixedBatchSpout
 
close() - Method in class org.apache.storm.jdbc.spout.UserSpout
 
close() - Method in class org.apache.storm.jms.spout.JmsSpout
close() - Method in class org.apache.storm.kafka.spout.KafkaSpout
 
close() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentOpaqueSpoutEmitter
 
close() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutCoordinator
 
close() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentSpoutEmitter
 
close() - Method in class org.apache.storm.kafka.spout.trident.KafkaTridentTransactionalSpoutEmitter
 
close() - Method in class org.apache.storm.kinesis.spout.KinesisSpout
 
close() - Method in class org.apache.storm.loadgen.ScopedTopologySet
 
close() - Method in class org.apache.storm.LocalCluster
 
close() - Method in class org.apache.storm.LocalCluster.LocalTopology
 
close() - Method in class org.apache.storm.LocalDRPC
 
close() - Method in class org.apache.storm.localizer.AsyncLocalizer
 
close() - Method in class org.apache.storm.LogWriter
 
close() - Method in interface org.apache.storm.messaging.IConnection
close this connection.
close() - Method in class org.apache.storm.messaging.netty.Client
Gracefully close this client.
close() - Method in class org.apache.storm.metric.FileBasedEventLogger
 
close() - Method in interface org.apache.storm.metric.IEventLogger
 
close() - Method in class org.apache.storm.metric.internal.CountStatAndMetric
 
close() - Method in class org.apache.storm.metric.internal.LatencyStatAndMetric
 
close() - Method in class org.apache.storm.metric.internal.MultiCountStatAndMetric
 
close() - Method in class org.apache.storm.metric.internal.MultiLatencyStatAndMetric
 
close() - Method in class org.apache.storm.metric.internal.RateTracker
 
close() - Method in class org.apache.storm.metric.timed.TimedResource
 
close() - Method in interface org.apache.storm.metric.timed.TimerDecorated
 
close() - Method in interface org.apache.storm.metricstore.MetricStore
Close the metric store.
close() - Method in class org.apache.storm.metricstore.NoOpMetricStore
 
close() - Method in class org.apache.storm.metricstore.rocksdb.MetricsCleaner
 
close() - Method in class org.apache.storm.metricstore.rocksdb.RocksDbMetricsWriter
 
close() - Method in class org.apache.storm.metricstore.rocksdb.RocksDbStore
Shutdown the store.
close() - Method in class org.apache.storm.mongodb.common.MongoDbClient
Closes all resources associated with this instance.
close() - Method in class org.apache.storm.mongodb.topology.WordSpout
 
close() - Method in class org.apache.storm.mqtt.spout.MqttSpout
 
close() - Method in class org.apache.storm.nimbus.AssignmentDistributionService
 
close() - Method in interface org.apache.storm.nimbus.ILeaderElector
Method called to allow for cleanup.
close() - Method in class org.apache.storm.opentsdb.MetricGenBatchSpout
 
close() - Method in class org.apache.storm.pacemaker.PacemakerClient
 
close() - Method in class org.apache.storm.pacemaker.PacemakerClientPool
 
close() - Method in class org.apache.storm.perf.utils.BasicMetricsCollector
 
close() - Method in class org.apache.storm.pmml.RawInputFromCSVSpout
 
close() - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedis
 
close() - Method in class org.apache.storm.redis.common.adapter.RedisCommandsAdapterJedisCluster
 
close() - Method in class org.apache.storm.redis.common.container.JedisClusterContainer
Release Container.
close() - Method in interface org.apache.storm.redis.common.container.JedisCommandsInstanceContainer
Release Container.
close() - Method in class org.apache.storm.redis.common.container.JedisContainer
Release Container.
close() - Method in class org.apache.storm.redis.common.container.RedisClusterContainer
close() - Method in class org.apache.storm.redis.common.container.RedisContainer
close() - Method in class org.apache.storm.redis.topology.WordSpout
 
close() - Method in class org.apache.storm.rocketmq.spout.RocketMqSpout
 
close() - Method in class org.apache.storm.security.auth.digest.DigestSaslTransportPlugin
 
close() - Method in class org.apache.storm.security.auth.kerberos.KerberosSaslTransportPlugin
 
close() - Method in class org.apache.storm.security.auth.kerberos.NoOpTTrasport
 
close() - Method in class org.apache.storm.security.auth.sasl.SaslTransportPlugin
 
close() - Method in class org.apache.storm.security.auth.ThriftClient
 
close() - Method in class org.apache.storm.security.auth.workertoken.WorkerTokenAuthorizer
 
close() - Method in class org.apache.storm.solr.spout.SolrFieldsSpout
 
close() - Method in class org.apache.storm.solr.spout.SolrJsonSpout
 
close() - Method in interface org.apache.storm.spout.ISpout
Called when an ISpout is going to be shutdown.
close() - Method in class org.apache.storm.spout.ShellSpout
 
CLOSE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
close() - Method in class org.apache.storm.sql.runtime.datasource.socket.spout.SocketSpout
 
close() - Method in class org.apache.storm.starter.spout.RandomNumberGeneratorSpout
 
close() - Method in interface org.apache.storm.state.IStateSpout
 
close() - Method in class org.apache.storm.StormTimer
cancel timer.
close() - Method in class org.apache.storm.testing.FeederSpout
 
close() - Method in class org.apache.storm.testing.FixedTupleSpout
 
close() - Method in class org.apache.storm.testing.InProcessZookeeper
 
close() - Method in class org.apache.storm.testing.MockLeaderElector
 
close() - Method in class org.apache.storm.testing.SpoutTracker
 
close() - Method in class org.apache.storm.testing.staticmocking.MockedClientZookeeper
 
close() - Method in class org.apache.storm.testing.staticmocking.MockedCluster
 
close() - Method in class org.apache.storm.testing.staticmocking.MockedSupervisorUtils
 
close() - Method in class org.apache.storm.testing.staticmocking.MockedZookeeper
 
close() - Method in class org.apache.storm.testing.TestEventLogSpout
 
close() - Method in class org.apache.storm.testing.TestPlannerSpout
 
close() - Method in class org.apache.storm.testing.TestWordSpout
 
close() - Method in class org.apache.storm.testing.TmpPath
 
close() - Method in class org.apache.storm.topology.base.BaseRichSpout
 
close() - Method in class org.apache.storm.trident.spout.BatchSpoutExecutor.BatchSpoutEmitter
 
close() - Method in class org.apache.storm.trident.spout.BatchSpoutExecutor.EmptyCoordinator
 
close() - Method in interface org.apache.storm.trident.spout.IBatchSpout
 
close() - Method in interface org.apache.storm.trident.spout.IOpaquePartitionedTridentSpout.Coordinator
 
close() - Method in interface org.apache.storm.trident.spout.IOpaquePartitionedTridentSpout.Emitter
 
close() - Method in interface org.apache.storm.trident.spout.IPartitionedTridentSpout.Coordinator
 
close() - Method in interface org.apache.storm.trident.spout.IPartitionedTridentSpout.Emitter
 
close() - Method in interface org.apache.storm.trident.spout.ITridentSpout.BatchCoordinator
Release any resources from this coordinator.
close() - Method in interface org.apache.storm.trident.spout.ITridentSpout.Emitter
Release any resources held by this emitter.
close() - Method in class org.apache.storm.trident.spout.OpaquePartitionedTridentSpoutExecutor.Coordinator
 
close() - Method in class org.apache.storm.trident.spout.OpaquePartitionedTridentSpoutExecutor.Emitter
 
close() - Method in class org.apache.storm.trident.spout.RichSpoutBatchTriggerer
 
close() - Method in class org.apache.storm.trident.testing.FeederBatchSpout.FeederCoordinator
 
close() - Method in class org.apache.storm.trident.testing.FixedBatchSpout
 
close() - Method in class org.apache.storm.trident.topology.MasterBatchCoordinator
 
close() - Method in class org.apache.storm.trident.topology.state.TransactionalState
 
close() - Method in class org.apache.storm.utils.BufferFileInputStream
 
close() - Method in class org.apache.storm.utils.BufferInputStream
 
close() - Method in class org.apache.storm.utils.DRPCClient.LocalOverride
 
close() - Method in class org.apache.storm.utils.JCQueue
 
close() - Method in class org.apache.storm.utils.JCQueue.QueueMetrics
 
close() - Method in class org.apache.storm.utils.NimbusClient.LocalOverride
 
close() - Method in class org.apache.storm.utils.StormCommonInstaller
 
close() - Method in interface org.apache.storm.utils.SupervisorIfaceFactory
 
close() - Method in class org.apache.storm.utils.Time.SimulatedTime
 
close() - Method in class org.apache.storm.zookeeper.LeaderElectorImp
 
closed - Variable in class org.apache.storm.hive.common.HiveWriter
 
closeResources() - Method in class org.apache.storm.daemon.worker.WorkerState
 
CLS - Static variable in class org.apache.storm.st.topology.window.data.TimeData
 
Cluster - Class in org.apache.storm.scheduler
The current state of the storm cluster.
Cluster(INimbus, ResourceMetrics, Map<String, SupervisorDetails>, Map<String, ? extends SchedulerAssignment>, Topologies, Map<String, Object>) - Constructor for class org.apache.storm.scheduler.Cluster
 
Cluster(Cluster) - Constructor for class org.apache.storm.scheduler.Cluster
Copy constructor.
Cluster(Cluster, Topologies) - Constructor for class org.apache.storm.scheduler.Cluster
Testing Constructor that takes an existing cluster and replaces the topologies in it.
cluster - Variable in class org.apache.storm.scheduler.multitenant.NodePool
 
cluster - Variable in class org.apache.storm.scheduler.resource.strategies.scheduling.BaseResourceAwareStrategy
 
CLUSTER_NAME - Static variable in class org.apache.storm.elasticsearch.common.EsConstants
The cluster name.
ClusterFactory - Class in org.apache.storm.cassandra.client
Default interface to build cassandra Cluster from the a Storm Topology configuration.
ClusterFactory() - Constructor for class org.apache.storm.cassandra.client.ClusterFactory
 
ClusterInfo(long) - Constructor for class org.apache.storm.metric.api.IClusterMetricsConsumer.ClusterInfo
 
ClusterMetricRegistryValidator() - Constructor for class org.apache.storm.validation.ConfigValidation.ClusterMetricRegistryValidator
 
ClusterMetricsConsumerExecutor - Class in org.apache.storm.metric
 
ClusterMetricsConsumerExecutor(String, Object) - Constructor for class org.apache.storm.metric.ClusterMetricsConsumerExecutor
 
ClusterStateContext - Class in org.apache.storm.cluster
This class is intended to provide runtime-context to StateStorageFactory implementors, giving information such as what daemon is creating it.
ClusterStateContext() - Constructor for class org.apache.storm.cluster.ClusterStateContext
 
ClusterStateContext(DaemonType, Map<String, Object>) - Constructor for class org.apache.storm.cluster.ClusterStateContext
 
ClusterStateListener - Interface in org.apache.storm.cluster
 
ClusterSummary - Class in org.apache.storm.generated
 
ClusterSummary() - Constructor for class org.apache.storm.generated.ClusterSummary
 
ClusterSummary(List<SupervisorSummary>, List<TopologySummary>, List<NimbusSummary>) - Constructor for class org.apache.storm.generated.ClusterSummary
 
ClusterSummary(ClusterSummary) - Constructor for class org.apache.storm.generated.ClusterSummary
Performs a deep copy on other.
ClusterSummary._Fields - Enum in org.apache.storm.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClusterUtils - Class in org.apache.storm.cluster
 
ClusterUtils() - Constructor for class org.apache.storm.cluster.ClusterUtils
 
ClusterWorkerHeartbeat - Class in org.apache.storm.generated
 
ClusterWorkerHeartbeat() - Constructor for class org.apache.storm.generated.ClusterWorkerHeartbeat
 
ClusterWorkerHeartbeat(String, Map<ExecutorInfo, ExecutorStats>, int, int) - Constructor for class org.apache.storm.generated.ClusterWorkerHeartbeat
 
ClusterWorkerHeartbeat(ClusterWorkerHeartbeat) - Constructor for class org.apache.storm.generated.ClusterWorkerHeartbeat
Performs a deep copy on other.
ClusterWorkerHeartbeat._Fields - Enum in org.apache.storm.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
COALESCE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
COBOL - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
coGroupByKey(PairStream<K, V1>) - Method in class org.apache.storm.streams.PairStream
Groups the values of this stream with the values having the same key from the other stream.
CoGroupByKeyProcessor<K,V1,V2> - Class in org.apache.storm.streams.processors
co-group by key implementation.
CoGroupByKeyProcessor(String, String) - Constructor for class org.apache.storm.streams.processors.CoGroupByKeyProcessor
 
COLLATE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CollateClause() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
Parses a COLLATE clause
COLLATION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
COLLATION_CATALOG - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
COLLATION_ID - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
COLLATION_NAME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
COLLATION_SCHEMA - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
collect(Nimbus.Iface) - Method in class org.apache.storm.perf.utils.BasicMetricsCollector
 
COLLECT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
COLLECTION - Static variable in class org.apache.storm.solr.topology.SolrTopology
 
COLLECTION_NAME - Static variable in class org.apache.storm.sql.mongodb.MongoDataSourcesProvider
 
collectionName - Variable in class org.apache.storm.mongodb.trident.state.MongoMapState.Options
 
CollectionsTypeName() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
 
collectMetricsAndKill(String, Integer, int) - Static method in class org.apache.storm.perf.utils.Helper
 
collector - Variable in class org.apache.storm.elasticsearch.bolt.AbstractEsBolt
 
collector - Variable in class org.apache.storm.eventhubs.bolt.EventHubBolt
 
collector - Variable in class org.apache.storm.hbase.bolt.AbstractHBaseBolt
 
collector - Variable in class org.apache.storm.hdfs.bolt.AbstractHdfsBolt
 
collector - Variable in class org.apache.storm.jdbc.bolt.AbstractJdbcBolt
 
collector - Variable in class org.apache.storm.kafka.spout.KafkaSpout
 
collector - Variable in class org.apache.storm.mongodb.bolt.AbstractMongoBolt
 
collector - Variable in class org.apache.storm.mqtt.spout.MqttSpout
 
collector - Variable in class org.apache.storm.redis.bolt.AbstractRedisBolt
 
collector - Variable in class org.apache.storm.topology.BaseStatefulBoltExecutor
 
collectTridentTupleOrKey(TridentBatchTuple, List<String>) - Method in class org.apache.storm.trident.windowing.StoreBasedTridentWindowManager
 
COLON - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
Column<T> - Class in org.apache.storm.cassandra.query
 
Column(String, T) - Constructor for class org.apache.storm.cassandra.query.Column
 
Column<T> - Class in org.apache.storm.jdbc.common
A database table can be defined as a list of rows and each row can be defined as a list of columns where each column instance has a name, a value and a type.
Column(String, T, int) - Constructor for class org.apache.storm.jdbc.common.Column
 
Column(String, int) - Constructor for class org.apache.storm.jdbc.common.Column
 
column - Variable in class org.apache.storm.sql.parser.impl.SimpleCharStream
 
COLUMN - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
COLUMN_NAME - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
ColumnConstraint - Class in org.apache.storm.sql.parser
 
ColumnConstraint.PrimaryKey - Class in org.apache.storm.sql.parser
 
ColumnDefinition - Class in org.apache.storm.sql.parser
 
ColumnDefinition(SqlIdentifier, SqlDataTypeSpec, ColumnConstraint, SqlParserPos) - Constructor for class org.apache.storm.sql.parser.ColumnDefinition
 
ColumnDefinitionList() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
 
columnFamily - Variable in class org.apache.storm.hbase.trident.state.HBaseMapState.Options
 
ColumnList - Class in org.apache.storm.hbase.common
Represents a list of HBase columns.
ColumnList() - Constructor for class org.apache.storm.hbase.common.ColumnList
 
ColumnList.AbstractColumn - Class in org.apache.storm.hbase.common
 
ColumnList.Column - Class in org.apache.storm.hbase.common
 
ColumnList.Counter - Class in org.apache.storm.hbase.common
 
ColumnMetaData(String, String) - Constructor for class org.apache.storm.hbase.bolt.mapper.HBaseProjectionCriteria.ColumnMetaData
 
ColumnMetaData(byte[], byte[]) - Constructor for class org.apache.storm.hbase.bolt.mapper.HBaseProjectionCriteria.ColumnMetaData
 
columns(Tuple) - Method in interface org.apache.storm.hbase.bolt.mapper.HBaseMapper
Given a tuple, return a list of HBase columns to insert.
columns(Tuple) - Method in class org.apache.storm.hbase.bolt.mapper.SimpleHBaseMapper
 
columns(TridentTuple) - Method in class org.apache.storm.hbase.trident.mapper.SimpleTridentHBaseMapper
 
columns(TridentTuple) - Method in interface org.apache.storm.hbase.trident.mapper.TridentHBaseMapper
Given a tuple, return a list of HBase columns to insert.
ColumnType(List<SqlNode>) - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
 
combine(T, T) - Method in interface org.apache.storm.metric.api.ICombiner
 
combine(Integer, Integer) - Method in class org.apache.storm.starter.trident.TridentReach.One
 
combine(Long, Long) - Method in class org.apache.storm.trident.operation.builtin.Count
 
combine(Number, Number) - Method in class org.apache.storm.trident.operation.builtin.Sum
 
combine(T, T) - Method in interface org.apache.storm.trident.operation.CombinerAggregator
 
CombinedMetric - Class in org.apache.storm.metric.api
 
CombinedMetric(ICombiner) - Constructor for class org.apache.storm.metric.api.CombinedMetric
 
CombinedShellMetric - Class in org.apache.storm.metric.api.rpc
 
CombinedShellMetric(ICombiner) - Constructor for class org.apache.storm.metric.api.rpc.CombinedShellMetric
 
CombinerAggregator<T,A,R> - Interface in org.apache.storm.streams.operations
Interface for aggregating values.
CombinerAggregator<T> - Interface in org.apache.storm.trident.operation
 
CombinerAggregatorCombineImpl - Class in org.apache.storm.trident.operation.impl
 
CombinerAggregatorCombineImpl(CombinerAggregator) - Constructor for class org.apache.storm.trident.operation.impl.CombinerAggregatorCombineImpl
 
CombinerAggregatorInitImpl - Class in org.apache.storm.trident.operation.impl
 
CombinerAggregatorInitImpl(CombinerAggregator) - Constructor for class org.apache.storm.trident.operation.impl.CombinerAggregatorInitImpl
 
CombinerAggStateUpdater - Class in org.apache.storm.trident.operation.impl
 
CombinerAggStateUpdater(CombinerAggregator) - Constructor for class org.apache.storm.trident.operation.impl.CombinerAggStateUpdater
 
CombinerValueUpdater - Class in org.apache.storm.trident.state
 
CombinerValueUpdater(CombinerAggregator, Object) - Constructor for class org.apache.storm.trident.state.CombinerValueUpdater
 
ComboList - Class in org.apache.storm.trident.tuple
 
ComboList(List[], ComboList.Pointer[]) - Constructor for class org.apache.storm.trident.tuple.ComboList
 
ComboList.Factory - Class in org.apache.storm.trident.tuple
 
COMMA - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
COMMAND_FUNCTION - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
COMMAND_FUNCTION_CODE - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
CommandExec - Class in org.apache.storm.maven.plugin.util
 
CommandExec(Mojo) - Constructor for class org.apache.storm.maven.plugin.util.CommandExec
 
COMMANDS - Static variable in class org.apache.storm.command.AdminCommands
 
commit() - Method in class org.apache.storm.blobstore.BlobStoreFile
 
commit() - Method in class org.apache.storm.blobstore.LocalFsBlobStoreFile
 
commit(Long) - Method in class org.apache.storm.cassandra.trident.state.CassandraState
 
commit(long) - Method in class org.apache.storm.hbase.state.HBaseKeyValueState
 
commit() - Method in class org.apache.storm.hbase.state.HBaseKeyValueState
 
commit(Long) - Method in class org.apache.storm.hbase.trident.state.HBaseState
 
commit() - Method in class org.apache.storm.hdfs.blobstore.HdfsBlobStoreFile
 
commit(Long) - Method in class org.apache.storm.hdfs.trident.HdfsState
 
commit(Long) - Method in class org.apache.storm.hive.trident.HiveState
 
commit(Long) - Method in class org.apache.storm.jdbc.trident.state.JdbcState
 
commit(Long) - Method in class org.apache.storm.jms.trident.JmsState
 
commit(OffsetAndMetadata) - Method in class org.apache.storm.kafka.spout.internal.OffsetManager
Marks an offset as committed.
commit(Long) - Method in class org.apache.storm.kafka.trident.TridentKafkaState
 
commit(Long) - Method in class org.apache.storm.mongodb.trident.state.MongoState
 
commit(Long) - Method in class org.apache.storm.opentsdb.trident.OpenTsdbState
 
commit(long) - Method in class org.apache.storm.redis.state.RedisKeyValueState
 
commit() - Method in class org.apache.storm.redis.state.RedisKeyValueState
 
commit(Long) - Method in class org.apache.storm.redis.trident.state.RedisClusterState
commit(Long) - Method in class org.apache.storm.redis.trident.state.RedisState
commit(Long) - Method in class org.apache.storm.rocketmq.trident.state.RocketMqState
 
commit() - Method in class org.apache.storm.security.auth.kerberos.AutoTGTKrb5LoginModule
 
commit() - Method in class org.apache.storm.solr.config.CountBasedCommit
 
commit() - Method in interface org.apache.storm.solr.config.SolrCommitStrategy
 
commit(Long) - Method in class org.apache.storm.solr.trident.SolrState
 
COMMIT - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
commit() - Method in class org.apache.storm.state.InMemoryKeyValueState
 
commit(long) - Method in class org.apache.storm.state.InMemoryKeyValueState
 
commit(long) - Method in interface org.apache.storm.state.State
Commit a previously prepared transaction.
commit() - Method in interface org.apache.storm.state.State
Persist the current state.
commit(TransactionAttempt) - Method in interface org.apache.storm.trident.spout.ICommitterTridentSpout.Emitter
 
commit(TransactionAttempt) - Method in class org.apache.storm.trident.spout.OpaquePartitionedTridentSpoutExecutor.Emitter
 
commit(Long) - Method in class org.apache.storm.trident.state.map.NonTransactionalMap
 
commit(Long) - Method in class org.apache.storm.trident.state.map.OpaqueMap
 
commit(Long) - Method in class org.apache.storm.trident.state.map.SnapshottableMap
 
commit(Long) - Method in class org.apache.storm.trident.state.map.TransactionalMap
 
commit(Long) - Method in class org.apache.storm.trident.state.ReadOnlyState
 
commit(Long) - Method in interface org.apache.storm.trident.state.State
 
commit(Long) - Method in class org.apache.storm.trident.testing.LRUMemoryMapState
 
commit(Long) - Method in class org.apache.storm.trident.testing.MemoryMapState
 
commit(Long) - Method in class org.apache.storm.trident.windowing.WindowsState
 
commit(long) - Method in class org.apache.storm.windowing.persistence.WindowState
Commits the WindowState.
COMMIT_FREQ_COUNT - Static variable in class org.apache.storm.hdfs.spout.Configs
COMMIT_FREQ_SEC - Static variable in class org.apache.storm.hdfs.spout.Configs
Deprecated.
COMMIT_STREAM_ID - Static variable in class org.apache.storm.trident.topology.MasterBatchCoordinator
 
CommitFailure(HiveEndPoint, Long, Throwable) - Constructor for exception org.apache.storm.hive.common.HiveWriter.CommitFailure
 
CommitMetadata - Class in org.apache.storm.kafka.spout.internal
Object representing metadata committed to Kafka.
CommitMetadata(String, int, String) - Constructor for class org.apache.storm.kafka.spout.internal.CommitMetadata
Kafka metadata.
CommitMetadataManager - Class in org.apache.storm.kafka.spout.internal
Generates and reads commit metadata.
CommitMetadataManager(TopologyContext, KafkaSpoutConfig.ProcessingGuarantee) - Constructor for class org.apache.storm.kafka.spout.internal.CommitMetadataManager
Create a manager with the given context.
commitNewVersion(long) - Method in class org.apache.storm.localizer.LocalizedResource
 
commitNewVersion(long) - Method in class org.apache.storm.localizer.LocallyCachedBlob
Commit the new version and make it available for the end user.
commitNewVersion(long) - Method in class org.apache.storm.localizer.LocallyCachedTopologyBlob
 
commitStream - Variable in class org.apache.storm.trident.topology.TridentBoltExecutor.CoordCondition
 
commitStream - Variable in class org.apache.storm.trident.topology.TridentBoltExecutor.CoordSpec
 
COMMITTED - Static variable in interface org.apache.storm.sql.parser.impl.StormParserImplConstants
 
committedOffset - Variable in class org.apache.storm.eventhubs.spout.SimplePartitionManager
 
committer - Variable in class org.apache.storm.trident.planner.ProcessorNode
 
COMMON_CPU_RESOURCE_NAME - Static variable in class org.apache.storm.Constants
 
COMMON_OFFHEAP_MEMORY_RESOURCE_NAME - Static variable in class org.apache.storm.Constants
 
COMMON_ONHEAP_MEMORY_RESOURCE_NAME - Static variable in class org.apache.storm.Constants
 
COMMON_TOTAL_MEMORY_RESOURCE_NAME - Static variable in class org.apache.storm.Constants
 
CommonAggregateStats - Class in org.apache.storm.generated
 
CommonAggregateStats() - Constructor for class org.apache.storm.generated.CommonAggregateStats
 
CommonAggregateStats(CommonAggregateStats) - Constructor for class org.apache.storm.generated.CommonAggregateStats
Performs a deep copy on other.
CommonAggregateStats._Fields - Enum in org.apache.storm.generated
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CommonKafkaSpoutConfig<K,V> - Class in org.apache.storm.kafka.spout.internal
 
CommonKafkaSpoutConfig(CommonKafkaSpoutConfig.Builder<K, V, ?>) - Constructor for class org.apache.storm.kafka.spout.internal.CommonKafkaSpoutConfig
Creates a new CommonKafkaSpoutConfig using a Builder.
CommonKafkaSpoutConfig.Builder<K,V,T extends CommonKafkaSpoutConfig.Builder<K,V,T>> - Class in org.apache.storm.kafka.spout.internal
 
CommonNonReservedKeyWord() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
Parses a non-reserved keyword for use as an identifier.
CommonStats - Class in org.apache.storm.stats
 
CommonStats(int, int) - Constructor for class org.apache.storm.stats.CommonStats
 
comp() - Method in class org.apache.storm.sql.parser.impl.StormParserImpl
Parses a comparison operator inside a SOME / ALL predicate.
compactWindow() - Method in class org.apache.storm.windowing.StatefulWindowManager
 
compactWindow() - Method in class org.apache.storm.windowing.WindowManager
expires events that fall out of the window every EXPIRE_EVENTS_THRESHOLD so that the window does not grow too big.
compare(FileStatus, FileStatus) - Method in class org.apache.storm.hdfs.common.ModifTimeComparator
 
compare(TopicPartition, TopicPartition) - Method in class org.apache.storm.kafka.spout.TopicPartitionComparator
 
compare(T, T) - Method in class org.apache.storm.trident.operation.builtin.ComparisonAggregator
 
compare(Comparable<Object>, Comparable<Object>) - Method in class org.apache.storm.trident.operation.builtin.Max
 
compare(T, T) - Method in class org.apache.storm.trident.operation.builtin.MaxWithComparator
 
compare(Comparable<Object>, Comparable<Object>) - Method in class org.apache.storm.trident.operation.builtin.Min
 
compare(T, T) - Method in class org.apache.storm.trident.operation.builtin.MinWithComparator
 
compareTo(EventDataWrap) - Method in class org.apache.storm.eventhubs.spout.EventDataWrap
 
compareTo(AccessControl) - Method in class org.apache.storm.generated.AccessControl
 
compareTo(AlreadyAliveException) - Method in exception org.apache.storm.generated.AlreadyAliveException
 
compareTo(Assignment) - Method in class org.apache.storm.generated.Assignment
 
compareTo(AuthorizationException) - Method in exception org.apache.storm.generated.AuthorizationException
 
compareTo(BeginDownloadResult) - Method in class org.apache.storm.generated.BeginDownloadResult
 
compareTo(Bolt) - Method in class org.apache.storm.generated.Bolt
 
compareTo(BoltAggregateStats) - Method in class org.apache.storm.generated.BoltAggregateStats
 
compareTo(BoltStats) - Method in class org.apache.storm.generated.BoltStats
 
compareTo(ClusterSummary) - Method in class org.apache.storm.generated.ClusterSummary
 
compareTo(ClusterWorkerHeartbeat) - Method in class org.apache.storm.generated.ClusterWorkerHeartbeat
 
compareTo(CommonAggregateStats) - Method in class org.apache.storm.generated.CommonAggregateStats
 
compareTo(ComponentAggregateStats) - Method in class org.apache.storm.generated.ComponentAggregateStats
 
compareTo(ComponentCommon) - Method in class org.apache.storm.generated.ComponentCommon
 
compareTo(ComponentObject) - Method in class org.apache.storm.generated.ComponentObject
 
compareTo(ComponentPageInfo) - Method in class org.apache.storm.generated.ComponentPageInfo
 
compareTo(Credentials) - Method in class org.apache.storm.generated.Credentials
 
compareTo(DebugOptions) - Method in class org.apache.storm.generated.DebugOptions
 
compareTo(DistributedRPC.execute_args) - Method in class org.apache.storm.generated.DistributedRPC.execute_args
 
compareTo(DistributedRPC.execute_result) - Method in class org.apache.storm.generated.DistributedRPC.execute_result
 
compareTo(DistributedRPCInvocations.failRequest_args) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_args
 
compareTo(DistributedRPCInvocations.failRequest_result) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequest_result
 
compareTo(DistributedRPCInvocations.failRequestV2_args) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_args
 
compareTo(DistributedRPCInvocations.failRequestV2_result) - Method in class org.apache.storm.generated.DistributedRPCInvocations.failRequestV2_result
 
compareTo(DistributedRPCInvocations.fetchRequest_args) - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_args
 
compareTo(DistributedRPCInvocations.fetchRequest_result) - Method in class org.apache.storm.generated.DistributedRPCInvocations.fetchRequest_result
 
compareTo(DistributedRPCInvocations.result_args) - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_args
 
compareTo(DistributedRPCInvocations.result_result) - Method in class org.apache.storm.generated.DistributedRPCInvocations.result_result
 
compareTo(DRPCExecutionException) - Method in exception org.apache.storm.generated.DRPCExecutionException
 
compareTo(DRPCRequest) - Method in class org.apache.storm.generated.DRPCRequest
 
compareTo(ErrorInfo) - Method in class org.apache.storm.generated.ErrorInfo
 
compareTo(ExecutorAggregateStats) - Method in class org.apache.storm.generated.ExecutorAggregateStats
 
compareTo(ExecutorInfo) - Method in class org.apache.storm.generated.ExecutorInfo
 
compareTo(ExecutorSpecificStats) - Method in class org.apache.storm.generated.ExecutorSpecificStats
 
compareTo(ExecutorStats) - Method in class org.apache.storm.generated.ExecutorStats
 
compareTo(ExecutorSummary) - Method in class org.apache.storm.generated.ExecutorSummary
 
compareTo(GetInfoOptions) - Method in class org.apache.storm.generated.GetInfoOptions
 
compareTo(GlobalStreamId) - Method in class org.apache.storm.generated.GlobalStreamId
 
compareTo(Grouping) - Method in class org.apache.storm.generated.Grouping
 
compareTo(HBAuthorizationException) - Method in exception org.apache.storm.generated.HBAuthorizationException
 
compareTo(HBExecutionException) - Method in exception org.apache.storm.generated.HBExecutionException
 
compareTo(HBMessage) - Method in class org.apache.storm.generated.HBMessage
 
compareTo(HBMessageData) - Method in class org.apache.storm.generated.HBMessageData
 
compareTo(HBNodes) - Method in class org.apache.storm.generated.HBNodes
 
compareTo(HBPulse) - Method in class org.apache.storm.generated.HBPulse
 
compareTo(HBRecords) - Method in class org.apache.storm.generated.HBRecords
 
compareTo(IllegalStateException) - Method in exception org.apache.storm.generated.IllegalStateException
 
compareTo(InvalidTopologyException) - Method in exception org.apache.storm.generated.InvalidTopologyException
 
compareTo(JavaObject) - Method in class org.apache.storm.generated.JavaObject
 
compareTo(JavaObjectArg) - Method in class org.apache.storm.generated.JavaObjectArg
 
compareTo(KeyAlreadyExistsException) - Method in exception org.apache.storm.generated.KeyAlreadyExistsException
 
compareTo(KeyNotFoundException) - Method in exception org.apache.storm.generated.KeyNotFoundException
 
compareTo(KillOptions) - Method in class org.apache.storm.generated.KillOptions
 
compareTo(ListBlobsResult) - Method in class org.apache.storm.generated.ListBlobsResult
 
compareTo(LocalAssignment) - Method in class org.apache.storm.generated.LocalAssignment
 
compareTo(LocalStateData) - Method in class org.apache.storm.generated.LocalStateData
 
compareTo(LogConfig) - Method in class org.apache.storm.generated.LogConfig
 
compareTo(LogLevel) - Method in class org.apache.storm.generated.LogLevel
 
compareTo(LSApprovedWorkers) - Method in class org.apache.storm.generated.LSApprovedWorkers
 
compareTo(LSSupervisorAssignments) - Method in class org.apache.storm.generated.LSSupervisorAssignments
 
compareTo(LSSupervisorId) - Method in class org.apache.storm.generated.LSSupervisorId
 
compareTo(LSTopoHistory) - Method in class org.apache.storm.generated.LSTopoHistory
 
compareTo(LSTopoHistoryList) - Method in class org.apache.storm.generated.LSTopoHistoryList
 
compareTo(LSWorkerHeartbeat) - Method in class org.apache.storm.generated.LSWorkerHeartbeat
 
compareTo(Nimbus.activate_args) - Method in class org.apache.storm.generated.Nimbus.activate_args
 
compareTo(Nimbus.activate_result) - Method in class org.apache.storm.generated.Nimbus.activate_result
 
compareTo(Nimbus.beginBlobDownload_args) - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_args
 
compareTo(Nimbus.beginBlobDownload_result) - Method in class org.apache.storm.generated.Nimbus.beginBlobDownload_result
 
compareTo(Nimbus.beginCreateBlob_args) - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_args
 
compareTo(Nimbus.beginCreateBlob_result) - Method in class org.apache.storm.generated.Nimbus.beginCreateBlob_result
 
compareTo(Nimbus.beginFileUpload_args) - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_args
 
compareTo(Nimbus.beginFileUpload_result) - Method in class org.apache.storm.generated.Nimbus.beginFileUpload_result
 
compareTo(Nimbus.beginUpdateBlob_args) - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_args
 
compareTo(Nimbus.beginUpdateBlob_result) - Method in class org.apache.storm.generated.Nimbus.beginUpdateBlob_result
 
compareTo(Nimbus.cancelBlobUpload_args) - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_args
 
compareTo(Nimbus.cancelBlobUpload_result) - Method in class org.apache.storm.generated.Nimbus.cancelBlobUpload_result
 
compareTo(Nimbus.createStateInZookeeper_args) - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_args
 
compareTo(Nimbus.createStateInZookeeper_result) - Method in class org.apache.storm.generated.Nimbus.createStateInZookeeper_result
 
compareTo(Nimbus.deactivate_args) - Method in class org.apache.storm.generated.Nimbus.deactivate_args
 
compareTo(Nimbus.deactivate_result) - Method in class org.apache.storm.generated.Nimbus.deactivate_result
 
compareTo(Nimbus.debug_args) - Method in class org.apache.storm.generated.Nimbus.debug_args
 
compareTo(Nimbus.debug_result) - Method in class org.apache.storm.generated.Nimbus.debug_result
 
compareTo(Nimbus.deleteBlob_args) - Method in class org.apache.storm.generated.Nimbus.deleteBlob_args
 
compareTo(Nimbus.deleteBlob_result) - Method in class org.apache.storm.generated.Nimbus.deleteBlob_result
 
compareTo(Nimbus.downloadBlobChunk_args) - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_args
 
compareTo(Nimbus.downloadBlobChunk_result) - Method in class org.apache.storm.generated.Nimbus.downloadBlobChunk_result
 
compareTo(Nimbus.downloadChunk_args) - Method in class org.apache.storm.generated.Nimbus.downloadChunk_args
 
compareTo(Nimbus.downloadChunk_result) - Method in class org.apache.storm.generated.Nimbus.downloadChunk_result
 
compareTo(Nimbus.finishBlobUpload_args) - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_args
 
compareTo(Nimbus.finishBlobUpload_result) - Method in class org.apache.storm.generated.Nimbus.finishBlobUpload_result
 
compareTo(Nimbus.finishFileUpload_args) - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_args
 
compareTo(Nimbus.finishFileUpload_result) - Method in class org.apache.storm.generated.Nimbus.finishFileUpload_result
 
compareTo(Nimbus.getBlobMeta_args) - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_args
 
compareTo(Nimbus.getBlobMeta_result) - Method in class org.apache.storm.generated.Nimbus.getBlobMeta_result
 
compareTo(Nimbus.getBlobReplication_args) - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_args
 
compareTo(Nimbus.getBlobReplication_result) - Method in class org.apache.storm.generated.Nimbus.getBlobReplication_result
 
compareTo(Nimbus.getClusterInfo_args) - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_args
 
compareTo(Nimbus.getClusterInfo_result) - Method in class org.apache.storm.generated.Nimbus.getClusterInfo_result
 
compareTo(Nimbus.getComponentPageInfo_args) - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_args
 
compareTo(Nimbus.getComponentPageInfo_result) - Method in class org.apache.storm.generated.Nimbus.getComponentPageInfo_result
 
compareTo(Nimbus.getComponentPendingProfileActions_args) - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_args
 
compareTo(Nimbus.getComponentPendingProfileActions_result) - Method in class org.apache.storm.generated.Nimbus.getComponentPendingProfileActions_result
 
compareTo(Nimbus.getLeader_args) - Method in class org.apache.storm.generated.Nimbus.getLeader_args
 
compareTo(Nimbus.getLeader_result) - Method in class org.apache.storm.generated.Nimbus.getLeader_result
 
compareTo(Nimbus.getLogConfig_args) - Method in class org.apache.storm.generated.Nimbus.getLogConfig_args
 
compareTo(Nimbus.getLogConfig_result) - Method in class org.apache.storm.generated.Nimbus.getLogConfig_result
 
compareTo(Nimbus.getNimbusConf_args) - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_args
 
compareTo(Nimbus.getNimbusConf_result) - Method in class org.apache.storm.generated.Nimbus.getNimbusConf_result
 
compareTo(Nimbus.getOwnerResourceSummaries_args) - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_args
 
compareTo(Nimbus.getOwnerResourceSummaries_result) - Method in class org.apache.storm.generated.Nimbus.getOwnerResourceSummaries_result
 
compareTo(Nimbus.getSupervisorAssignments_args) - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_args
 
compareTo(Nimbus.getSupervisorAssignments_result) - Method in class org.apache.storm.generated.Nimbus.getSupervisorAssignments_result
 
compareTo(Nimbus.getSupervisorPageInfo_args) - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_args
 
compareTo(Nimbus.getSupervisorPageInfo_result) - Method in class org.apache.storm.generated.Nimbus.getSupervisorPageInfo_result
 
compareTo(Nimbus.getTopology_args) - Method in class org.apache.storm.generated.Nimbus.getTopology_args
 
compareTo(Nimbus.getTopology_result) - Method in class org.apache.storm.generated.Nimbus.getTopology_result
 
compareTo(Nimbus.getTopologyConf_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_args
 
compareTo(Nimbus.getTopologyConf_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyConf_result
 
compareTo(Nimbus.getTopologyHistory_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_args
 
compareTo(Nimbus.getTopologyHistory_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyHistory_result
 
compareTo(Nimbus.getTopologyInfo_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_args
 
compareTo(Nimbus.getTopologyInfo_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfo_result
 
compareTo(Nimbus.getTopologyInfoWithOpts_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_args
 
compareTo(Nimbus.getTopologyInfoWithOpts_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyInfoWithOpts_result
 
compareTo(Nimbus.getTopologyPageInfo_args) - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_args
 
compareTo(Nimbus.getTopologyPageInfo_result) - Method in class org.apache.storm.generated.Nimbus.getTopologyPageInfo_result
 
compareTo(Nimbus.getUserTopology_args) - Method in class org.apache.storm.generated.Nimbus.getUserTopology_args
 
compareTo(Nimbus.getUserTopology_result) - Method in class org.apache.storm.generated.Nimbus.getUserTopology_result
 
compareTo(Nimbus.isRemoteBlobExists_args) - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_args
 
compareTo(Nimbus.isRemoteBlobExists_result) - Method in class org.apache.storm.generated.Nimbus.isRemoteBlobExists_result
 
compareTo(Nimbus.isTopologyNameAllowed_args) - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_args
 
compareTo(Nimbus.isTopologyNameAllowed_result) - Method in class org.apache.storm.generated.Nimbus.isTopologyNameAllowed_result
 
compareTo(Nimbus.killTopology_args) - Method in class org.apache.storm.generated.Nimbus.killTopology_args
 
compareTo(Nimbus.killTopology_result) - Method in class org.apache.storm.generated.Nimbus.killTopology_result
 
compareTo(Nimbus.killTopologyWithOpts_args) - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_args
 
compareTo(Nimbus.killTopologyWithOpts_result) - Method in class org.apache.storm.generated.Nimbus.killTopologyWithOpts_result
 
compareTo(Nimbus.listBlobs_args) - Method in class org.apache.storm.generated.Nimbus.listBlobs_args
 
compareTo(Nimbus.listBlobs_result) - Method in class org.apache.storm.generated.Nimbus.listBlobs_result
 
compareTo(Nimbus.processWorkerMetrics_args) - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_args
 
compareTo(Nimbus.processWorkerMetrics_result) - Method in class org.apache.storm.generated.Nimbus.processWorkerMetrics_result
 
compareTo(Nimbus.rebalance_args) - Method in class org.apache.storm.generated.Nimbus.rebalance_args
 
compareTo(Nimbus.rebalance_result) - Method in class org.apache.storm.generated.Nimbus.rebalance_result
 
compareTo(Nimbus.sendSupervisorWorkerHeartbeat_args) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_args
 
compareTo(Nimbus.sendSupervisorWorkerHeartbeat_result) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeat_result
 
compareTo(Nimbus.sendSupervisorWorkerHeartbeats_args) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_args
 
compareTo(Nimbus.sendSupervisorWorkerHeartbeats_result) - Method in class org.apache.storm.generated.Nimbus.sendSupervisorWorkerHeartbeats_result
 
compareTo(Nimbus.setBlobMeta_args) - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_args
 
compareTo(Nimbus.setBlobMeta_result) - Method in class org.apache.storm.generated.Nimbus.setBlobMeta_result
 
compareTo(Nimbus.setLogConfig_args) - Method in class org.apache.storm.generated.Nimbus.setLogConfig_args
 
compareTo(Nimbus.setLogConfig_result) - Method in class org.apache.storm.generated.Nimbus.setLogConfig_result
 
compareTo(Nimbus.setWorkerProfiler_args) - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_args
 
compareTo(Nimbus.setWorkerProfiler_result) - Method in class org.apache.storm.generated.Nimbus.setWorkerProfiler_result
 
compareTo(Nimbus.submitTopology_args) - Method in class org.apache.storm.generated.Nimbus.submitTopology_args
 
compareTo(Nimbus.submitTopology_result) - Method in class org.apache.storm.generated.Nimbus.submitTopology_result
 
compareTo(Nimbus.submitTopologyWithOpts_args) - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_args
 
compareTo(Nimbus.submitTopologyWithOpts_result) - Method in class org.apache.storm.generated.Nimbus.submitTopologyWithOpts_result
 
compareTo(Nimbus.updateBlobReplication_args) - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_args
 
compareTo(Nimbus.updateBlobReplication_result) - Method in class org.apache.storm.generated.Nimbus.updateBlobReplication_result
 
compareTo(Nimbus.uploadBlobChunk_args) - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_args
 
compareTo(Nimbus.uploadBlobChunk_result) - Method in class org.apache.storm.generated.Nimbus.uploadBlobChunk_result
 
compareTo(Nimbus.uploadChunk_args) - Method in class org.apache.storm.generated.Nimbus.uploadChunk_args
 
compareTo(Nimbus.uploadChunk_result) - Method in class org.apache.storm.generated.Nimbus.uploadChunk_result
 
compareTo(Nimbus.uploadNewCredentials_args) - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_args
 
compareTo(Nimbus.uploadNewCredentials_result) - Method in class org.apache.storm.generated.Nimbus.uploadNewCredentials_result
 
compareTo(NimbusSummary) - Method in class org.apache.storm.generated.NimbusSummary
 
compareTo(NodeInfo) - Method in class org.apache.storm.generated.NodeInfo
 
compareTo(NotAliveException) - Method in exception org.apache.storm.generated.NotAliveException
 
compareTo(NullStruct) - Method in class org.apache.storm.generated.NullStruct
 
compareTo(OwnerResourceSummary) - Method in class org.apache.storm.generated.OwnerResourceSummary
 
compareTo(PrivateWorkerKey) - Method in class org.apache.storm.generated.PrivateWorkerKey
 
compareTo(ProfileRequest) - Method in class org.apache.storm.generated.ProfileRequest
 
compareTo(ReadableBlobMeta) - Method in class org.apache.storm.generated.ReadableBlobMeta
 
compareTo(RebalanceOptions) - Method in class org.apache.storm.generated.RebalanceOptions
 
compareTo(SettableBlobMeta) - Method in class org.apache.storm.generated.SettableBlobMeta
 
compareTo(SharedMemory) - Method in class org.apache.storm.generated.SharedMemory
 
compareTo(ShellComponent) - Method in class org.apache.storm.generated.ShellComponent
 
compareTo(SpecificAggregateStats) - Method in class org.apache.storm.generated.SpecificAggregateStats
 
compareTo(SpoutAggregateStats) - Method in class org.apache.storm.generated.SpoutAggregateStats
 
compareTo(SpoutSpec) - Method in class org.apache.storm.generated.SpoutSpec
 
compareTo(SpoutStats) - Method in class org.apache.storm.generated.SpoutStats
 
compareTo(StateSpoutSpec) - Method in class org.apache.storm.generated.StateSpoutSpec
 
compareTo(StormBase) - Method in class org.apache.storm.generated.StormBase
 
compareTo(StormTopology) - Method in class org.apache.storm.generated.StormTopology
 
compareTo(StreamInfo) - Method in class org.apache.storm.generated.StreamInfo
 
compareTo(SubmitOptions) - Method in class org.apache.storm.generated.SubmitOptions
 
compareTo(Supervisor.getLocalAssignmentForStorm_args) - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_args
 
compareTo(Supervisor.getLocalAssignmentForStorm_result) - Method in class org.apache.storm.generated.Supervisor.getLocalAssignmentForStorm_result
 
compareTo(Supervisor.sendSupervisorAssignments_args) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_args
 
compareTo(Supervisor.sendSupervisorAssignments_result) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorAssignments_result
 
compareTo(Supervisor.sendSupervisorWorkerHeartbeat_args) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_args
 
compareTo(Supervisor.sendSupervisorWorkerHeartbeat_result) - Method in class org.apache.storm.generated.Supervisor.sendSupervisorWorkerHeartbeat_result
 
compareTo(SupervisorAssignments) - Method in class org.apache.storm.generated.SupervisorAssignments
 
compareTo(SupervisorInfo) - Method in class org.apache.storm.generated.SupervisorInfo
 
compareTo(SupervisorPageInfo) - Method in class org.apache.storm.generated.SupervisorPageInfo
 
compareTo(SupervisorSummary) - Method in class org.apache.storm.generated.SupervisorSummary
 
compareTo(SupervisorWorkerHeartbeat) - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeat
 
compareTo(SupervisorWorkerHeartbeats) - Method in class org.apache.storm.generated.SupervisorWorkerHeartbeats
 
compareTo(ThriftSerializedObject) - Method in class org.apache.storm.generated.ThriftSerializedObject
 
compareTo(TopologyActionOptions) - Method in class org.apache.storm.generated.TopologyActionOptions
 
compareTo(TopologyHistoryInfo) - Method in class org.apache.storm.generated.TopologyHistoryInfo
 
compareTo(TopologyInfo) - Method in class org.apache.storm.generated.TopologyInfo
 
compareTo(TopologyPageInfo) - Method in class org.apache.storm.generated.TopologyPageInfo
 
compareTo(TopologyStats) - Method in class org.apache.storm.generated.TopologyStats
 
compareTo(TopologySummary) - Method in class org.apache.storm.generated.TopologySummary
 
compareTo(WorkerMetricList) - Method in class org.apache.storm.generated.WorkerMetricList
 
compareTo(WorkerMetricPoint) - Method in class org.apache.storm.generated.WorkerMetricPoint
 
compareTo(WorkerMetrics) - Method in class org.apache.storm.generated.WorkerMetrics
 
compareTo(WorkerResources) - Method in class org.apache.storm.generated.WorkerResources
 
compareTo(WorkerSummary) - Method in class org.apache.storm.generated.WorkerSummary
 
compareTo(WorkerToken) - Method in class org.apache.storm.generated.WorkerToken
 
compareTo(WorkerTokenInfo) - Method in class org.apache.storm.generated.WorkerTokenInfo
 
compareTo(FileOffset) - Method in class org.apache.storm.hdfs.spout.SequenceFileReader.Offset
 
compareTo(FileOffset) - Method in class org.apache.storm.hdfs.spout.TextFileReader.Offset
 
compareTo(JmsMessageID) - Method in class org.apache.storm.jms.spout.JmsMessageID
 
compareTo(Metric) - Method in class org.apache.storm.metricstore.Metric
 
compareTo(RocksDbKey) - Method in class org.apache.storm.metricstore.rocksdb.RocksDbKey
compares to keys on a byte by byte basis.
compareTo(RasNode) - Method in class org.apache.storm.scheduler.resource.RasNode
 
compareTo(TimeData) - Method in class org.apache.storm.st.topology.window.data.TimeData
 
compareTo(Rankable) - Method in class org.apache.storm.starter.tools.RankableObjectWithFields
 
compareTo(Object) - Method in class org.apache.storm.trident.util.IndexedEdge
 
compareTo(SimpleVersion) - Method in class org.apache.storm.utils.SimpleVersion
 
ComparisonAggregator<T> - Class in org.apache.storm.trident.operation.builtin
Abstract Aggregator for comparing two values in a stream.
ComparisonAggregator(String) - Constructor for class org.apache.storm.trident.operation.builtin.ComparisonAggregator
 
ComparisonAggregator.State - Class in org.apache.storm.trident.operation.builtin
 
compile(List<RexNode>, RelDataType, String) - Method in class org.apache.storm.sql.compiler.RexNodeToJavaCodeCompiler
 
compile(RexProgram, String) - Method in class org.apache.storm.sql.compiler.RexNodeToJavaCodeCompiler
 
compile(Map<String, ISqlStreamsDataSource>, String) - Method in class org.apache.storm.sql.planner.streams.QueryPlanner
 
CompilerUtil - Class in org.apache.storm.sql.compiler
 
CompilerUtil() - Constructor for class org.apache.storm.sql.compiler.CompilerUtil
 
CompilerUtil.TableBuilderInfo - Class in org.apache.storm.sql.compiler
 
compileSql(String) - Method in class org.apache.storm.sql.StormSqlContext
 
compileToBlock(List<RexNode>, RelDataType) - Method in class org.apache.storm.sql.compiler.RexNodeToJavaCodeCompiler