| Name | Description | Type | Package | Framework |
| AbstractHBaseBolt | | Class | org.apache.storm.hbase.bolt | Apache Storm |
|
| AbstractHdfsBolt | | Class | org.apache.storm.hdfs.bolt | Apache Storm |
|
| AbstractJdbcBolt | | Class | org.apache.storm.jdbc.bolt | Apache Storm |
|
| AbstractRankerBolt | This abstract bolt provides the basic behavior of bolts that rank objects according to their count. | Class | storm.starter.bolt | Apache Storm |
|
| AbstractRedisBolt | | Class | org.apache.storm.redis.bolt | Apache Storm |
|
| AckFailDelegate | | Interface | backtype.storm.testing | Apache Storm |
|
| AckFailMapTracker | | Class | backtype.storm.testing | Apache Storm |
|
| AckTracker | | Class | backtype.storm.testing | Apache Storm |
|
| AggregateProcessor | | Class | storm.trident.planner.processor | Apache Storm |
|
| Aggregator | | Interface | storm.trident.operation | Apache Storm |
|
| AlreadyAliveException | | Class | backtype.storm.generated | Apache Storm |
|
| AppendCollector | | Class | storm.trident.planner.processor | Apache Storm |
|
| ArrayListSerializer | | Class | backtype.storm.serialization.types | Apache Storm |
|
| AssignableMetric | | Class | backtype.storm.metric.api | Apache Storm |
|
| AssignableShellMetric | | Class | backtype.storm.metric.api.rpc | Apache Storm |
|
| AuthorizationException | | Class | backtype.storm.generated | Apache Storm |
|
| AuthUtils | | Class | backtype.storm.security.auth | Apache Storm |
|
| AutoHBase | Automatically get hbase delegation tokens and push it to user's topology. | Class | org.apache.storm.hbase.security | Apache Storm |
|
| AutoHDFS | Automatically get HDFS delegation tokens and push it to user's topology. | Class | org.apache.storm.hdfs.common.security | Apache Storm |
|
| AutoTGT | Automatically take a user's TGT, and push it, and renew it in Nimbus. | Class | backtype.storm.security.auth.kerberos | Apache Storm |
|
| AutoTGTKrb5LoginModule | | Class | backtype.storm.security.auth.kerberos | Apache Storm |
|
| AutoTGTKrb5LoginModuleTest | Custom LoginModule extended for testing. | Class | backtype.storm.security.auth.kerberos | Apache Storm |
|
| BaseAggregator | | Class | storm.trident.operation | Apache Storm |
|
| BaseBasicBolt | | Class | backtype.storm.topology.base | Apache Storm |
|
| BaseBatchBolt | | Class | backtype.storm.topology.base | Apache Storm |
|
| BaseComponent | | Class | backtype.storm.topology.base | Apache Storm |
|
| BaseConfigurationDeclarer | | Class | backtype.storm.topology | Apache Storm |
|
| BaseFilter | | Class | storm.trident.operation | Apache Storm |
|
| BaseFunction | | Class | storm.trident.operation | Apache Storm |
|
| BaseMultiReducer | | Class | storm.trident.operation | Apache Storm |
|
| BaseOpaquePartitionedTransactionalSpout | | Class | backtype.storm.topology.base | Apache Storm |
|
| BaseOperation | | Class | storm.trident.operation | Apache Storm |
|
| BasePartitionedTransactionalSpout | | Class | backtype.storm.topology.base | Apache Storm |
|
| BaseQueryFunction | | Class | storm.trident.state | Apache Storm |
|
| BaseRichBolt | | Class | backtype.storm.topology.base | Apache Storm |
|
| BaseRichSpout | | Class | backtype.storm.topology.base | Apache Storm |
|
| BaseStateUpdater | | Class | storm.trident.state | Apache Storm |
|
| BaseTaskHook | | Class | backtype.storm.hooks | Apache Storm |
|
| BaseTransactionalBolt | | Class | backtype.storm.topology.base | Apache Storm |
|
| BaseTransactionalSpout | | Class | backtype.storm.topology.base | Apache Storm |
|
| BasicBoltExecutor | | Class | backtype.storm.topology | Apache Storm |
|
| BasicDRPCTopology | This topology is a basic example of doing distributed RPC on top of Storm. | Class | storm.starter | Apache Storm |
|
| BasicOutputCollector | | Class | backtype.storm.topology | Apache Storm |
|
| BatchBoltExecutor | | Class | backtype.storm.coordination | Apache Storm |
|
| BatchInfo | | Class | storm.trident.topology | Apache Storm |
|
| BatchNumberList | | Class | backtype.storm.testing | Apache Storm |
|
| BatchOutputCollector | | Class | backtype.storm.coordination | Apache Storm |
|
| BatchOutputCollectorImpl | | Class | backtype.storm.coordination | Apache Storm |
|
| BatchProcessWord | | Class | backtype.storm.testing | Apache Storm |
|
| BatchRepeatA | | Class | backtype.storm.testing | Apache Storm |
|
| BatchSpoutExecutor | | Class | storm.trident.spout | Apache Storm |
|
| BatchSubtopologyBuilder | | Class | backtype.storm.coordination | Apache Storm |
|
| BlowfishTupleSerializer | | Class | backtype.storm.security.serialization | Apache Storm |
|
| Bolt | | Class | backtype.storm.generated | Apache Storm |
|
| BoltAckInfo | | Class | backtype.storm.hooks.info | Apache Storm |
|
| BoltDeclarer | BoltDeclarer includes grouping APIs for storm topology. | Interface | backtype.storm.topology | Apache Storm |
|
| BoltExecuteInfo | | Class | backtype.storm.hooks.info | Apache Storm |
|
| BoltFailInfo | | Class | backtype.storm.hooks.info | Apache Storm |
|
| BoltMsg | BoltMsg is an object that represents the data sent from a shell component to a bolt process that implements a multi-language protocol. | Class | backtype.storm.multilang | Apache Storm |
|
| BoltStats | | Class | backtype.storm.generated | Apache Storm |
|
| BoltTracker | | Class | backtype.storm.testing | Apache Storm |
|
| BridgeReceiver | | Class | storm.trident.planner | Apache Storm |
|
| Broker | | Class | storm.kafka | Apache Storm |
|
| BufferFileInputStream | | Class | backtype.storm.utils | Apache Storm |
|
| CachedBatchReadsMap | | Class | storm.trident.state.map | Apache Storm |
|
| CachedMap | Useful to layer over a map that communicates with a database. | Class | storm.trident.state.map | Apache Storm |
|
| CaptureCollector | | Class | storm.trident.operation.impl | Apache Storm |
|
| ChainedAggregatorDeclarer | | Class | storm.trident.fluent | Apache Storm |
|
| ChainedAggregatorImpl | | Class | storm.trident.operation.impl | Apache Storm |
|
| ChainedFullAggregatorDeclarer | | Interface | storm.trident.fluent | Apache Storm |
|
| ChainedPartitionAggregatorDeclarer | | Interface | storm.trident.fluent | Apache Storm |
|
| ChainedResult | | Class | storm.trident.operation.impl | Apache Storm |
|
| Client | A Netty client for sending task messages to a remote destination (Netty server). | Class | backtype.storm.messaging.netty | Apache Storm |
|
| ClientCallbackHandler | client side callback handler. | Class | backtype.storm.security.auth.digest | Apache Storm |
|
| ClientCallbackHandler | SASL client side callback handler. | Class | backtype.storm.security.auth.kerberos | Apache Storm |
|
| ClojureBolt | | Class | backtype.storm.clojure | Apache Storm |
|
| ClojureSpout | | Class | backtype.storm.clojure | Apache Storm |
|
| ClojureTimerTask | | Class | backtype.storm.utils | Apache Storm |
|
| ClojureTransformer | | Class | org.apache.storm.maven.shade.clojure | Apache Storm |
|
| Cluster | | Class | backtype.storm.scheduler | Apache Storm |
|
| ClusterSummary | | Class | backtype.storm.generated | Apache Storm |
|
| Column | 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. | Class | org.apache.storm.jdbc.common | Apache Storm |
|
| ColumnList | Represents a list of HBase columns. | Class | org.apache.storm.hbase.common | Apache Storm |
|
| CombinedMetric | | Class | backtype.storm.metric.api | Apache Storm |
|
| CombinedShellMetric | | Class | backtype.storm.metric.api.rpc | Apache Storm |
|
| CombinerAggregator | | Interface | storm.trident.operation | Apache Storm |
|
| CombinerAggregatorCombineImpl | | Class | storm.trident.operation.impl | Apache Storm |
|
| CombinerAggregatorInitImpl | | Class | storm.trident.operation.impl | Apache Storm |
|
| CombinerAggStateUpdater | | Class | storm.trident.operation.impl | Apache Storm |
|
| CombinerValueUpdater | | Class | storm.trident.state | Apache Storm |
|
| ComboList | | Class | storm.trident.tuple | Apache Storm |
|
| CommandExec | | Class | org.apache.storm.maven.plugin.util | Apache Storm |
|
| CompleteTopologyParam | The param class for the Testing. | Class | backtype.storm.testing | Apache Storm |
|
| ComponentCommon | | Class | backtype.storm.generated | Apache Storm |
|
| ComponentConfigurationDeclarer | | Interface | backtype.storm.topology | Apache Storm |
|
| ComponentObject | | Class | backtype.storm.generated | Apache Storm |
|
| CompoundSpout | | Class | backtype.storm.planner | Apache Storm |
|
| CompoundTask | | Class | backtype.storm.planner | Apache Storm |
|
| Config | Topology configs are specified as a plain old map. | Class | backtype.storm | Apache Storm |
|
| ConfigValidation | Provides functionality for validating configuration fields. | Class | backtype.storm | Apache Storm |
|
| ConnectionWithStatus | | Class | backtype.storm.messaging | Apache Storm |
|
| ConsList | | Class | storm.trident.tuple | Apache Storm |
|
| Constants | | Class | backtype.storm | Apache Storm |
|
| Container | | Class | backtype.storm.utils | Apache Storm |
|
| Context | | Class | backtype.storm.messaging.netty | Apache Storm |
|
| CoordinatedBolt | Coordination requires the request ids to be globally unique for awhile. | Class | backtype.storm.coordination | Apache Storm |
|
| Count | | Class | storm.trident.operation.builtin | Apache Storm |
|
| CountAsAggregator | | Class | storm.trident.testing | Apache Storm |
|
| CountingBatchBolt | | Class | backtype.storm.testing | Apache Storm |
|
| CountingCommitBolt | | Class | backtype.storm.testing | Apache Storm |
|
| CountMetric | | Class | backtype.storm.metric.api | Apache Storm |
|
| CountShellMetric | | Class | backtype.storm.metric.api.rpc | Apache Storm |
|
| CountSyncPolicy | SyncPolicy implementation that will trigger a file system sync after a certain number of tuples | Class | org.apache.storm.hdfs.bolt.sync | Apache Storm |
|
| CountSyncPolicy | SyncPolicy implementation that will trigger a file system sync after a certain number of tuples | Class | org.apache.storm.hdfs.trident.sync | Apache Storm |
|
| CRC32OutputStream | | Class | backtype.storm.utils | Apache Storm |
|
| Credentials | | Class | backtype.storm.generated | Apache Storm |
|
| CustomStreamGrouping | | Interface | backtype.storm.grouping | Apache Storm |
|
| Debug | | Class | storm.trident.operation.builtin | Apache Storm |
|
| DefaultCoordinator | | Class | storm.kafka.trident | Apache Storm |
|
| DefaultFileNameFormat | Creates file names with the following format: {prefix}{componentId}-{taskId}-{rotationNum}-{timestamp}{extension} | Class | org.apache.storm.hdfs.bolt.format | Apache Storm |
|
| DefaultFileNameFormat | Creates file names with the following format: {prefix}-{partitionId}-{rotationNum}-{timestamp}{extension} | Class | org.apache.storm.hdfs.trident.format | Apache Storm |
|
| DefaultHttpCredentialsPlugin | | Class | backtype.storm.security.auth | Apache Storm |
|
| DefaultKryoFactory | | Class | backtype.storm.serialization | Apache Storm |
|
| DefaultPool | | Class | backtype.storm.scheduler.multitenant | Apache Storm |
|
| DefaultPrincipalToLocal | Storm can be configured to launch worker processed as a given user. | Class | backtype.storm.security.auth | Apache Storm |
|
| DefaultSequenceFormat | Basic SequenceFormat implementation that uses LongWritable for keys and Text for values. | Class | org.apache.storm.hdfs.bolt.format | Apache Storm |
|
| DefaultSequenceFormat | Basic SequenceFormat implementation that uses LongWritable for keys and Text for values. | Class | org.apache.storm.hdfs.trident.format | Apache Storm |
|
| DefaultSerializationDelegate | | Class | backtype.storm.serialization | Apache Storm |
|
| DefaultTopicSelector | | Class | storm.kafka.bolt.selector | Apache Storm |
|
| DefaultTopicSelector | | Class | storm.kafka.trident.selector | Apache Storm |
|
| DefaultTopologyValidator | | Class | backtype.storm.nimbus | Apache Storm |
|
| DelimitedRecordFormat | RecordFormat implementation that uses field and record delimiters. | Class | org.apache.storm.hdfs.bolt.format | Apache Storm |
|
| DelimitedRecordFormat | RecordFormat implementation that uses field and record delimiters. | Class | org.apache.storm.hdfs.trident.format | Apache Storm |
|
| DelimitedRecordHiveMapper | | Class | org.apache.storm.hive.bolt.mapper | Apache Storm |
|
| DenyAuthorizer | | Class | backtype.storm.security.auth.authorizer | Apache Storm |
|
| DigestSaslTransportPlugin | | Class | backtype.storm.security.auth.digest | Apache Storm |
|
| DisruptorQueue | A single consumer queue that uses the LMAX Disruptor. | Class | backtype.storm.utils | Apache Storm |
|
| DistributedRPC | | Class | backtype.storm.generated | Apache Storm |
|
| DistributedRPCInvocations | | Class | backtype.storm.generated | Apache Storm |
|
| DRPCAuthorizerBase | | Class | backtype.storm.security.auth.authorizer | Apache Storm |
|
| DRPCClient | | Class | backtype.storm.utils | Apache Storm |
|
| DRPCExecutionException | | Class | backtype.storm.generated | Apache Storm |
|
| DRPCInvocationsClient | | Class | backtype.storm.drpc | Apache Storm |
|
| DRPCRequest | | Class | backtype.storm.generated | Apache Storm |
|
| DRPCSimpleACLAuthorizer | | Class | backtype.storm.security.auth.authorizer | Apache Storm |
|
| DRPCSpout | | Class | backtype.storm.drpc | Apache Storm |
|
| DynamicBrokersReader | | Class | storm.kafka | Apache Storm |
|
| DynamicPartitionConnections | | Class | storm.kafka | Apache Storm |
|
| EachProcessor | | Class | storm.trident.planner.processor | Apache Storm |
|
| EmitInfo | | Class | backtype.storm.hooks.info | Apache Storm |
|
| Equals | | Class | storm.trident.operation.builtin | Apache Storm |
|
| ErrorEdgeFactory | | Class | storm.trident.util | Apache Storm |
|
| ErrorInfo | | Class | backtype.storm.generated | Apache Storm |
|
| ExclamationTopology | This is a basic example of a Storm topology. | Class | storm.starter | Apache Storm |
|
| ExecutorDetails | | Class | backtype.storm.scheduler | Apache Storm |
|
| ExecutorInfo | | Class | backtype.storm.generated | Apache Storm |
|
| ExecutorSpecificStats | | Class | backtype.storm.generated | Apache Storm |
|
| ExecutorStats | | Class | backtype.storm.generated | Apache Storm |
|
| ExecutorSummary | | Class | backtype.storm.generated | Apache Storm |
|
| ExponentialBackoffMsgRetryManager | | Class | storm.kafka | Apache Storm |
|
| FailedException | | Class | backtype.storm.topology | Apache Storm |
|
| FailedFetchException | | Class | storm.kafka | Apache Storm |
|
| FailedMsgRetryManager | | Interface | storm.kafka | Apache Storm |
|
| FeederBatchSpout | | Class | storm.trident.testing | Apache Storm |
|
| FeederCommitterBatchSpout | | Class | storm.trident.testing | Apache Storm |
|
| FeederSpout | | Class | backtype.storm.testing | Apache Storm |
|
| FieldNameBasedTupleToKafkaMapper | | Class | storm.kafka.bolt.mapper | Apache Storm |
|
| FieldNameBasedTupleToKafkaMapper | | Class | storm.kafka.trident.mapper | Apache Storm |
|
| Fields | | Class | backtype.storm.tuple | Apache Storm |
|
| FileNameFormat | Formatter interface for determining HDFS file names. | Interface | org.apache.storm.hdfs.bolt.format | Apache Storm |
|
| FileNameFormat | Formatter interface for determining HDFS file names. | Interface | org.apache.storm.hdfs.trident.format | Apache Storm |
|
| FileRotationPolicy | Used by the HdfsBolt to decide when to rotate files. | Interface | org.apache.storm.hdfs.bolt.rotation | Apache Storm |
|
| FileRotationPolicy | Used by the HdfsBolt to decide when to rotate files. | Interface | org.apache.storm.hdfs.trident.rotation | Apache Storm |
|
| FileSizeRotationPolicy | File rotation policy that will rotate files when a certain file size is reached. | Class | org.apache.storm.hdfs.bolt.rotation | Apache Storm |
|
| FileSizeRotationPolicy | File rotation policy that will rotate files when a certain file size is reached. | Class | org.apache.storm.hdfs.trident.rotation | Apache Storm |
|
| Filter | | Interface | storm.trident.operation | Apache Storm |
|
| FilterExecutor | | Class | storm.trident.operation.impl | Apache Storm |
|
| FilterNull | | Class | storm.trident.operation.builtin | Apache Storm |
|
| FirstN | | Class | storm.trident.operation.builtin | Apache Storm |
|
| FixedBatchSpout | | Class | storm.trident.testing | Apache Storm |
|
| FixedTuple | | Class | backtype.storm.testing | Apache Storm |
|
| FixedTupleSpout | | Class | backtype.storm.testing | Apache Storm |
|
| ForwardingMetricsConsumer | | Class | backtype.storm.testing | Apache Storm |
|
| FreePool | | Class | backtype.storm.scheduler.multitenant | Apache Storm |
|
| FreshCollector | | Class | storm.trident.planner.processor | Apache Storm |
|
| Function | | Interface | storm.trident.operation | Apache Storm |
|
| GeneralTopologyContext | | Class | backtype.storm.task | Apache Storm |
|
| GetInfoOptions | | Class | backtype.storm.generated | Apache Storm |
|
| GlobalAggregationScheme | | Interface | storm.trident.fluent | Apache Storm |
|
| GlobalBatchToPartition | | Class | storm.trident.operation.impl | Apache Storm |
|
| GlobalGrouping | | Class | storm.trident.partition | Apache Storm |
|
| GlobalPartitionInformation | | Class | storm.kafka.trident | Apache Storm |
|
| GlobalStreamId | | Class | backtype.storm.generated | Apache Storm |
|
| GraphGrouper | | Class | storm.trident.graph | Apache Storm |
|
| Group | | Class | storm.trident.graph | Apache Storm |
|
| GroupCollector | | Class | storm.trident.operation.impl | Apache Storm |
|
| GroupedAggregator | | Class | storm.trident.operation.impl | Apache Storm |
|
| GroupedMultiReducer | | Interface | storm.trident.operation | Apache Storm |
|
| GroupedMultiReducerExecutor | | Class | storm.trident.operation.impl | Apache Storm |
|
| GroupedStream | | Class | storm.trident.fluent | Apache Storm |
|
| Grouping | | Class | backtype.storm.generated | Apache Storm |
|
| GzipBridgeSerializationDelegate | Always writes gzip out, but tests incoming to see if it's gzipped. | Class | backtype.storm.serialization | Apache Storm |
|
| GzipSerializationDelegate | Note, this assumes it's deserializing a gzip byte stream, and will err if it encounters any other serialization. | Class | backtype.storm.serialization | Apache Storm |
|
| HashMapSerializer | | Class | backtype.storm.serialization.types | Apache Storm |
|
| HashSetSerializer | | Class | backtype.storm.serialization.types | Apache Storm |
|
| HBaseBolt | Basic bolt for writing to HBase. | Class | org.apache.storm.hbase.bolt | Apache Storm |
|
| HBaseClient | | Class | org.apache.storm.hbase.common | Apache Storm |
|
| HBaseLookupBolt | Basic bolt for querying from HBase. | Class | org.apache.storm.hbase.bolt | Apache Storm |
|
| HBaseMapper | Maps a backtype. | Interface | org.apache.storm.hbase.bolt.mapper | Apache Storm |
|
| HBaseMapState | | Class | org.apache.storm.hbase.trident.state | Apache Storm |
|
| HBaseProjectionCriteria | Allows the user to specify the projection criteria. | Class | org.apache.storm.hbase.bolt.mapper | Apache Storm |
|
| HBaseQuery | | Class | org.apache.storm.hbase.trident.state | Apache Storm |
|
| HBaseSecurityUtil | This class provides util methods for storm-hbase connector communicating with secured HBase. | Class | org.apache.storm.hbase.security | Apache Storm |
|
| HBaseState | | Class | org.apache.storm.hbase.trident.state | Apache Storm |
|
| HBaseStateFactory | | Class | org.apache.storm.hbase.trident.state | Apache Storm |
|
| HBaseUpdater | | Class | org.apache.storm.hbase.trident.state | Apache Storm |
|
| HBaseValueMapper | declares the output fields for the lookup bolt. | Interface | org.apache.storm.hbase.bolt.mapper | Apache Storm |
|
| HdfsBolt | | Class | org.apache.storm.hdfs.bolt | Apache Storm |
|
| HdfsSecurityUtil | | Class | org.apache.storm.hdfs.common.security | Apache Storm |
|
| HdfsState | | Class | org.apache.storm.hdfs.trident | Apache Storm |
|
| HdfsStateFactory | | Class | org.apache.storm.hdfs.trident | Apache Storm |
|
| HdfsUpdater | | Class | org.apache.storm.hdfs.trident | Apache Storm |
|
| HiveBolt | | Class | org.apache.storm.hive.bolt | Apache Storm |
|
| HiveMapper | Maps a backtype. | Interface | org.apache.storm.hive.bolt.mapper | Apache Storm |
|
| HiveOptions | | Class | org.apache.storm.hive.common | Apache Storm |
|
| HiveState | | Class | org.apache.storm.hive.trident | Apache Storm |
|
| HiveStateFactory | | Class | org.apache.storm.hive.trident | Apache Storm |
|
| HiveUpdater | | Class | org.apache.storm.hive.trident | Apache Storm |
|
| HiveUtils | | Class | org.apache.storm.hive.common | Apache Storm |
|
| HiveWriter | | Class | org.apache.storm.hive.common | Apache Storm |
|
| IAggregatableStream | | Interface | storm.trident.fluent | Apache Storm |
|
| IAuthorizer | Nimbus could be configured with an authorization plugin. | Interface | backtype.storm.security.auth | Apache Storm |
|
| IAutoCredentials | Provides a way to automatically push credentials to a topology and to retreave them in the worker. | Interface | backtype.storm.security.auth | Apache Storm |
|
| IBackingMap | | Interface | storm.trident.state.map | Apache Storm |
|
| IBasicBolt | | Interface | backtype.storm.topology | Apache Storm |
|
| IBasicOutputCollector | | Interface | backtype.storm.topology | Apache Storm |
|
| IBatchBolt | | Interface | backtype.storm.coordination | Apache Storm |
|
| IBatchCoordinator | | Interface | storm.kafka.trident | Apache Storm |
|
| IBatchID | Skip navigation linksOverviewPackageClassUseTreeDeprecatedIndexHelp | Interface | storm.trident.spout | Apache Storm |
|
| IBatchSpout | | Interface | storm.trident.spout | Apache Storm |
|
| IBolt | An IBolt represents a component that takes tuples as input and produces tuples as output. | Interface | backtype.storm.task | Apache Storm |
|
| IBrokerReader | | Interface | storm.kafka.trident | Apache Storm |
|
| IChainedAggregatorDeclarer | Skip navigation linksOverviewPackageClassUseTreeDeprecatedIndexHelp | Interface | storm.trident.fluent | Apache Storm |
|
| IColumn | Interface definition for classes that support being written to HBase asSkip navigation links | Interface | org.apache.storm.hbase.common | Apache Storm |
|
| ICombiner | | Interface | backtype.storm.metric.api | Apache Storm |
|
| ICommitterTransactionalSpout | | Interface | backtype.storm.transactional | Apache Storm |
|
| ICommitterTridentSpout | | Interface | storm.trident.spout | Apache Storm |
|
| IComponent | Common methods for all possible components in a topology. | Interface | backtype.storm.topology | Apache Storm |
|
| IConnection | | Interface | backtype.storm.messaging | Apache Storm |
|
| IContext | This interface needs to be implemented for messaging plugin. | Interface | backtype.storm.messaging | Apache Storm |
|
| ICounter | Interface definition for classes that support being written to HBase asSkip navigation links | Interface | org.apache.storm.hbase.common | Apache Storm |
|
| ICredentialsListener | Allows a bolt or a spout to be informed when the credentials of the topology have changed. | Interface | backtype.storm | Apache Storm |
|
| ICredentialsRenewer | Provides a way to renew credentials on behelf of a user. | Interface | backtype.storm.security.auth | Apache Storm |
|
| IdentityBolt | | Class | backtype.storm.testing | Apache Storm |
|
| IdentityGrouping | | Class | storm.trident.partition | Apache Storm |
|
| IdentityMultiReducer | | Class | storm.trident.operation.impl | Apache Storm |
|
| IErrorReporter | | Interface | backtype.storm.task | Apache Storm |
|
| IGroupMappingServiceProvider | Get all various group memberships of a given user. | Interface | backtype.storm.security.auth | Apache Storm |
|
| IHttpCredentialsPlugin | Interface for handling credentials in an HttpServletRequestGets the user name from the request. | Interface | backtype.storm.security.auth | Apache Storm |
|
| IKryoDecorator | | Interface | backtype.storm.serialization | Apache Storm |
|
| IKryoFactory | An interface that controls the Kryo instance used by Storm for serialization. | Interface | backtype.storm.serialization | Apache Storm |
|
| ILocalCluster | | Interface | backtype.storm | Apache Storm |
|
| ILocalDRPC | | Interface | backtype.storm | Apache Storm |
|
| IMetric | | Interface | backtype.storm.metric.api | Apache Storm |
|
| IMetricsConsumer | | Interface | backtype.storm.metric.api | Apache Storm |
|
| IMetricsContext | | Interface | backtype.storm.task | Apache Storm |
|
| IMultiSchemableSpout | | Interface | backtype.storm.spout | Apache Storm |
|
| IndexedEdge | | Class | storm.trident.util | Apache Storm |
|
| IndexHashBatchToPartition | | Class | storm.trident.operation.impl | Apache Storm |
|
| IndexHashGrouping | | Class | storm.trident.partition | Apache Storm |
|
| IndifferentAccessMap | | Class | backtype.storm.utils | Apache Storm |
|
| INimbus | | Interface | backtype.storm.scheduler | Apache Storm |
|
| INimbusCredentialPlugin | Nimbus auto credential plugin that will be called on nimbus host during submit topology option. | Interface | backtype.storm.security | Apache Storm |
|
| InprocMessaging | | Class | backtype.storm.utils | Apache Storm |
|
| InputDeclarer | The stream is replicated across all the bolt's tasks. | Interface | backtype.storm.topology | Apache Storm |
|
| IntermediateRankingsBolt | This bolt ranks incoming objects by their count. | Class | storm.starter.bolt | Apache Storm |
|
| InvalidRequestException | | Class | backtype.storm.ui | Apache Storm |
|
| InvalidTopologyException | | Class | backtype.storm.generated | Apache Storm |
|
| IOpaquePartitionedTransactionalSpout | This defines a transactional spout which does *not* necessarily replay the same batch every time it emits a batch for a transaction id. | Interface | backtype.storm.transactional.partitioned | Apache Storm |
|
| IOpaquePartitionedTridentSpout | This defines a transactional spout which does *not* necessarily replay the same batch every time it emits a batch for a transaction id. | Interface | storm.trident.spout | Apache Storm |
|
| IOutputCollector | | Interface | backtype.storm.task | Apache Storm |
|
| IPartitionedTransactionalSpout | This interface defines a transactional spout that reads its tuples from a partitioned set of brokers. | Interface | backtype.storm.transactional.partitioned | Apache Storm |
|
| IPartitionedTridentSpout | This interface defines a transactional spout that reads its tuples from a partitioned set of brokers. | Interface | storm.trident.spout | Apache Storm |
|
| IPrincipalToLocal | Storm can be configured to launch worker processed as a given user. | Interface | backtype.storm.security.auth | Apache Storm |
|
| IReducer | | Interface | backtype.storm.metric.api | Apache Storm |
|
| IRichBolt | When writing topologies using Java, IRichBolt and IRichSpout are the main interfaces to use to implement components of the topology. | Interface | backtype.storm.topology | Apache Storm |
|
| IRichSpout | When writing topologies using Java, IRichBolt and IRichSpout are the main interfaces to use to implement components of the topology. | Interface | backtype.storm.topology | Apache Storm |
|
| IRichStateSpout | | Interface | backtype.storm.topology | Apache Storm |
|
| IScheduler | | Interface | backtype.storm.scheduler | Apache Storm |
|
| ISchemableSpout | | Interface | backtype.storm.spout | Apache Storm |
|
| ISerializer | The ISerializer interface describes the methods that an object should implement to provide serialization and de-serialization capabilities to | Interface | backtype.storm.multilang | Apache Storm |
|
| IShellMetric | | Interface | backtype.storm.metric.api.rpc | Apache Storm |
|
| IsolatedPool | | Class | backtype.storm.scheduler.multitenant | Apache Storm |
|
| ISpout | ISpout is the core interface for implementing spouts. | Interface | backtype.storm.spout | Apache Storm |
|
| ISpoutOutputCollector | | Interface | backtype.storm.spout | Apache Storm |
|
| ISpoutPartition | This is used as a Zookeeper node path for storing metadata. | Interface | storm.trident.spout | Apache Storm |
|
| ISpoutWaitStrategy | The strategy a spout needs to use when its waiting. | Interface | backtype.storm.spout | Apache Storm |
|
| IStateSpout | | Interface | backtype.storm.state | Apache Storm |
|
| IStateSpoutOutputCollector | | Interface | backtype.storm.state | Apache Storm |
|
| ISubscribedState | | Interface | backtype.storm.state | Apache Storm |
|
| ISupervisor | The id used in assignments. | Interface | backtype.storm.scheduler | Apache Storm |
|
| ISynchronizeOutputCollector | | Interface | backtype.storm.state | Apache Storm |
|
| ITaskHook | | Interface | backtype.storm.hooks | Apache Storm |
|
| ITopologyValidator | | Interface | backtype.storm.nimbus | Apache Storm |
|
| ITransactionalSpout | | Interface | backtype.storm.transactional | Apache Storm |
|
| ITransportPlugin | | Interface | backtype.storm.security.auth | Apache Storm |
|
| ITridentBatchBolt | | Interface | storm.trident.topology | Apache Storm |
|
| ITridentSpout | | Interface | storm.trident.spout | Apache Storm |
|
| ITuple | Returns true if this tuple contains the specified name of the field. | Interface | backtype.storm.tuple | Apache Storm |
|
| ITupleCollection | | Interface | storm.trident.state | Apache Storm |
|
| ITupleDeserializer | | Interface | backtype.storm.serialization | Apache Storm |
|
| ITupleSerializer | | Interface | backtype.storm.serialization | Apache Storm |
|
| JavaObject | | Class | backtype.storm.generated | Apache Storm |
|
| JavaObjectArg | | Class | backtype.storm.generated | Apache Storm |
|
| JdbcClient | | Class | org.apache.storm.jdbc.common | Apache Storm |
|
| JdbcInsertBolt | Basic bolt for writing to any Database table. | Class | org.apache.storm.jdbc.bolt | Apache Storm |
|
| JdbcLookupBolt | Basic bolt for querying from any database. | Class | org.apache.storm.jdbc.bolt | Apache Storm |
|
| JdbcLookupMapper | declare what are the fields that this code will output. | Interface | org.apache.storm.jdbc.mapper | Apache Storm |
|
| JdbcMapper | | Interface | org.apache.storm.jdbc.mapper | Apache Storm |
|
| JdbcQuery | | Class | org.apache.storm.jdbc.trident.state | Apache Storm |
|
| JdbcState | | Class | org.apache.storm.jdbc.trident.state | Apache Storm |
|
| JdbcStateFactory | | Class | org.apache.storm.jdbc.trident.state | Apache Storm |
|
| JdbcUpdater | | Class | org.apache.storm.jdbc.trident.state | Apache Storm |
|
| JedisClusterConfig | | Class | org.apache.storm.redis.util.config | Apache Storm |
|
| JedisClusterContainer | | Class | org.apache.storm.redis.util.container | Apache Storm |
|
| JedisCommandsContainerBuilder | | Class | org.apache.storm.redis.util.container | Apache Storm |
|
| JedisCommandsInstanceContainer | redis. | Interface | org.apache.storm.redis.util.container | Apache Storm |
|
| JedisContainer | | Class | org.apache.storm.redis.util.container | Apache Storm |
|
| JedisPoolConfig | | Class | org.apache.storm.redis.util.config | Apache Storm |
|
| JoinerMultiReducer | | Class | storm.trident.operation.impl | Apache Storm |
|
| JoinResult | | Class | backtype.storm.drpc | Apache Storm |
|
| JoinType | | Class | storm.trident | Apache Storm |
|
| JSONNonTransactionalSerializer | | Class | storm.trident.state | Apache Storm |
|
| JSONOpaqueSerializer | | Class | storm.trident.state | Apache Storm |
|
| JsonRecordHiveMapper | | Class | org.apache.storm.hive.bolt.mapper | Apache Storm |
|
| JsonSerializer | JsonSerializer implements the JSON multilang protocol. | Class | backtype.storm.multilang | Apache Storm |
|
| JSONTransactionalSerializer | | Class | storm.trident.state | Apache Storm |
|
| KafkaBolt | Bolt implementation that can send Tuple data to Kafka It expects the producer configuration and topic in storm config under | Class | storm.kafka.bolt | Apache Storm |
|
| KafkaConfig | | Class | storm.kafka | Apache Storm |
|
| KafkaError | | Class | storm.kafka | Apache Storm |
|
| KafkaSpout | | Class | storm.kafka | Apache Storm |
|
| KafkaTopicSelector | | Interface | storm.kafka.bolt.selector | Apache Storm |
|
| KafkaTopicSelector | | Interface | storm.kafka.trident.selector | Apache Storm |
|
| KafkaUtils | | Class | storm.kafka | Apache Storm |
|
| KerberosPrincipalToLocal | | Class | backtype.storm.security.auth | Apache Storm |
|
| KerberosSaslTransportPlugin | | Class | backtype.storm.security.auth.kerberos | Apache Storm |
|
| KeyedCountingBatchBolt | | Class | backtype.storm.testing | Apache Storm |
|
| KeyedCountingCommitterBolt | | Class | backtype.storm.testing | Apache Storm |
|
| KeyedFairBolt | | Class | backtype.storm.drpc | Apache Storm |
|
| KeyedRoundRobinQueue | | Class | backtype.storm.utils | Apache Storm |
|
| KeyedSummingBatchBolt | | Class | backtype.storm.testing | Apache Storm |
|
| KeyValueScheme | | Interface | storm.kafka | Apache Storm |
|
| KeyValueSchemeAsMultiScheme | | Class | storm.kafka | Apache Storm |
|
| KillOptions | | Class | backtype.storm.generated | Apache Storm |
|
| KryoTupleDeserializer | | Class | backtype.storm.serialization | Apache Storm |
|
| KryoTupleSerializer | | Class | backtype.storm.serialization | Apache Storm |
|
| KryoValuesDeserializer | | Class | backtype.storm.serialization | Apache Storm |
|
| KryoValuesSerializer | | Class | backtype.storm.serialization | Apache Storm |
|
| LinearDRPCInputDeclarer | | Interface | backtype.storm.drpc | Apache Storm |
|
| LinearDRPCTopologyBuilder | | Class | backtype.storm.drpc | Apache Storm |
|
| ListDelegate | | Class | backtype.storm.utils | Apache Storm |
|
| ListDelegateSerializer | | Class | backtype.storm.serialization.types | Apache Storm |
|
| LocalState | A simple, durable, atomic K/V database. | Class | backtype.storm.utils | Apache Storm |
|
| LoggingMetricsConsumer | | Class | backtype.storm.metric | Apache Storm |
|
| LRUMap | | Class | storm.trident.util | Apache Storm |
|
| LRUMemoryMapState | | Class | storm.trident.testing | Apache Storm |
|
| ManualDRPC | | Class | storm.starter | Apache Storm |
|
| MapCombinerAggStateUpdater | | Class | storm.trident.state.map | Apache Storm |
|
| MapGet | | Class | storm.trident.operation.builtin | Apache Storm |
|
| MapReducerAggStateUpdater | | Class | storm.trident.state.map | Apache Storm |
|
| MapState | | Interface | storm.trident.state.map | Apache Storm |
|
| MasterBatchCoordinator | | Class | storm.trident.topology | Apache Storm |
|
| MaxMetric | | Class | storm.kafka.trident | Apache Storm |
|
| MeanReducer | | Class | backtype.storm.metric.api | Apache Storm |
|
| MemoryBackingMap | | Class | storm.trident.testing | Apache Storm |
|
| MemoryMapState | | Class | storm.trident.testing | Apache Storm |
|
| MemoryTransactionalSpout | | Class | backtype.storm.testing | Apache Storm |
|
| MemoryTransactionalSpoutMeta | | Class | backtype.storm.testing | Apache Storm |
|
| MessageDecoder | | Class | backtype.storm.messaging.netty | Apache Storm |
|
| MessageEncoder | | Class | backtype.storm.messaging.netty | Apache Storm |
|
| MessageId | | Class | backtype.storm.tuple | Apache Storm |
|
| MetricsConsumerBolt | | Class | backtype.storm.metric | Apache Storm |
|
| MicroBatchIBackingMap | | Class | storm.trident.state.map | Apache Storm |
|
| MkClusterParam | The param arg for Testing. | Class | backtype.storm.testing | Apache Storm |
|
| MkTupleParam | | Class | backtype.storm.testing | Apache Storm |
|
| MockedSources | | Class | backtype.storm.testing | Apache Storm |
|
| Monitor | | Class | backtype.storm.utils | Apache Storm |
|
| MoveFileAction | | Class | org.apache.storm.hdfs.common.rotation | Apache Storm |
|
| MultiCountMetric | | Class | backtype.storm.metric.api | Apache Storm |
|
| MultiReducedMetric | | Class | backtype.storm.metric.api | Apache Storm |
|
| MultiReducer | | Interface | storm.trident.operation | Apache Storm |
|
| MultiReducerProcessor | | Class | storm.trident.planner.processor | Apache Storm |
|
| MultiScheme | | Interface | backtype.storm.spout | Apache Storm |
|
| MultitenantScheduler | | Class | backtype.storm.scheduler.multitenant | Apache Storm |
|
| MutableInt | | Class | backtype.storm.utils | Apache Storm |
|
| MutableLong | | Class | backtype.storm.utils | Apache Storm |
|
| MutableObject | | Class | backtype.storm.utils | Apache Storm |
|
| Negate | | Class | storm.trident.operation.builtin | Apache Storm |
|
| NettyRenameThreadFactory | | Class | backtype.storm.messaging.netty | Apache Storm |
|
| NGrouping | | Class | backtype.storm.testing | Apache Storm |
|
| Nimbus | | Class | backtype.storm.generated | Apache Storm |
|
| NimbusClient | | Class | backtype.storm.utils | Apache Storm |
|
| Node | Represents a single node in the cluster. | Class | backtype.storm.scheduler.multitenant | Apache Storm |
|
| Node | | Class | storm.trident.planner | Apache Storm |
|
| NodePool | A pool of nodes that can be used to run topologies. | Class | backtype.storm.scheduler.multitenant | Apache Storm |
|
| NodeStateInfo | | Class | storm.trident.planner | Apache Storm |
|
| NonRichBoltTracker | | Class | backtype.storm.testing | Apache Storm |
|
| NonTransactionalMap | | Class | storm.trident.state.map | Apache Storm |
|
| NoopAuthorizer | A no-op authorization implementation that illustrate info available for authorization decisions. | Class | backtype.storm.security.auth.authorizer | Apache Storm |
|
| NoOutputException | A NoOutputException states that no data has been received from the connectedSee Also:Serialized Form | Class | backtype.storm.multilang | Apache Storm |
|
| NoRotationPolicy | File rotation policy that will never rotate. | Class | org.apache.storm.hdfs.bolt.rotation | Apache Storm |
|
| NoRotationPolicy | File rotation policy that will never rotate. | Class | org.apache.storm.hdfs.trident.rotation | Apache Storm |
|
| NotAliveException | | Class | backtype.storm.generated | Apache Storm |
|
| NothingEmptyEmitStrategy | | Class | backtype.storm.spout | Apache Storm |
|
| NthLastModifiedTimeTracker | This class tracks the time-since-last-modify of a "thing" in a rolling fashion. | Class | storm.starter.tools | Apache Storm |
|
| NullStruct | | Class | backtype.storm.generated | Apache Storm |
|
| NumErrorsChoice | enum NumErrorsChoiceEnum Constant Summary | Class | backtype.storm.generated | Apache Storm |
|
| OpaqueMap | | Class | storm.trident.state.map | Apache Storm |
|
| OpaqueMemoryTransactionalSpout | This spout only works in local mode. | Class | backtype.storm.testing | Apache Storm |
|
| OpaquePartitionedTransactionalSpoutExecutor | | Class | backtype.storm.transactional.partitioned | Apache Storm |
|
| OpaquePartitionedTridentSpoutExecutor | | Class | storm.trident.spout | Apache Storm |
|
| OpaqueTridentKafkaSpout | | Class | storm.kafka.trident | Apache Storm |
|
| OpaqueValue | | Class | storm.trident.state | Apache Storm |
|
| Operation | | Interface | storm.trident.operation | Apache Storm |
|
| OutputCollector | This output collector exposes the API for emitting tuples from an IRichBolt. | Class | backtype.storm.task | Apache Storm |
|
| OutputFieldsDeclarer | | Interface | backtype.storm.topology | Apache Storm |
|
| OutputFieldsGetter | | Class | backtype.storm.topology | Apache Storm |
|
| PartialKeyGrouping | | Class | backtype.storm.grouping | Apache Storm |
|
| Partition | | Class | storm.kafka | Apache Storm |
|
| PartitionCoordinator | | Interface | storm.kafka | Apache Storm |
|
| PartitionedTransactionalSpoutExecutor | | Class | backtype.storm.transactional.partitioned | Apache Storm |
|
| PartitionedTridentSpoutExecutor | | Class | storm.trident.spout | Apache Storm |
|
| PartitionManager | | Class | storm.kafka | Apache Storm |
|
| PartitionNode | | Class | storm.trident.planner | Apache Storm |
|
| PartitionPersistProcessor | | Class | storm.trident.planner.processor | Apache Storm |
|
| PrepareBatchBolt | | Class | backtype.storm.testing | Apache Storm |
|
| PrepareRequest | | Class | backtype.storm.drpc | Apache Storm |
|
| PrinterBolt | | Class | storm.starter.bolt | Apache Storm |
|
| PrintSampleStream | | Class | storm.starter | Apache Storm |
|
| ProcessorContext | | Class | storm.trident.planner | Apache Storm |
|
| ProcessorNode | | Class | storm.trident.planner | Apache Storm |
|
| ProjectedProcessor | | Class | storm.trident.planner.processor | Apache Storm |
|
| PythonShellMetricsBolt | | Class | backtype.storm.testing | Apache Storm |
|
| PythonShellMetricsSpout | | Class | backtype.storm.testing | Apache Storm |
|
| QueryFunction | | Interface | storm.trident.state | Apache Storm |
|
| RandomSentenceSpout | | Class | storm.starter.spout | Apache Storm |
|
| Rankable | Note: We do not defensively copy the object wrapped by the Rankable. | Interface | storm.starter.tools | Apache Storm |
|
| RankableObjectWithFields | This class wraps an objects and its associated count, including any additional data fields. | Class | storm.starter.tools | Apache Storm |
|
| Rankings | | Class | storm.starter.tools | Apache Storm |
|
| RawMultiScheme | | Class | backtype.storm.spout | Apache Storm |
|
| RawScheme | | Class | backtype.storm.spout | Apache Storm |
|
| ReachTopology | This is a good example of doing complex Distributed RPC on top of Storm. | Class | storm.starter | Apache Storm |
|
| ReadOnlyMapState | | Interface | storm.trident.state.map | Apache Storm |
|
| ReadOnlySnapshottable | | Interface | storm.trident.state.snapshot | Apache Storm |
|
| ReadOnlyState | | Class | storm.trident.state | Apache Storm |
|
| RebalanceOptions | | Class | backtype.storm.generated | Apache Storm |
|
| RecordFormat | Formats a Tuple object into a byte array that will be written to HDFS. | Interface | org.apache.storm.hdfs.bolt.format | Apache Storm |
|
| RecordFormat | Formats a Tuple object into a byte array that will be written to HDFS. | Interface | org.apache.storm.hdfs.trident.format | Apache Storm |
|
| RedisClusterMapState | | Class | org.apache.storm.redis.trident.state | Apache Storm |
|
| RedisClusterState | | Class | org.apache.storm.redis.trident.state | Apache Storm |
|
| RedisClusterStateQuerier | | Class | org.apache.storm.redis.trident.state | Apache Storm |
|
| RedisClusterStateUpdater | | Class | org.apache.storm.redis.trident.state | Apache Storm |
|
| RedisMapState | | Class | org.apache.storm.redis.trident.state | Apache Storm |
|
| RedisState | | Class | org.apache.storm.redis.trident.state | Apache Storm |
|
| RedisStateQuerier | | Class | org.apache.storm.redis.trident.state | Apache Storm |
|
| RedisStateSetCountQuerier | | Class | org.apache.storm.redis.trident.state | Apache Storm |
|
| RedisStateSetUpdater | | Class | org.apache.storm.redis.trident.state | Apache Storm |
|
| RedisStateUpdater | | Class | org.apache.storm.redis.trident.state | Apache Storm |
|
| ReducedMetric | | Class | backtype.storm.metric.api | Apache Storm |
|
| ReducedShellMetric | | Class | backtype.storm.metric.api.rpc | Apache Storm |
|
| ReducerAggregator | | Interface | storm.trident.operation | Apache Storm |
|
| ReducerAggregatorImpl | | Class | storm.trident.operation.impl | Apache Storm |
|
| ReducerAggStateUpdater | | Class | storm.trident.operation.impl | Apache Storm |
|
| ReducerValueUpdater | | Class | storm.trident.state | Apache Storm |
|
| RegisteredGlobalState | This class is used as part of testing Storm. | Class | backtype.storm.utils | Apache Storm |
|
| RemovableMapState | | Interface | storm.trident.state.map | Apache Storm |
|
| ReportedFailedException | | Class | backtype.storm.topology | Apache Storm |
|
| ReqContext | context request context includes info about (1) remote address, | Class | backtype.storm.security.auth | Apache Storm |
|
| Result | | Class | storm.trident.operation.impl | Apache Storm |
|
| ReturnResults | | Class | backtype.storm.drpc | Apache Storm |
|
| ReturnResultsReducer | | Class | storm.trident.drpc | Apache Storm |
|
| RichShellBolt | | Class | backtype.storm.clojure | Apache Storm |
|
| RichShellSpout | | Class | backtype.storm.clojure | Apache Storm |
|
| RichSpoutBatchExecutor | | Class | storm.trident.spout | Apache Storm |
|
| RichSpoutBatchId | | Class | storm.trident.spout | Apache Storm |
|
| RichSpoutBatchIdSerializer | | Class | storm.trident.spout | Apache Storm |
|
| RichSpoutBatchTriggerer | | Class | storm.trident.spout | Apache Storm |
|
| RollingCountAggBolt | This bolt aggregates counts from multiple upstream bolts. | Class | storm.starter.bolt | Apache Storm |
|
| RollingCountBolt | This bolt performs rolling counts of incoming objects, i. | Class | storm.starter.bolt | Apache Storm |
|
| RollingTopWords | This topology does a continuous computation of the top N words that the topology has seen in terms of cardinality. | Class | storm.starter | Apache Storm |
|
| RotatingMap | Expires keys that have not been updated in the configured number of seconds. | Class | backtype.storm.utils | Apache Storm |
|
| RotatingTransactionalState | A map from txid to a value. | Class | backtype.storm.transactional.state | Apache Storm |
|
| RotatingTransactionalState | | Class | storm.trident.topology.state | Apache Storm |
|
| RotationAction | org. | Interface | org.apache.storm.hdfs.common.rotation | Apache Storm |
|
| SaslMessageToken | Send and receive SASL tokens. | Class | backtype.storm.messaging.netty | Apache Storm |
|
| SaslNettyClient | | Class | backtype.storm.messaging.netty | Apache Storm |
|
| SaslStormClientHandler | | Class | backtype.storm.messaging.netty | Apache Storm |
|
| SaslStormServerAuthorizeHandler | Authorize or deny client requests based on existence and completeness of client's SASL authentication. | Class | backtype.storm.messaging.netty | Apache Storm |
|
| SaslStormServerHandler | | Class | backtype.storm.messaging.netty | Apache Storm |
|
| SaslTransportPlugin | Base class for SASL authentication plugin. | Class | backtype.storm.security.auth | Apache Storm |
|
| SchedulerAssignment | Return the executors covered by this assignmentsMapgetExecutorToSlot() | Interface | backtype.storm.scheduler | Apache Storm |
|
| SchedulerAssignmentImpl | | Class | backtype.storm.scheduler | Apache Storm |
|
| Scheme | | Interface | backtype.storm.spout | Apache Storm |
|
| SchemeAsMultiScheme | | Class | backtype.storm.spout | Apache Storm |
|
| SequenceFileBolt | | Class | org.apache.storm.hdfs.bolt | Apache Storm |
|
| SequenceFormat | Interface for converting Tuple objects to HDFS sequence file key-value pairs. | Interface | org.apache.storm.hdfs.bolt.format | Apache Storm |
|
| SequenceFormat | Interface for converting TridentTuple objects to HDFS sequence file key-value pairs. | Interface | org.apache.storm.hdfs.trident.format | Apache Storm |
|
| SerializableSerializer | | Class | backtype.storm.serialization | Apache Storm |
|
| SerializationDelegate | Allow Utils to delegate meta serialization. | Interface | backtype.storm.serialization | Apache Storm |
|
| SerializationFactory | | Class | backtype.storm.serialization | Apache Storm |
|
| Serializer | | Interface | storm.trident.state | Apache Storm |
|
| ServerCallbackHandler | | Class | backtype.storm.security.auth.digest | Apache Storm |
|
| ServerCallbackHandler | | Class | backtype.storm.security.auth.kerberos | Apache Storm |
|
| ServiceRegistry | | Class | backtype.storm.utils | Apache Storm |
|
| ShellBasedGroupsMapping | | Class | backtype.storm.security.auth | Apache Storm |
|
| ShellBolt | A bolt that shells out to another process to process tuples. | Class | backtype.storm.task | Apache Storm |
|
| ShellComponent | | Class | backtype.storm.generated | Apache Storm |
|
| ShellMsg | ShellMsg is an object that represents the data sent to a shell component from a process that implements a multi-language protocol. | Class | backtype.storm.multilang | Apache Storm |
|
| ShellProcess | | Class | backtype.storm.utils | Apache Storm |
|
| ShellSpout | | Class | backtype.storm.spout | Apache Storm |
|
| ShellUtils | | Class | backtype.storm.utils | Apache Storm |
|
| SimpleACLAuthorizer | | Class | backtype.storm.security.auth.authorizer | Apache Storm |
|
| SimpleHBaseMapper | | Class | org.apache.storm.hbase.bolt.mapper | Apache Storm |
|
| SimpleJdbcLookupMapper | | Class | org.apache.storm.jdbc.mapper | Apache Storm |
|
| SimpleJdbcMapper | | Class | org.apache.storm.jdbc.mapper | Apache Storm |
|
| SimpleTransportPlugin | Simple transport for Thrift plugin. | Class | backtype.storm.security.auth | Apache Storm |
|
| SimpleTridentHBaseMapper | | Class | org.apache.storm.hbase.trident.mapper | Apache Storm |
|
| SimpleWhitelistAuthorizer | An authorization implementation that simply checks a whitelist of users that are allowed to use the cluster. | Class | backtype.storm.security.auth.authorizer | Apache Storm |
|
| SingleEmitAggregator | | Class | storm.trident.operation.impl | Apache Storm |
|
| SingleJoinBolt | | Class | storm.starter.bolt | Apache Storm |
|
| SingleJoinExample | | Class | storm.starter | Apache Storm |
|
| SingleUserPrincipal | A Principal that represents a user. | Class | backtype.storm.security.auth | Apache Storm |
|
| SingleUserSimpleTransport | | Class | backtype.storm.testing | Apache Storm |
|
| SkewedRollingTopWords | This topology does a continuous computation of the top N words that the topology has seen in terms of cardinality. | Class | storm.starter | Apache Storm |
|
| SleepSpoutWaitStrategy | | Class | backtype.storm.spout | Apache Storm |
|
| SlidingWindowCounter | This class counts objects in a sliding window fashion. | Class | storm.starter.tools | Apache Storm |
|
| SlotBasedCounter | This class provides per-slot counts of the occurrences of objects. | Class | storm.starter.tools | Apache Storm |
|
| SnapshotGet | | Class | storm.trident.operation.builtin | Apache Storm |
|
| Snapshottable | | Interface | storm.trident.state.snapshot | Apache Storm |
|
| SnapshottableMap | | Class | storm.trident.state.map | Apache Storm |
|
| Split | | Class | storm.trident.testing | Apache Storm |
|
| SpoutAckInfo | | Class | backtype.storm.hooks.info | Apache Storm |
|
| SpoutConfig | | Class | storm.kafka | Apache Storm |
|
| SpoutDeclarer | | Interface | backtype.storm.topology | Apache Storm |
|
| SpoutFailInfo | | Class | backtype.storm.hooks.info | Apache Storm |
|
| SpoutMsg | SpoutMsg is an object that represents the data sent from a shell spout to a process that implements a multi-language spout. | Class | backtype.storm.multilang | Apache Storm |
|
| SpoutNode | | Class | storm.trident.planner | Apache Storm |
|
| SpoutOutputCollector | This output collector exposes the API for emitting tuples from an IRichSpout. | Class | backtype.storm.spout | Apache Storm |
|
| SpoutSpec | | Class | backtype.storm.generated | Apache Storm |
|
| SpoutStats | | Class | backtype.storm.generated | Apache Storm |
|
| SpoutTracker | | Class | backtype.storm.testing | Apache Storm |
|
| State | There's 3 different kinds of state: 1. | Interface | storm.trident.state | Apache Storm |
|
| StateFactory | | Interface | storm.trident.state | Apache Storm |
|
| StateMetric | | Class | backtype.storm.metric.api | Apache Storm |
|
| StateQueryProcessor | | Class | storm.trident.planner.processor | Apache Storm |
|
| StateSpec | | Class | storm.trident.state | Apache Storm |
|
| StateSpoutOutputCollector | | Class | backtype.storm.state | Apache Storm |
|
| StateSpoutSpec | | Class | backtype.storm.generated | Apache Storm |
|
| StateType | | Class | storm.trident.state | Apache Storm |
|
| StateUpdater | | Interface | storm.trident.state | Apache Storm |
|
| StaticBrokerReader | | Class | storm.kafka.trident | Apache Storm |
|
| StaticCoordinator | | Class | storm.kafka | Apache Storm |
|
| StaticHosts | | Class | storm.kafka | Apache Storm |
|
| StaticPartitionConnections | | Class | storm.kafka | Apache Storm |
|
| StormBoundedExponentialBackoffRetry | | Class | backtype.storm.utils | Apache Storm |
|
| StormClientErrorHandler | | Class | backtype.storm.messaging.netty | Apache Storm |
|
| StormRunner | | Class | storm.starter.util | Apache Storm |
|
| StormSubmitter | Use this class to submit topologies to run on the Storm cluster. | Class | backtype.storm | Apache Storm |
|
| StormTopology | | Class | backtype.storm.generated | Apache Storm |
|
| Stream | | Class | storm.trident | Apache Storm |
|
| StreamInfo | | Class | backtype.storm.generated | Apache Storm |
|
| StringKeyValueScheme | | Class | storm.kafka | Apache Storm |
|
| StringLength | | Class | storm.trident.testing | Apache Storm |
|
| StringScheme | | Class | storm.kafka | Apache Storm |
|
| SubmitOptions | | Class | backtype.storm.generated | Apache Storm |
|
| SubtopologyBolt | | Class | storm.trident.planner | Apache Storm |
|
| Sum | | Class | storm.trident.operation.builtin | Apache Storm |
|
| SupervisorDetails | | Class | backtype.storm.scheduler | Apache Storm |
|
| SupervisorSummary | | Class | backtype.storm.generated | Apache Storm |
|
| SynchronizeOutputCollector | | Class | backtype.storm.state | Apache Storm |
|
| SyncPolicy | Interface for controlling when the HdfsBolt syncs and flushes the filesystem. | Interface | org.apache.storm.hdfs.bolt.sync | Apache Storm |
|
| SyncPolicy | Interface for controlling when the HdfsBolt syncs and flushes the filesystem. | Interface | org.apache.storm.hdfs.trident.sync | Apache Storm |
|
| SystemBolt | | Class | backtype.storm.metric | Apache Storm |
|
| TaskBundle | | Class | backtype.storm.planner | Apache Storm |
|
| TaskMessage | | Class | backtype.storm.messaging | Apache Storm |
|
| TBackoffConnect | | Class | backtype.storm.security.auth | Apache Storm |
|
| TestAggregatesCounter | | Class | backtype.storm.testing | Apache Storm |
|
| TestConfBolt | | Class | backtype.storm.testing | Apache Storm |
|
| TestEventLogSpout | | Class | backtype.storm.testing | Apache Storm |
|
| TestEventOrderCheckBolt | | Class | backtype.storm.testing | Apache Storm |
|
| TestGlobalCount | | Class | backtype.storm.testing | Apache Storm |
|
| TestJob | This is the core interface for the storm java testing, usually we put our java unit testing logic in the run method. | Interface | backtype.storm.testing | Apache Storm |
|
| TestKryoDecorator | | Class | backtype.storm.testing | Apache Storm |
|
| TestPlannerBolt | | Class | backtype.storm.testing | Apache Storm |
|
| TestPlannerSpout | | Class | backtype.storm.testing | Apache Storm |
|
| TestSerObject | | Class | backtype.storm.testing | Apache Storm |
|
| TestTransactionalState | Facilitates testing of non-public methods in the parent class. | Class | backtype.storm.transactional.state | Apache Storm |
|
| TestTransactionalState | Facilitates testing of non-public methods in the parent class. | Class | storm.trident.topology.state | Apache Storm |
|
| TestUtils | | Class | backtype.storm.utils | Apache Storm |
|
| TestWordCounter | | Class | backtype.storm.testing | Apache Storm |
|
| TestWordSpout | | Class | backtype.storm.testing | Apache Storm |
|
| ThriftClient | | Class | backtype.storm.security.auth | Apache Storm |
|
| ThriftConnectionType | enum ThriftConnectionTypeThe purpose for which the Thrift server is created. | Class | backtype.storm.security.auth | Apache Storm |
|
| ThriftServer | | Class | backtype.storm.security.auth | Apache Storm |
|
| ThriftTopologyUtils | | Class | backtype.storm.utils | Apache Storm |
|
| Time | | Class | backtype.storm.utils | Apache Storm |
|
| TimeCacheMap | Expires keys that have not been updated in the configured number of seconds. | Class | backtype.storm.utils | Apache Storm |
|
| TimedRotationPolicy | | Class | org.apache.storm.hdfs.bolt.rotation | Apache Storm |
|
| TimedRotationPolicy | | Class | org.apache.storm.hdfs.trident.rotation | Apache Storm |
|
| TopicOffsetOutOfRangeException | | Class | storm.kafka | Apache Storm |
|
| Topologies | | Class | backtype.storm.scheduler | Apache Storm |
|
| TopologyBuilder | TopologyBuilder exposes the Java API for specifying a topology for Storm to execute. | Class | backtype.storm.topology | Apache Storm |
|
| TopologyContext | A TopologyContext is given to bolts and spouts in their "prepare" and "open" methods, respectively. | Class | backtype.storm.task | Apache Storm |
|
| TopologyDetails | | Class | backtype.storm.scheduler | Apache Storm |
|
| TopologyInfo | | Class | backtype.storm.generated | Apache Storm |
|
| TopologyInitialStatus | enum TopologyInitialStatusEnum Constant Summary | Class | backtype.storm.generated | Apache Storm |
|
| TopologySummary | | Class | backtype.storm.generated | Apache Storm |
|
| TotalRankingsBolt | This bolt merges incoming Rankings. | Class | storm.starter.bolt | Apache Storm |
|
| TrackedTopology | | Class | backtype.storm.testing | Apache Storm |
|
| TransactionalGlobalCount | This is a basic example of a transactional topology. | Class | storm.starter | Apache Storm |
|
| TransactionalMap | | Class | storm.trident.state.map | Apache Storm |
|
| TransactionalSpoutBatchExecutor | | Class | backtype.storm.transactional | Apache Storm |
|
| TransactionalSpoutCoordinator | | Class | backtype.storm.transactional | Apache Storm |
|
| TransactionalState | | Class | backtype.storm.transactional.state | Apache Storm |
|
| TransactionalState | | Class | storm.trident.topology.state | Apache Storm |
|
| TransactionalTopologyBuilder | Trident subsumes the functionality provided by transactional topologies, so this class is deprecated. | Class | backtype.storm.transactional | Apache Storm |
|
| TransactionalTridentKafkaSpout | | Class | storm.kafka.trident | Apache Storm |
|
| TransactionalValue | | Class | storm.trident.state | Apache Storm |
|
| TransactionalWords | This class defines a more involved transactional topology then TransactionalGlobalCount. | Class | storm.starter | Apache Storm |
|
| TransactionAttempt | | Class | backtype.storm.transactional | Apache Storm |
|
| TransactionAttempt | | Class | storm.trident.topology | Apache Storm |
|
| TransferDrainer | | Class | backtype.storm.utils | Apache Storm |
|
| TransportFactory | | Class | backtype.storm.messaging | Apache Storm |
|
| TridentBoltExecutor | | Class | storm.trident.topology | Apache Storm |
|
| TridentCollector | | Interface | storm.trident.operation | Apache Storm |
|
| TridentContext | | Class | storm.trident.planner.processor | Apache Storm |
|
| TridentHBaseMapper | Maps a storm. | Interface | org.apache.storm.hbase.trident.mapper | Apache Storm |
|
| TridentKafkaConfig | | Class | storm.kafka.trident | Apache Storm |
|
| TridentKafkaEmitter | | Class | storm.kafka.trident | Apache Storm |
|
| TridentKafkaState | | Class | storm.kafka.trident | Apache Storm |
|
| TridentKafkaStateFactory | | Class | storm.kafka.trident | Apache Storm |
|
| TridentKafkaUpdater | | Class | storm.kafka.trident | Apache Storm |
|
| TridentMultiReducerContext | | Class | storm.trident.operation | Apache Storm |
|
| TridentOperationContext | | Class | storm.trident.operation | Apache Storm |
|
| TridentProcessor | | Interface | storm.trident.planner | Apache Storm |
|
| TridentReach | | Class | storm.starter.trident | Apache Storm |
|
| TridentSpoutCoordinator | | Class | storm.trident.spout | Apache Storm |
|
| TridentSpoutExecutor | | Class | storm.trident.spout | Apache Storm |
|
| TridentState | | Class | storm.trident | Apache Storm |
|
| TridentTopology | | Class | storm.trident | Apache Storm |
|
| TridentTopologyBuilder | | Class | storm.trident.topology | Apache Storm |
|
| TridentTuple | | Interface | storm.trident.tuple | Apache Storm |
|
| TridentTupleMapper | | Interface | org.apache.storm.redis.trident.mapper | Apache Storm |
|
| TridentTupleToKafkaMapper | | Interface | storm.kafka.trident.mapper | Apache Storm |
|
| TridentTupleView | | Class | storm.trident.tuple | Apache Storm |
|
| TridentUtils | | Class | storm.trident.util | Apache Storm |
|
| TridentWordCount | | Class | storm.starter.trident | Apache Storm |
|
| TrueFilter | | Class | storm.trident.operation.impl | Apache Storm |
|
| TrueFilter | | Class | storm.trident.testing | Apache Storm |
|
| Tuple | The tuple is the main data structure in Storm. | Interface | backtype.storm.tuple | Apache Storm |
|
| TupleCaptureBolt | | Class | backtype.storm.testing | Apache Storm |
|
| TupleCollectionGet | | Class | storm.trident.operation.builtin | Apache Storm |
|
| TupleHelpers | | Class | storm.starter.util | Apache Storm |
|
| TupleImpl | | Class | backtype.storm.tuple | Apache Storm |
|
| TupleReceiver | | Interface | storm.trident.planner | Apache Storm |
|
| TupleToKafkaMapper | as the really verbose name suggests this interface mapps a storm tuple to kafka key and message. | Interface | storm.kafka.bolt.mapper | Apache Storm |
|
| TuplifyArgs | | Class | storm.trident.testing | Apache Storm |
|
| TwitterSampleSpout | | Class | storm.starter.spout | Apache Storm |
|
| UniqueIdGen | | Class | storm.trident.fluent | Apache Storm |
|
| Util | | Class | org.apache.storm.jdbc.common | Apache Storm |
|
| Utils | | Class | backtype.storm.utils | Apache Storm |
|
| Utils | | Class | org.apache.storm.hbase.common | Apache Storm |
|
| ValuePointer | | Class | storm.trident.tuple | Apache Storm |
|
| Values | A convenience class for making tuple values using new Values("field1", 2, 3)See Also:Serialized Form | Class | backtype.storm.tuple | Apache Storm |
|
| VersionedStore | | Class | backtype.storm.utils | Apache Storm |
|
| VersionInfo | | Class | backtype.storm.utils | Apache Storm |
|
| VersionInfoMojo | | Class | org.apache.storm.maven.plugin.versioninfo | Apache Storm |
|
| WindowedTimeThrottler | | Class | backtype.storm.utils | Apache Storm |
|
| WordCountTopology | This topology demonstrates Storm's stream groupings and multilang capabilities. | Class | storm.starter | Apache Storm |
|
| WordCountTopologyNode | This topology demonstrates Storm's stream groupings and multilang capabilities. | Class | storm.starter | Apache Storm |
|
| WorkerSlot | | Class | backtype.storm.scheduler | Apache Storm |
|
| WorkerTopologyContext | | Class | backtype.storm.task | Apache Storm |
|
| WritableUtils | | Class | backtype.storm.utils | Apache Storm |
|
| ZkBrokerReader | | Class | storm.kafka.trident | Apache Storm |
|
| ZkCoordinator | | Class | storm.kafka | Apache Storm |
|
| ZkHosts | | Class | storm.kafka | Apache Storm |
|
| ZkState | | Class | storm.kafka | Apache Storm |
|
| ZookeeperAuthInfo | | Class | backtype.storm.utils | Apache Storm |
|
| ZookeeperServerCnxnFactory | | Class | backtype.storm.utils | Apache Storm |