Uses of Interface
org.apache.storm.task.IBolt
-
-
Uses of IBolt in org.apache.storm
Classes in org.apache.storm that implement IBolt Modifier and Type Class Description static class
ExclamationTopology.ExclamationBolt
Methods in org.apache.storm with parameters of type IBolt Modifier and Type Method Description static Bolt
Thrift. prepareSerializedBoltDetails(Map<GlobalStreamId,Grouping> inputs, IBolt bolt, Map<String,StreamInfo> outputs, Integer parallelismHint, Map<String,Object> conf)
-
Uses of IBolt in org.apache.storm.clojure
Classes in org.apache.storm.clojure that implement IBolt Modifier and Type Class Description class
ClojureBolt
class
RichShellBolt
-
Uses of IBolt in org.apache.storm.coordination
Classes in org.apache.storm.coordination that implement IBolt Modifier and Type Class Description class
BatchBoltExecutor
class
CoordinatedBolt
Coordination requires the request ids to be globally unique for awhile. -
Uses of IBolt in org.apache.storm.daemon
Classes in org.apache.storm.daemon that implement IBolt Modifier and Type Class Description class
Acker
Methods in org.apache.storm.daemon that return IBolt Modifier and Type Method Description static IBolt
StormCommon. makeAckerBolt()
IBolt
StormCommon. makeAckerBoltImpl()
-
Uses of IBolt in org.apache.storm.drpc
Classes in org.apache.storm.drpc that implement IBolt Modifier and Type Class Description class
JoinResult
class
KeyedFairBolt
class
ReturnResults
-
Uses of IBolt in org.apache.storm.flux.wrappers.bolts
Classes in org.apache.storm.flux.wrappers.bolts that implement IBolt 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 IBolt in org.apache.storm.hdfs.bolt
Classes in org.apache.storm.hdfs.bolt that implement IBolt Modifier and Type Class Description class
AbstractHdfsBolt
class
AvroGenericRecordBolt
class
HdfsBolt
static class
HdfsFileTopology.MyBolt
class
SequenceFileBolt
static class
SequenceFileTopology.MyBolt
-
Uses of IBolt in org.apache.storm.hdfs.spout
Classes in org.apache.storm.hdfs.spout that implement IBolt Modifier and Type Class Description static class
HdfsSpoutTopology.ConstBolt
-
Uses of IBolt in org.apache.storm.hive.bolt
Classes in org.apache.storm.hive.bolt that implement IBolt Modifier and Type Class Description class
HiveBolt
Deprecated, for removal: This API element is subject to removal in a future version. -
Uses of IBolt in org.apache.storm.jdbc.bolt
Classes in org.apache.storm.jdbc.bolt that implement IBolt 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 IBolt in org.apache.storm.jms.bolt
Classes in org.apache.storm.jms.bolt that implement IBolt 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 IBolt in org.apache.storm.jms.example
Classes in org.apache.storm.jms.example that implement IBolt 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 IBolt in org.apache.storm.kafka.bolt
Classes in org.apache.storm.kafka.bolt that implement IBolt Modifier and Type Class Description class
KafkaBolt<K,V>
Bolt implementation that can send Tuple data to Kafka. -
Uses of IBolt in org.apache.storm.kafka.spout
Classes in org.apache.storm.kafka.spout that implement IBolt Modifier and Type Class Description class
KafkaSpoutTestBolt
-
Uses of IBolt in org.apache.storm.loadgen
Classes in org.apache.storm.loadgen that implement IBolt Modifier and Type Class Description class
LoadBolt
A bolt that simulates a real world bolt based off of statistics about it. -
Uses of IBolt in org.apache.storm.metric
Classes in org.apache.storm.metric that implement IBolt Modifier and Type Class Description class
EventLoggerBolt
class
MetricsConsumerBolt
class
SystemBolt
-
Uses of IBolt in org.apache.storm.perf.bolt
Classes in org.apache.storm.perf.bolt that implement IBolt Modifier and Type Class Description class
DevNullBolt
class
IdBolt
-
Uses of IBolt in org.apache.storm.perf.utils
Classes in org.apache.storm.perf.utils that implement IBolt Modifier and Type Class Description class
IdentityBolt
-
Uses of IBolt in org.apache.storm.planner
Fields in org.apache.storm.planner declared as IBolt Modifier and Type Field Description IBolt
TaskBundle. task
Constructors in org.apache.storm.planner with parameters of type IBolt Constructor Description TaskBundle(IBolt task, int componentId)
-
Uses of IBolt in org.apache.storm.redis.bolt
Classes in org.apache.storm.redis.bolt that implement IBolt 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 IBolt in org.apache.storm.redis.topology
Classes in org.apache.storm.redis.topology that implement IBolt Modifier and Type Class Description static class
LookupWordCount.PrintWordTotalCountBolt
static class
WhitelistWordCount.PrintWordTotalCountBolt
-
Uses of IBolt in org.apache.storm.sql.runtime.datasource.socket.bolt
Classes in org.apache.storm.sql.runtime.datasource.socket.bolt that implement IBolt Modifier and Type Class Description class
SocketBolt
The Bolt implementation for Socket. -
Uses of IBolt in org.apache.storm.starter
Classes in org.apache.storm.starter that implement IBolt 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 IBolt in org.apache.storm.starter.bolt
Classes in org.apache.storm.starter.bolt that implement IBolt 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 IBolt in org.apache.storm.task
Classes in org.apache.storm.task that implement IBolt Modifier and Type Class Description class
ShellBolt
A bolt that shells out to another process to process tuples. -
Uses of IBolt in org.apache.storm.testing
Classes in org.apache.storm.testing that implement IBolt Modifier and Type Class Description class
BoltTracker
class
NonRichBoltTracker
class
PythonShellMetricsBolt
class
TestAggregatesCounter
class
TestEventOrderCheckBolt
class
TestGlobalCount
class
TestPlannerBolt
class
TupleCaptureBolt
Constructors in org.apache.storm.testing with parameters of type IBolt Constructor Description NonRichBoltTracker(IBolt delegate, String id)
-
Uses of IBolt in org.apache.storm.topology
Subinterfaces of IBolt in org.apache.storm.topology Modifier and Type Interface Description interface
IRichBolt
When writing topologies using Java,IRichBolt
andIRichSpout
are the main interfaces to use to implement components of the topology.Classes in org.apache.storm.topology that implement IBolt 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 IBolt in org.apache.storm.topology.base
Classes in org.apache.storm.topology.base that implement IBolt Modifier and Type Class Description class
BaseRichBolt
class
BaseTickTupleAwareRichBolt
This class is based on BaseRichBolt, but is aware of tick tuple. -
Uses of IBolt in org.apache.storm.trident.topology
Classes in org.apache.storm.trident.topology that implement IBolt Modifier and Type Class Description class
TridentBoltExecutor
-