Uses of Interface
org.apache.storm.topology.IComponent
-
-
Uses of IComponent in org.apache.storm
Classes in org.apache.storm that implement IComponent Modifier and Type Class Description static class
ExclamationTopology.ExclamationBolt
static class
ExclamationTopology.FixedOrderWordSpout
-
Uses of IComponent in org.apache.storm.bolt
Classes in org.apache.storm.bolt that implement IComponent Modifier and Type Class Description class
JoinBolt
-
Uses of IComponent in org.apache.storm.clojure
Classes in org.apache.storm.clojure that implement IComponent Modifier and Type Class Description class
ClojureBolt
class
ClojureSpout
class
RichShellBolt
class
RichShellSpout
-
Uses of IComponent in org.apache.storm.coordination
Subinterfaces of IComponent in org.apache.storm.coordination Modifier and Type Interface Description interface
IBatchBolt<T>
Classes in org.apache.storm.coordination that implement IComponent Modifier and Type Class Description class
BatchBoltExecutor
class
CoordinatedBolt
Coordination requires the request ids to be globally unique for awhile. -
Uses of IComponent in org.apache.storm.drpc
Classes in org.apache.storm.drpc that implement IComponent Modifier and Type Class Description class
DRPCSpout
class
JoinResult
class
KeyedFairBolt
class
PrepareRequest
class
ReturnResults
-
Uses of IComponent in org.apache.storm.flux.examples
Classes in org.apache.storm.flux.examples that implement IComponent Modifier and Type Class Description class
StatefulWordCounter
class
TestPrintBolt
Prints the tuples to stdout.class
TestWindowBolt
class
WordCounter
This bolt is used by the HBase example. -
Uses of IComponent in org.apache.storm.flux.wrappers.bolts
Classes in org.apache.storm.flux.wrappers.bolts that implement IComponent Modifier and Type Class Description class
FluxShellBolt
A generic `ShellBolt` implementation that allows you specify output fields and even streams without having to subclass `ShellBolt` to do so.class
LogInfoBolt
Simple bolt that does nothing other than LOG.info() every tuple recieveed. -
Uses of IComponent in org.apache.storm.flux.wrappers.spouts
Classes in org.apache.storm.flux.wrappers.spouts that implement IComponent Modifier and Type Class Description class
FluxShellSpout
A generic `ShellSpout` implementation that allows you specify output fields and even streams without having to subclass `ShellSpout` to do so. -
Uses of IComponent in org.apache.storm.hdfs.bolt
Classes in org.apache.storm.hdfs.bolt that implement IComponent 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 IComponent in org.apache.storm.hdfs.spout
Classes in org.apache.storm.hdfs.spout that implement IComponent Modifier and Type Class Description class
HdfsSpout
static class
HdfsSpoutTopology.ConstBolt
-
Uses of IComponent in org.apache.storm.hive.bolt
Classes in org.apache.storm.hive.bolt that implement IComponent 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 IComponent in org.apache.storm.jdbc.bolt
Classes in org.apache.storm.jdbc.bolt that implement IComponent 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 IComponent in org.apache.storm.jdbc.spout
Classes in org.apache.storm.jdbc.spout that implement IComponent Modifier and Type Class Description class
UserSpout
-
Uses of IComponent in org.apache.storm.jms.bolt
Classes in org.apache.storm.jms.bolt that implement IComponent 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 IComponent in org.apache.storm.jms.example
Classes in org.apache.storm.jms.example that implement IComponent 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 IComponent in org.apache.storm.jms.spout
Classes in org.apache.storm.jms.spout that implement IComponent 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 IComponent in org.apache.storm.kafka.bolt
Classes in org.apache.storm.kafka.bolt that implement IComponent Modifier and Type Class Description class
KafkaBolt<K,V>
Bolt implementation that can send Tuple data to Kafka. -
Uses of IComponent in org.apache.storm.kafka.spout
Classes in org.apache.storm.kafka.spout that implement IComponent Modifier and Type Class Description class
KafkaSpout<K,V>
class
KafkaSpoutTestBolt
-
Uses of IComponent in org.apache.storm.lambda
Classes in org.apache.storm.lambda that implement IComponent Modifier and Type Class Description class
LambdaBiConsumerBolt
class
LambdaConsumerBolt
class
LambdaSpout
-
Uses of IComponent in org.apache.storm.loadgen
Classes in org.apache.storm.loadgen that implement IComponent 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 IComponent in org.apache.storm.perf.bolt
Classes in org.apache.storm.perf.bolt that implement IComponent Modifier and Type Class Description class
CountBolt
class
DevNullBolt
class
IdBolt
class
SplitSentenceBolt
-
Uses of IComponent in org.apache.storm.perf.spout
Classes in org.apache.storm.perf.spout that implement IComponent 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 IComponent in org.apache.storm.perf.utils
Classes in org.apache.storm.perf.utils that implement IComponent Modifier and Type Class Description class
IdentityBolt
-
Uses of IComponent in org.apache.storm.redis.bolt
Classes in org.apache.storm.redis.bolt that implement IComponent 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 IComponent in org.apache.storm.redis.topology
Classes in org.apache.storm.redis.topology that implement IComponent Modifier and Type Class Description static class
LookupWordCount.PrintWordTotalCountBolt
static class
WhitelistWordCount.PrintWordTotalCountBolt
class
WordCounter
class
WordSpout
-
Uses of IComponent in org.apache.storm.spout
Classes in org.apache.storm.spout that implement IComponent Modifier and Type Class Description class
CheckpointSpout
Emits checkpoint tuples which is used to save the state of theIStatefulComponent
across the topology. -
Uses of IComponent in org.apache.storm.sql.runtime.datasource.socket.bolt
Classes in org.apache.storm.sql.runtime.datasource.socket.bolt that implement IComponent Modifier and Type Class Description class
SocketBolt
The Bolt implementation for Socket. -
Uses of IComponent in org.apache.storm.sql.runtime.datasource.socket.spout
Classes in org.apache.storm.sql.runtime.datasource.socket.spout that implement IComponent Modifier and Type Class Description class
SocketSpout
Spout for Socket data. -
Uses of IComponent in org.apache.storm.st.topology.window
Classes in org.apache.storm.st.topology.window that implement IComponent Modifier and Type Class Description class
IncrementingSpout
class
TimeDataIncrementingSpout
class
TimeDataVerificationBolt
class
VerificationBolt
-
Uses of IComponent in org.apache.storm.starter
-
Uses of IComponent in org.apache.storm.starter.bolt
Classes in org.apache.storm.starter.bolt that implement IComponent 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
SlidingWindowSumBolt
Computes sliding window sum.class
TotalRankingsBolt
This bolt merges incomingRankings
.class
WordCountBolt
-
Uses of IComponent in org.apache.storm.starter.spout
Classes in org.apache.storm.starter.spout that implement IComponent 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 IComponent in org.apache.storm.testing
Classes in org.apache.storm.testing that implement IComponent Modifier and Type Class Description class
BoltTracker
class
FeederSpout
class
FixedTupleSpout
class
IdentityBolt
class
PrepareBatchBolt
class
PythonShellMetricsBolt
class
PythonShellMetricsSpout
class
SpoutTracker
class
TestAggregatesCounter
class
TestConfBolt
class
TestEventLogSpout
class
TestEventOrderCheckBolt
class
TestGlobalCount
class
TestPlannerBolt
class
TestPlannerSpout
class
TestWordBytesCounter
class
TestWordCounter
class
TestWordSpout
class
TupleCaptureBolt
-
Uses of IComponent in org.apache.storm.topology
Subinterfaces of IComponent in org.apache.storm.topology Modifier and Type Interface Description interface
IBasicBolt
interface
IRichBolt
When writing topologies using Java,IRichBolt
andIRichSpout
are the main interfaces to use to implement components of the topology.interface
IRichSpout
When writing topologies using Java,IRichBolt
andIRichSpout
are the main interfaces to use to implement components of the topology.interface
IRichStateSpout
interface
IStatefulBolt<T extends State>
A bolt abstraction for supporting stateful computation.interface
IStatefulComponent<T extends State>
Common methods for stateful components in the topology.interface
IStatefulWindowedBolt<T extends State>
A windowed bolt abstraction for supporting windowing operation with state.interface
IWindowedBolt
A bolt abstraction for supporting time and count based sliding & tumbling windows.Classes in org.apache.storm.topology that implement IComponent Modifier and Type Class Description class
BaseStatefulBoltExecutor
Base class that abstracts the common logic for executing bolts in a stateful topology.class
BasicBoltExecutor
class
CheckpointTupleForwarder
WrapsIRichBolt
and forwards checkpoint tuples in a stateful topology.class
PersistentWindowedBoltExecutor<T extends State>
Wraps aIStatefulWindowedBolt
and handles the execution.class
StatefulBoltExecutor<T extends State>
Wraps aIStatefulBolt
and manages the state of the bolt.class
StatefulWindowedBoltExecutor<T extends State>
Wraps aIStatefulWindowedBolt
and handles the execution.class
WindowedBoltExecutor
AnIWindowedBolt
wrapper that does the windowing of tuples. -
Uses of IComponent in org.apache.storm.topology.base
Classes in org.apache.storm.topology.base that implement IComponent Modifier and Type Class Description class
BaseBasicBolt
class
BaseBatchBolt<T>
class
BaseComponent
class
BaseRichBolt
class
BaseRichSpout
class
BaseStatefulBolt<T extends State>
class
BaseStatefulWindowedBolt<T extends State>
class
BaseTickTupleAwareRichBolt
This class is based on BaseRichBolt, but is aware of tick tuple.class
BaseWindowedBolt
-
Uses of IComponent in org.apache.storm.trident.planner
Classes in org.apache.storm.trident.planner that implement IComponent Modifier and Type Class Description class
SubtopologyBolt
A Bolt that does processing for a subsection of the complete graph. -
Uses of IComponent in org.apache.storm.trident.spout
Classes in org.apache.storm.trident.spout that implement IComponent Modifier and Type Class Description class
RichSpoutBatchTriggerer
class
TridentSpoutCoordinator
class
TridentSpoutExecutor
-
Uses of IComponent in org.apache.storm.trident.topology
Subinterfaces of IComponent in org.apache.storm.trident.topology Modifier and Type Interface Description interface
ITridentBatchBolt
Classes in org.apache.storm.trident.topology that implement IComponent Modifier and Type Class Description class
MasterBatchCoordinator
class
TridentBoltExecutor
-
Uses of IComponent in org.apache.storm.trident.util
Methods in org.apache.storm.trident.util with parameters of type IComponent Modifier and Type Method Description static Fields
TridentUtils. getSingleOutputStreamFields(IComponent component)
-