Uses of Interface
org.apache.storm.task.IBolt
Packages that use IBolt
Package
Description
- 
Uses of IBolt in org.apache.stormClasses in org.apache.storm that implement IBoltMethods in org.apache.storm with parameters of type IBoltModifier and TypeMethodDescriptionstatic BoltThrift.prepareSerializedBoltDetails(Map<GlobalStreamId, Grouping> inputs, IBolt bolt, Map<String, StreamInfo> outputs, Integer parallelismHint, Map<String, Object> conf) 
- 
Uses of IBolt in org.apache.storm.clojureClasses in org.apache.storm.clojure that implement IBolt
- 
Uses of IBolt in org.apache.storm.coordinationClasses in org.apache.storm.coordination that implement IBoltModifier and TypeClassDescriptionclassclassCoordination requires the request ids to be globally unique for awhile.
- 
Uses of IBolt in org.apache.storm.daemonClasses in org.apache.storm.daemon that implement IBoltMethods in org.apache.storm.daemon that return IBoltModifier and TypeMethodDescriptionstatic IBoltStormCommon.makeAckerBolt()StormCommon.makeAckerBoltImpl()
- 
Uses of IBolt in org.apache.storm.drpcClasses in org.apache.storm.drpc that implement IBolt
- 
Uses of IBolt in org.apache.storm.flux.wrappers.boltsClasses in org.apache.storm.flux.wrappers.bolts that implement IBoltModifier and TypeClassDescriptionclassA 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.boltClasses in org.apache.storm.hdfs.bolt that implement IBoltModifier and TypeClassDescriptionclassclassclassstatic classclassstatic class
- 
Uses of IBolt in org.apache.storm.hdfs.spoutClasses in org.apache.storm.hdfs.spout that implement IBolt
- 
Uses of IBolt in org.apache.storm.jdbc.boltClasses in org.apache.storm.jdbc.bolt that implement IBoltModifier and TypeClassDescriptionclassclassBasic bolt for writing to any Database table.classBasic bolt for querying from any database.
- 
Uses of IBolt in org.apache.storm.jms.boltClasses in org.apache.storm.jms.bolt that implement IBoltModifier and TypeClassDescriptionclassA JmsBolt receivesorg.apache.storm.tuple.Tupleobjects from a Storm topology and publishes JMS Messages to a destination (topic or queue).
- 
Uses of IBolt in org.apache.storm.jms.exampleClasses in org.apache.storm.jms.example that implement IBoltModifier and TypeClassDescriptionclassA genericorg.apache.storm.topology.IRichBoltimplementation for testing/debugging the Storm JMS Spout and example topologies.
- 
Uses of IBolt in org.apache.storm.kafka.boltClasses in org.apache.storm.kafka.bolt that implement IBoltModifier and TypeClassDescriptionclassKafkaBolt<K,V> Bolt implementation that can send Tuple data to Kafka.
- 
Uses of IBolt in org.apache.storm.kafka.spoutClasses in org.apache.storm.kafka.spout that implement IBolt
- 
Uses of IBolt in org.apache.storm.loadgenClasses in org.apache.storm.loadgen that implement IBoltModifier and TypeClassDescriptionclassA bolt that simulates a real world bolt based off of statistics about it.
- 
Uses of IBolt in org.apache.storm.metricClasses in org.apache.storm.metric that implement IBoltModifier and TypeClassDescriptionclassclassclass
- 
Uses of IBolt in org.apache.storm.perf.boltClasses in org.apache.storm.perf.bolt that implement IBolt
- 
Uses of IBolt in org.apache.storm.perf.utilsClasses in org.apache.storm.perf.utils that implement IBolt
- 
Uses of IBolt in org.apache.storm.plannerFields 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.boltClasses in org.apache.storm.redis.bolt that implement IBoltModifier and TypeClassDescriptionclassAbstractRedisBolt class is for users to implement custom bolts which makes interaction with Redis.classBasic bolt for querying from Redis and filters out if key/field doesn't exist.classBasic bolt for querying from Redis and emits response as tuple.classBasic bolt for writing to Redis.
- 
Uses of IBolt in org.apache.storm.redis.topologyClasses in org.apache.storm.redis.topology that implement IBoltModifier and TypeClassDescriptionstatic classstatic class
- 
Uses of IBolt in org.apache.storm.sql.runtime.datasource.socket.boltClasses in org.apache.storm.sql.runtime.datasource.socket.bolt that implement IBolt
- 
Uses of IBolt in org.apache.storm.starterClasses in org.apache.storm.starter that implement IBoltModifier and TypeClassDescriptionstatic classstatic classstatic classstatic classstatic classstatic classstatic class
- 
Uses of IBolt in org.apache.storm.starter.boltClasses in org.apache.storm.starter.bolt that implement IBoltModifier and TypeClassDescriptionclassThis bolt aggregates counts from multiple upstream bolts.classThis bolt performs rolling counts of incoming objects, i.e.classExample of a simple custom bolt for joining two streams.
- 
Uses of IBolt in org.apache.storm.taskClasses in org.apache.storm.task that implement IBoltModifier and TypeClassDescriptionclassA bolt that shells out to another process to process tuples.
- 
Uses of IBolt in org.apache.storm.testingClasses in org.apache.storm.testing that implement IBoltModifier and TypeClassDescriptionclassclassclassclassclassclassclassclassConstructors in org.apache.storm.testing with parameters of type IBolt
- 
Uses of IBolt in org.apache.storm.topologySubinterfaces of IBolt in org.apache.storm.topologyModifier and TypeInterfaceDescriptioninterfaceWhen writing topologies using Java,IRichBoltandIRichSpoutare the main interfaces to use to implement components of the topology.Classes in org.apache.storm.topology that implement IBoltModifier and TypeClassDescriptionclassBase class that abstracts the common logic for executing bolts in a stateful topology.classclassWrapsIRichBoltand forwards checkpoint tuples in a stateful topology.classPersistentWindowedBoltExecutor<T extends State>Wraps aIStatefulWindowedBoltand handles the execution.classStatefulBoltExecutor<T extends State>Wraps aIStatefulBoltand manages the state of the bolt.classStatefulWindowedBoltExecutor<T extends State>Wraps aIStatefulWindowedBoltand handles the execution.classAnIWindowedBoltwrapper that does the windowing of tuples.
- 
Uses of IBolt in org.apache.storm.topology.baseClasses in org.apache.storm.topology.base that implement IBoltModifier and TypeClassDescriptionclassclassThis class is based on BaseRichBolt, but is aware of tick tuple.
- 
Uses of IBolt in org.apache.storm.trident.topologyClasses in org.apache.storm.trident.topology that implement IBolt