Uses of Class
org.apache.storm.topology.base.BaseComponent
-
-
Uses of BaseComponent in org.apache.storm
Subclasses of BaseComponent in org.apache.storm Modifier and Type Class Description static class
ExclamationTopology.ExclamationBolt
static class
ExclamationTopology.FixedOrderWordSpout
-
Uses of BaseComponent in org.apache.storm.drpc
Subclasses of BaseComponent in org.apache.storm.drpc Modifier and Type Class Description class
DRPCSpout
class
JoinResult
class
PrepareRequest
class
ReturnResults
-
Uses of BaseComponent in org.apache.storm.flux.examples
Subclasses of BaseComponent in org.apache.storm.flux.examples Modifier and Type Class Description class
TestPrintBolt
Prints the tuples to stdout.class
WordCounter
This bolt is used by the HBase example. -
Uses of BaseComponent in org.apache.storm.flux.wrappers.bolts
Subclasses of BaseComponent in org.apache.storm.flux.wrappers.bolts Modifier and Type Class Description class
LogInfoBolt
Simple bolt that does nothing other than LOG.info() every tuple recieveed. -
Uses of BaseComponent in org.apache.storm.hdfs.bolt
Subclasses of BaseComponent in org.apache.storm.hdfs.bolt Modifier and Type Class Description class
AbstractHdfsBolt
class
AvroGenericRecordBolt
class
HdfsBolt
static class
HdfsFileTopology.MyBolt
static class
HdfsFileTopology.SentenceSpout
class
SequenceFileBolt
static class
SequenceFileTopology.MyBolt
static class
SequenceFileTopology.SentenceSpout
-
Uses of BaseComponent in org.apache.storm.hdfs.spout
Subclasses of BaseComponent in org.apache.storm.hdfs.spout Modifier and Type Class Description class
HdfsSpout
static class
HdfsSpoutTopology.ConstBolt
-
Uses of BaseComponent in org.apache.storm.hive.bolt
Subclasses of BaseComponent in org.apache.storm.hive.bolt Modifier and Type Class Description static class
BucketTestHiveTopology.UserDataSpout
class
HiveBolt
Deprecated, for removal: This API element is subject to removal in a future version.static class
HiveTopology.UserDataSpout
static class
HiveTopologyPartitioned.UserDataSpout
-
Uses of BaseComponent in org.apache.storm.jdbc.bolt
Subclasses of BaseComponent in org.apache.storm.jdbc.bolt Modifier and Type Class Description class
AbstractJdbcBolt
class
JdbcInsertBolt
Basic bolt for writing to any Database table.class
JdbcLookupBolt
Basic bolt for querying from any database. -
Uses of BaseComponent in org.apache.storm.jms.bolt
Subclasses of BaseComponent in org.apache.storm.jms.bolt Modifier and Type Class Description class
JmsBolt
A JmsBolt receivesorg.apache.storm.tuple.Tuple
objects from a Storm topology and publishes JMS Messages to a destination (topic or queue). -
Uses of BaseComponent in org.apache.storm.jms.example
Subclasses of BaseComponent in org.apache.storm.jms.example Modifier and Type Class Description class
GenericBolt
A genericorg.apache.storm.topology.IRichBolt
implementation for testing/debugging the Storm JMS Spout and example topologies. -
Uses of BaseComponent in org.apache.storm.jms.spout
Subclasses of BaseComponent in org.apache.storm.jms.spout Modifier and Type Class Description class
JmsSpout
A StormSpout
implementation that listens to a JMS topic or queue and outputs tuples based on the messages it receives. -
Uses of BaseComponent in org.apache.storm.kafka.bolt
Subclasses of BaseComponent in org.apache.storm.kafka.bolt Modifier and Type Class Description class
KafkaBolt<K,V>
Bolt implementation that can send Tuple data to Kafka. -
Uses of BaseComponent in org.apache.storm.kafka.spout
Subclasses of BaseComponent in org.apache.storm.kafka.spout Modifier and Type Class Description class
KafkaSpout<K,V>
class
KafkaSpoutTestBolt
-
Uses of BaseComponent in org.apache.storm.lambda
Subclasses of BaseComponent in org.apache.storm.lambda Modifier and Type Class Description class
LambdaBiConsumerBolt
class
LambdaConsumerBolt
class
LambdaSpout
-
Uses of BaseComponent in org.apache.storm.loadgen
Subclasses of BaseComponent in org.apache.storm.loadgen Modifier and Type Class Description class
LoadBolt
A bolt that simulates a real world bolt based off of statistics about it.class
LoadSpout
A spout that simulates a real world spout based off of statistics about it.static class
ThroughputVsLatency.FastRandomSentenceSpout
static class
ThroughputVsLatency.SplitSentence
static class
ThroughputVsLatency.WordCount
-
Uses of BaseComponent in org.apache.storm.perf.bolt
Subclasses of BaseComponent in org.apache.storm.perf.bolt Modifier and Type Class Description class
CountBolt
class
DevNullBolt
class
IdBolt
class
SplitSentenceBolt
-
Uses of BaseComponent in org.apache.storm.perf.spout
Subclasses of BaseComponent in org.apache.storm.perf.spout Modifier and Type Class Description class
ConstSpout
class
FileReadSpout
class
StringGenSpout
Spout pre-computes a list with 30k fixed length random strings.class
WordGenSpout
-
Uses of BaseComponent in org.apache.storm.perf.utils
Subclasses of BaseComponent in org.apache.storm.perf.utils Modifier and Type Class Description class
IdentityBolt
-
Uses of BaseComponent in org.apache.storm.redis.bolt
Subclasses of BaseComponent in org.apache.storm.redis.bolt Modifier and Type Class Description class
AbstractRedisBolt
AbstractRedisBolt class is for users to implement custom bolts which makes interaction with Redis.class
RedisFilterBolt
Basic bolt for querying from Redis and filters out if key/field doesn't exist.class
RedisLookupBolt
Basic bolt for querying from Redis and emits response as tuple.class
RedisStoreBolt
Basic bolt for writing to Redis. -
Uses of BaseComponent in org.apache.storm.redis.topology
Subclasses of BaseComponent in org.apache.storm.redis.topology Modifier and Type Class Description static class
LookupWordCount.PrintWordTotalCountBolt
static class
WhitelistWordCount.PrintWordTotalCountBolt
-
Uses of BaseComponent in org.apache.storm.spout
Subclasses of BaseComponent in org.apache.storm.spout Modifier and Type Class Description class
CheckpointSpout
Emits checkpoint tuples which is used to save the state of theIStatefulComponent
across the topology. -
Uses of BaseComponent in org.apache.storm.sql.runtime.datasource.socket.bolt
Subclasses of BaseComponent in org.apache.storm.sql.runtime.datasource.socket.bolt Modifier and Type Class Description class
SocketBolt
The Bolt implementation for Socket. -
Uses of BaseComponent in org.apache.storm.st.topology.window
Subclasses of BaseComponent in org.apache.storm.st.topology.window Modifier and Type Class Description class
IncrementingSpout
class
TimeDataIncrementingSpout
-
Uses of BaseComponent in org.apache.storm.starter
-
Uses of BaseComponent in org.apache.storm.starter.bolt
Subclasses of BaseComponent in org.apache.storm.starter.bolt Modifier and Type Class Description class
AbstractRankerBolt
This abstract bolt provides the basic behavior of bolts that rank objects according to their count.class
IntermediateRankingsBolt
This bolt ranks incoming objects by their count.class
PrinterBolt
class
RollingCountAggBolt
This bolt aggregates counts from multiple upstream bolts.class
RollingCountBolt
This bolt performs rolling counts of incoming objects, i.e.class
SingleJoinBolt
Example of a simple custom bolt for joining two streams.class
TotalRankingsBolt
This bolt merges incomingRankings
.class
WordCountBolt
-
Uses of BaseComponent in org.apache.storm.starter.spout
Subclasses of BaseComponent in org.apache.storm.starter.spout Modifier and Type Class Description class
RandomIntegerSpout
Emits a random integer and a timestamp value (offset by one day), every 100 ms.class
RandomSentenceSpout
static class
RandomSentenceSpout.TimeStamped
-
Uses of BaseComponent in org.apache.storm.testing
Subclasses of BaseComponent in org.apache.storm.testing Modifier and Type Class Description class
FeederSpout
class
IdentityBolt
class
PrepareBatchBolt
class
SpoutTracker
class
TestAggregatesCounter
class
TestConfBolt
class
TestEventLogSpout
class
TestEventOrderCheckBolt
class
TestGlobalCount
class
TestPlannerBolt
class
TestPlannerSpout
class
TestWordBytesCounter
class
TestWordCounter
class
TestWordSpout
-
Uses of BaseComponent in org.apache.storm.topology.base
Subclasses of BaseComponent in org.apache.storm.topology.base Modifier and Type Class Description class
BaseBasicBolt
class
BaseBatchBolt<T>
class
BaseRichBolt
class
BaseRichSpout
class
BaseTickTupleAwareRichBolt
This class is based on BaseRichBolt, but is aware of tick tuple. -
Uses of BaseComponent in org.apache.storm.trident.topology
Subclasses of BaseComponent in org.apache.storm.trident.topology Modifier and Type Class Description class
MasterBatchCoordinator
-