Uses of Interface
org.apache.storm.task.IBolt
Packages that use IBolt
Package
Description
ElasticSearch examples classes.
-
Uses of IBolt in org.apache.storm
Classes in org.apache.storm that implement IBoltMethods in org.apache.storm with parameters of type IBoltModifier and TypeMethodDescriptionstatic 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 -
Uses of IBolt in org.apache.storm.coordination
Classes in org.apache.storm.coordination that implement IBoltModifier and TypeClassDescriptionclass
class
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 IBoltMethods in org.apache.storm.daemon that return IBoltModifier and TypeMethodDescriptionstatic IBolt
StormCommon.makeAckerBolt()
StormCommon.makeAckerBoltImpl()
-
Uses of IBolt in org.apache.storm.drpc
Classes in org.apache.storm.drpc that implement IBolt -
Uses of IBolt in org.apache.storm.elasticsearch.bolt
Classes in org.apache.storm.elasticsearch.bolt that implement IBoltModifier 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 IBolt in org.apache.storm.flux.wrappers.bolts
Classes in org.apache.storm.flux.wrappers.bolts that implement IBoltModifier 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 IBolt in org.apache.storm.hdfs.bolt
Classes in org.apache.storm.hdfs.bolt that implement IBoltModifier and TypeClassDescriptionclass
class
class
static class
class
static class
-
Uses of IBolt in org.apache.storm.hdfs.spout
Classes in org.apache.storm.hdfs.spout that implement IBolt -
Uses of IBolt in org.apache.storm.hive.bolt
Classes in org.apache.storm.hive.bolt that implement IBolt -
Uses of IBolt in org.apache.storm.jdbc.bolt
Classes in org.apache.storm.jdbc.bolt that implement IBoltModifier and TypeClassDescriptionclass
class
Basic bolt for writing to any Database table.class
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 IBoltModifier 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 IBolt in org.apache.storm.jms.example
Classes in org.apache.storm.jms.example that implement IBoltModifier and TypeClassDescriptionclass
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 IBoltModifier and TypeClassDescriptionclass
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 -
Uses of IBolt in org.apache.storm.loadgen
Classes in org.apache.storm.loadgen that implement IBoltModifier and TypeClassDescriptionclass
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 IBoltModifier and TypeClassDescriptionclass
class
class
-
Uses of IBolt in org.apache.storm.perf.bolt
Classes in org.apache.storm.perf.bolt that implement IBolt -
Uses of IBolt in org.apache.storm.perf.utils
Classes in org.apache.storm.perf.utils that implement IBolt -
Uses of IBolt in org.apache.storm.planner
Fields in org.apache.storm.planner declared as IBoltConstructors in org.apache.storm.planner with parameters of type IBolt -
Uses of IBolt in org.apache.storm.redis.bolt
Classes in org.apache.storm.redis.bolt that implement IBoltModifier 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 IBolt in org.apache.storm.redis.topology
Classes in org.apache.storm.redis.topology that implement IBoltModifier and TypeClassDescriptionstatic class
static class
-
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 -
Uses of IBolt in org.apache.storm.starter
Classes in org.apache.storm.starter that implement IBoltModifier and TypeClassDescriptionstatic class
static class
static class
static class
static class
static class
static class
-
Uses of IBolt in org.apache.storm.starter.bolt
Classes in org.apache.storm.starter.bolt that implement IBoltModifier 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 IBolt in org.apache.storm.task
Classes in org.apache.storm.task that implement IBoltModifier and TypeClassDescriptionclass
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 IBoltModifier and TypeClassDescriptionclass
class
class
class
class
class
class
class
Constructors in org.apache.storm.testing with parameters of type IBolt -
Uses of IBolt in org.apache.storm.topology
Subinterfaces of IBolt in org.apache.storm.topologyModifier and TypeInterfaceDescriptioninterface
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 IBoltModifier 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. -
Uses of IBolt in org.apache.storm.topology.base
Classes in org.apache.storm.topology.base that implement IBoltModifier and TypeClassDescriptionclass
class
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