Uses of Interface
org.apache.storm.topology.IRichBolt
-
-
Uses of IRichBolt in org.apache.storm
Classes in org.apache.storm that implement IRichBolt Modifier and Type Class Description static class
ExclamationTopology.ExclamationBolt
-
Uses of IRichBolt in org.apache.storm.clojure
Classes in org.apache.storm.clojure that implement IRichBolt Modifier and Type Class Description class
ClojureBolt
class
RichShellBolt
-
Uses of IRichBolt in org.apache.storm.coordination
Classes in org.apache.storm.coordination that implement IRichBolt Modifier and Type Class Description class
BatchBoltExecutor
class
CoordinatedBolt
Coordination requires the request ids to be globally unique for awhile.Constructors in org.apache.storm.coordination with parameters of type IRichBolt Constructor Description CoordinatedBolt(IRichBolt delegate)
CoordinatedBolt(IRichBolt delegate, String sourceComponent, CoordinatedBolt.SourceArgs sourceArgs, CoordinatedBolt.IdStreamSpec idStreamSpec)
CoordinatedBolt(IRichBolt delegate, Map<String,CoordinatedBolt.SourceArgs> sourceArgs, CoordinatedBolt.IdStreamSpec idStreamSpec)
-
Uses of IRichBolt in org.apache.storm.drpc
Classes in org.apache.storm.drpc that implement IRichBolt Modifier and Type Class Description class
JoinResult
class
KeyedFairBolt
class
ReturnResults
Methods in org.apache.storm.drpc with parameters of type IRichBolt Modifier and Type Method Description LinearDRPCInputDeclarer
LinearDRPCTopologyBuilder. addBolt(IRichBolt bolt)
Deprecated.LinearDRPCInputDeclarer
LinearDRPCTopologyBuilder. addBolt(IRichBolt bolt, Number parallelism)
Deprecated.Constructors in org.apache.storm.drpc with parameters of type IRichBolt Constructor Description KeyedFairBolt(IRichBolt delegate)
-
Uses of IRichBolt in org.apache.storm.flux.wrappers.bolts
Classes in org.apache.storm.flux.wrappers.bolts that implement IRichBolt 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. -
Uses of IRichBolt in org.apache.storm.hdfs.bolt
Classes in org.apache.storm.hdfs.bolt that implement IRichBolt Modifier and Type Class Description class
AbstractHdfsBolt
class
AvroGenericRecordBolt
class
HdfsBolt
static class
HdfsFileTopology.MyBolt
class
SequenceFileBolt
static class
SequenceFileTopology.MyBolt
-
Uses of IRichBolt in org.apache.storm.hdfs.spout
Classes in org.apache.storm.hdfs.spout that implement IRichBolt Modifier and Type Class Description static class
HdfsSpoutTopology.ConstBolt
-
Uses of IRichBolt in org.apache.storm.hive.bolt
Classes in org.apache.storm.hive.bolt that implement IRichBolt Modifier and Type Class Description class
HiveBolt
Deprecated, for removal: This API element is subject to removal in a future version. -
Uses of IRichBolt in org.apache.storm.jdbc.bolt
Classes in org.apache.storm.jdbc.bolt that implement IRichBolt 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 IRichBolt in org.apache.storm.jms.bolt
Classes in org.apache.storm.jms.bolt that implement IRichBolt 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 IRichBolt in org.apache.storm.jms.example
Classes in org.apache.storm.jms.example that implement IRichBolt 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 IRichBolt in org.apache.storm.kafka.bolt
Classes in org.apache.storm.kafka.bolt that implement IRichBolt Modifier and Type Class Description class
KafkaBolt<K,V>
Bolt implementation that can send Tuple data to Kafka. -
Uses of IRichBolt in org.apache.storm.kafka.spout
Classes in org.apache.storm.kafka.spout that implement IRichBolt Modifier and Type Class Description class
KafkaSpoutTestBolt
-
Uses of IRichBolt in org.apache.storm.loadgen
Classes in org.apache.storm.loadgen that implement IRichBolt Modifier and Type Class Description class
LoadBolt
A bolt that simulates a real world bolt based off of statistics about it. -
Uses of IRichBolt in org.apache.storm.perf.bolt
Classes in org.apache.storm.perf.bolt that implement IRichBolt Modifier and Type Class Description class
DevNullBolt
class
IdBolt
-
Uses of IRichBolt in org.apache.storm.perf.utils
Classes in org.apache.storm.perf.utils that implement IRichBolt Modifier and Type Class Description class
IdentityBolt
-
Uses of IRichBolt in org.apache.storm.redis.bolt
Classes in org.apache.storm.redis.bolt that implement IRichBolt 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 IRichBolt in org.apache.storm.redis.topology
Classes in org.apache.storm.redis.topology that implement IRichBolt Modifier and Type Class Description static class
LookupWordCount.PrintWordTotalCountBolt
static class
WhitelistWordCount.PrintWordTotalCountBolt
-
Uses of IRichBolt in org.apache.storm.sql.runtime
Methods in org.apache.storm.sql.runtime that return IRichBolt Modifier and Type Method Description IRichBolt
ISqlStreamsDataSource. getConsumer()
Provides instance of IRichBolt which can be used as consumer in topology. -
Uses of IRichBolt in org.apache.storm.sql.runtime.datasource.socket.bolt
Classes in org.apache.storm.sql.runtime.datasource.socket.bolt that implement IRichBolt Modifier and Type Class Description class
SocketBolt
The Bolt implementation for Socket. -
Uses of IRichBolt in org.apache.storm.starter
Classes in org.apache.storm.starter that implement IRichBolt Modifier and Type Class Description static class
BlobStoreAPIWordCountTopology.SplitSentence
static class
ExclamationTopology.ExclamationBolt
static class
MultipleLoggerTopology.ExclamationLoggingBolt
static class
MultiThreadWordCountTopology.MultiThreadedSplitSentence
static class
ResourceAwareExampleTopology.ExclamationBolt
static class
WordCountTopology.SplitSentence
static class
WordCountTopologyNode.SplitSentence
-
Uses of IRichBolt in org.apache.storm.starter.bolt
Classes in org.apache.storm.starter.bolt that implement IRichBolt Modifier and Type Class Description 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. -
Uses of IRichBolt in org.apache.storm.streams
Methods in org.apache.storm.streams with parameters of type IRichBolt Modifier and Type Method Description void
Stream. to(IRichBolt bolt)
Sends the elements of this stream to a bolt.void
Stream. to(IRichBolt bolt, int parallelism)
Sends the elements of this stream to a bolt. -
Uses of IRichBolt in org.apache.storm.testing
Classes in org.apache.storm.testing that implement IRichBolt Modifier and Type Class Description class
BoltTracker
class
PythonShellMetricsBolt
class
TestAggregatesCounter
class
TestEventOrderCheckBolt
class
TestGlobalCount
class
TestPlannerBolt
class
TupleCaptureBolt
Constructors in org.apache.storm.testing with parameters of type IRichBolt Constructor Description BoltTracker(IRichBolt delegate, String id)
-
Uses of IRichBolt in org.apache.storm.topology
Classes in org.apache.storm.topology that implement IRichBolt 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.Methods in org.apache.storm.topology with parameters of type IRichBolt Modifier and Type Method Description BoltDeclarer
TopologyBuilder. setBolt(String id, IRichBolt bolt)
Define a new bolt in this topology with parallelism of just one thread.BoltDeclarer
TopologyBuilder. setBolt(String id, IRichBolt bolt, Number parallelismHint)
Define a new bolt in this topology with the specified amount of parallelism.Constructors in org.apache.storm.topology with parameters of type IRichBolt Constructor Description CheckpointTupleForwarder(IRichBolt bolt)
-
Uses of IRichBolt in org.apache.storm.topology.base
Classes in org.apache.storm.topology.base that implement IRichBolt Modifier and Type Class Description class
BaseRichBolt
class
BaseTickTupleAwareRichBolt
This class is based on BaseRichBolt, but is aware of tick tuple. -
Uses of IRichBolt in org.apache.storm.trident.topology
Classes in org.apache.storm.trident.topology that implement IRichBolt Modifier and Type Class Description class
TridentBoltExecutor
-