Uses of Interface
org.apache.storm.topology.IRichSpout
Packages that use IRichSpout
Package
Description
- 
Uses of IRichSpout in org.apache.stormClasses in org.apache.storm that implement IRichSpoutMethods in org.apache.storm that return IRichSpoutMethods in org.apache.storm with parameters of type IRichSpoutModifier and TypeMethodDescriptionstatic SpoutSpecThrift.prepareSerializedSpoutDetails(IRichSpout spout, Map<String, StreamInfo> outputs) static Thrift.SpoutDetailsThrift.prepareSpoutDetails(IRichSpout spout) static Thrift.SpoutDetailsThrift.prepareSpoutDetails(IRichSpout spout, Integer parallelismHint) static Thrift.SpoutDetailsThrift.prepareSpoutDetails(IRichSpout spout, Integer parallelismHint, Map<String, Object> conf) Constructors in org.apache.storm with parameters of type IRichSpoutModifierConstructorDescriptionSpoutDetails(IRichSpout spout, Integer parallelism, Map<String, Object> conf) 
- 
Uses of IRichSpout in org.apache.storm.clojureClasses in org.apache.storm.clojure that implement IRichSpout
- 
Uses of IRichSpout in org.apache.storm.drpcClasses in org.apache.storm.drpc that implement IRichSpout
- 
Uses of IRichSpout in org.apache.storm.flux.modelMethods in org.apache.storm.flux.model with parameters of type IRichSpout
- 
Uses of IRichSpout in org.apache.storm.flux.wrappers.spoutsClasses in org.apache.storm.flux.wrappers.spouts that implement IRichSpoutModifier and TypeClassDescriptionclassA generic `ShellSpout` implementation that allows you specify output fields and even streams without having to subclass `ShellSpout` to do so.
- 
Uses of IRichSpout in org.apache.storm.hdfs.boltClasses in org.apache.storm.hdfs.bolt that implement IRichSpoutModifier and TypeClassDescriptionstatic classstatic class
- 
Uses of IRichSpout in org.apache.storm.hdfs.spoutClasses in org.apache.storm.hdfs.spout that implement IRichSpout
- 
Uses of IRichSpout in org.apache.storm.jdbc.spoutClasses in org.apache.storm.jdbc.spout that implement IRichSpout
- 
Uses of IRichSpout in org.apache.storm.jms.spoutClasses in org.apache.storm.jms.spout that implement IRichSpoutModifier and TypeClassDescriptionclassA StormSpoutimplementation that listens to a JMS topic or queue and outputs tuples based on the messages it receives.
- 
Uses of IRichSpout in org.apache.storm.kafka.spoutClasses in org.apache.storm.kafka.spout that implement IRichSpout
- 
Uses of IRichSpout in org.apache.storm.lambdaClasses in org.apache.storm.lambda that implement IRichSpout
- 
Uses of IRichSpout in org.apache.storm.loadgenClasses in org.apache.storm.loadgen that implement IRichSpoutModifier and TypeClassDescriptionclassA spout that simulates a real world spout based off of statistics about it.static class
- 
Uses of IRichSpout in org.apache.storm.perf.spoutClasses in org.apache.storm.perf.spout that implement IRichSpoutModifier and TypeClassDescriptionclassclassclassSpout pre-computes a list with 30k fixed length random strings.class
- 
Uses of IRichSpout in org.apache.storm.redis.topologyClasses in org.apache.storm.redis.topology that implement IRichSpout
- 
Uses of IRichSpout in org.apache.storm.spoutClasses in org.apache.storm.spout that implement IRichSpoutModifier and TypeClassDescriptionclassEmits checkpoint tuples which is used to save the state of theIStatefulComponentacross the topology.
- 
Uses of IRichSpout in org.apache.storm.sql.runtimeMethods in org.apache.storm.sql.runtime that return IRichSpoutModifier and TypeMethodDescriptionISqlStreamsDataSource.getProducer()Provides instance of IRichSpout which can be used as producer in topology.
- 
Uses of IRichSpout in org.apache.storm.sql.runtime.datasource.socket.spoutClasses in org.apache.storm.sql.runtime.datasource.socket.spout that implement IRichSpout
- 
Uses of IRichSpout in org.apache.storm.st.topology.windowClasses in org.apache.storm.st.topology.window that implement IRichSpout
- 
Uses of IRichSpout in org.apache.storm.starterClasses in org.apache.storm.starter that implement IRichSpoutModifier and TypeClassDescriptionstatic classstatic classstatic classstatic classstatic class
- 
Uses of IRichSpout in org.apache.storm.starter.spoutClasses in org.apache.storm.starter.spout that implement IRichSpoutModifier and TypeClassDescriptionclassEmits a random integer and a timestamp value (offset by one day), every 100 ms.classstatic class
- 
Uses of IRichSpout in org.apache.storm.streamsMethods in org.apache.storm.streams with parameters of type IRichSpoutModifier and TypeMethodDescriptionStreamBuilder.newStream(IRichSpout spout) Creates a newStreamof tuples from the givenIRichSpout.StreamBuilder.newStream(IRichSpout spout, int parallelism) Creates a newStreamof tuples from the givenIRichSpoutwith the given parallelism.<K,V> PairStream<K, V> StreamBuilder.newStream(IRichSpout spout, PairValueMapper<K, V> pairValueMapper) Creates a newPairStreamof key-value pairs from the givenIRichSpoutby extracting key and value from tuples via the suppliedPairValueMapper.<K,V> PairStream<K, V> StreamBuilder.newStream(IRichSpout spout, PairValueMapper<K, V> pairValueMapper, int parallelism) Creates a newPairStreamof key-value pairs from the givenIRichSpoutby extracting key and value from tuples via the suppliedPairValueMapperand with the given value of parallelism.<T> Stream<T>StreamBuilder.newStream(IRichSpout spout, TupleValueMapper<T> valueMapper) Creates a newStreamof values from the givenIRichSpoutby extracting field(s) from tuples via the suppliedTupleValueMapper.<T> Stream<T>StreamBuilder.newStream(IRichSpout spout, TupleValueMapper<T> valueMapper, int parallelism) Creates a newStreamof values from the givenIRichSpoutby extracting field(s) from tuples via the suppliedTupleValueMapperwith the given parallelism.
- 
Uses of IRichSpout in org.apache.storm.testingClasses in org.apache.storm.testing that implement IRichSpoutModifier and TypeClassDescriptionclassclassclassclassclassclassclassConstructors in org.apache.storm.testing with parameters of type IRichSpout
- 
Uses of IRichSpout in org.apache.storm.topologyMethods in org.apache.storm.topology with parameters of type IRichSpoutModifier and TypeMethodDescriptionTopologyBuilder.setSpout(String id, IRichSpout spout) Define a new spout in this topology.TopologyBuilder.setSpout(String id, IRichSpout spout, Number parallelismHint) Define a new spout in this topology with the specified parallelism.
- 
Uses of IRichSpout in org.apache.storm.topology.baseClasses in org.apache.storm.topology.base that implement IRichSpout
- 
Uses of IRichSpout in org.apache.storm.tridentMethods in org.apache.storm.trident with parameters of type IRichSpout
- 
Uses of IRichSpout in org.apache.storm.trident.spoutClasses in org.apache.storm.trident.spout that implement IRichSpoutConstructors in org.apache.storm.trident.spout with parameters of type IRichSpoutModifierConstructorDescriptionRichSpoutBatchExecutor(IRichSpout spout) RichSpoutBatchTriggerer(IRichSpout delegate, String streamName, String batchGroup) 
- 
Uses of IRichSpout in org.apache.storm.trident.topologyClasses in org.apache.storm.trident.topology that implement IRichSpoutMethods in org.apache.storm.trident.topology with parameters of type IRichSpoutModifier and TypeMethodDescriptionTridentTopologyBuilder.setBatchPerTupleSpout(String id, String streamName, IRichSpout spout, Integer parallelism, String batchGroup)