Uses of Interface
org.apache.storm.topology.IRichBolt
Package
Description
ElasticSearch examples classes.
-
Uses of IRichBolt in org.apache.storm
-
Uses of IRichBolt in org.apache.storm.clojure
-
Uses of IRichBolt in org.apache.storm.coordination
Modifier and TypeClassDescriptionclass
class
Coordination requires the request ids to be globally unique for awhile.ModifierConstructorDescriptionCoordinatedBolt
(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
Modifier and TypeMethodDescriptionDeprecated.Deprecated. -
Uses of IRichBolt in org.apache.storm.elasticsearch.bolt
Modifier and TypeClassDescriptionclass
class
Basic bolt for storing tuple to ES document.class
Basic bolt for looking up document in ES.class
Basic bolt for retrieve matched percolate queries. -
Uses of IRichBolt in org.apache.storm.flux.wrappers.bolts
Modifier and TypeClassDescriptionclass
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
Modifier and TypeClassDescriptionclass
class
class
static class
class
static class
-
Uses of IRichBolt in org.apache.storm.hdfs.spout
-
Uses of IRichBolt in org.apache.storm.hive.bolt
-
Uses of IRichBolt in org.apache.storm.jdbc.bolt
Modifier and TypeClassDescriptionclass
class
Basic bolt for writing to any Database table.class
Basic bolt for querying from any database. -
Uses of IRichBolt in org.apache.storm.jms.bolt
Modifier and TypeClassDescriptionclass
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
Modifier and TypeClassDescriptionclass
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
Modifier and TypeClassDescriptionclass
KafkaBolt<K,
V> Bolt implementation that can send Tuple data to Kafka. -
Uses of IRichBolt in org.apache.storm.kafka.spout
-
Uses of IRichBolt in org.apache.storm.loadgen
Modifier and TypeClassDescriptionclass
A bolt that simulates a real world bolt based off of statistics about it. -
Uses of IRichBolt in org.apache.storm.perf.bolt
-
Uses of IRichBolt in org.apache.storm.perf.utils
-
Uses of IRichBolt in org.apache.storm.redis.bolt
Modifier and TypeClassDescriptionclass
AbstractRedisBolt class is for users to implement custom bolts which makes interaction with Redis.class
Basic bolt for querying from Redis and filters out if key/field doesn't exist.class
Basic bolt for querying from Redis and emits response as tuple.class
Basic bolt for writing to Redis. -
Uses of IRichBolt in org.apache.storm.redis.topology
Modifier and TypeClassDescriptionstatic class
static class
-
Uses of IRichBolt in org.apache.storm.sql.runtime
Modifier and TypeMethodDescriptionISqlStreamsDataSource.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
-
Uses of IRichBolt in org.apache.storm.starter
Modifier and TypeClassDescriptionstatic class
static class
static class
static class
static class
static class
static class
-
Uses of IRichBolt in org.apache.storm.starter.bolt
Modifier and TypeClassDescriptionclass
This bolt aggregates counts from multiple upstream bolts.class
This bolt performs rolling counts of incoming objects, i.e. sliding window based counting.class
Example of a simple custom bolt for joining two streams. -
Uses of IRichBolt in org.apache.storm.streams
-
Uses of IRichBolt in org.apache.storm.testing
Modifier and TypeClassDescriptionclass
class
class
class
class
class
class
-
Uses of IRichBolt in org.apache.storm.topology
Modifier and TypeClassDescriptionclass
Base class that abstracts the common logic for executing bolts in a stateful topology.class
class
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
AnIWindowedBolt
wrapper that does the windowing of tuples.Modifier and TypeMethodDescriptionDefine a new bolt in this topology with parallelism of just one thread.Define a new bolt in this topology with the specified amount of parallelism. -
Uses of IRichBolt in org.apache.storm.topology.base
Modifier and TypeClassDescriptionclass
class
This class is based on BaseRichBolt, but is aware of tick tuple. -
Uses of IRichBolt in org.apache.storm.trident.topology