Uses of Interface
org.apache.storm.topology.IRichSpout
Packages that use IRichSpout
Package
Description
ElasticSearch examples classes.
-
Uses of IRichSpout in org.apache.storm
Classes 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 SpoutSpec
Thrift.prepareSerializedSpoutDetails
(IRichSpout spout, Map<String, StreamInfo> outputs) static Thrift.SpoutDetails
Thrift.prepareSpoutDetails
(IRichSpout spout) static Thrift.SpoutDetails
Thrift.prepareSpoutDetails
(IRichSpout spout, Integer parallelismHint) static Thrift.SpoutDetails
Thrift.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.clojure
Classes in org.apache.storm.clojure that implement IRichSpout -
Uses of IRichSpout in org.apache.storm.drpc
Classes in org.apache.storm.drpc that implement IRichSpout -
Uses of IRichSpout in org.apache.storm.elasticsearch.bolt
Classes in org.apache.storm.elasticsearch.bolt that implement IRichSpout -
Uses of IRichSpout in org.apache.storm.flux.model
Methods in org.apache.storm.flux.model with parameters of type IRichSpout -
Uses of IRichSpout in org.apache.storm.flux.wrappers.spouts
Classes in org.apache.storm.flux.wrappers.spouts that implement IRichSpoutModifier and TypeClassDescriptionclass
A 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.bolt
Classes in org.apache.storm.hdfs.bolt that implement IRichSpoutModifier and TypeClassDescriptionstatic class
static class
-
Uses of IRichSpout in org.apache.storm.hdfs.spout
Classes in org.apache.storm.hdfs.spout that implement IRichSpout -
Uses of IRichSpout in org.apache.storm.hive.bolt
Classes in org.apache.storm.hive.bolt that implement IRichSpoutModifier and TypeClassDescriptionstatic class
static class
static class
-
Uses of IRichSpout in org.apache.storm.jdbc.spout
Classes in org.apache.storm.jdbc.spout that implement IRichSpout -
Uses of IRichSpout in org.apache.storm.jms.spout
Classes in org.apache.storm.jms.spout that implement IRichSpoutModifier and TypeClassDescriptionclass
A StormSpout
implementation 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.spout
Classes in org.apache.storm.kafka.spout that implement IRichSpout -
Uses of IRichSpout in org.apache.storm.lambda
Classes in org.apache.storm.lambda that implement IRichSpout -
Uses of IRichSpout in org.apache.storm.loadgen
Classes in org.apache.storm.loadgen that implement IRichSpoutModifier and TypeClassDescriptionclass
A spout that simulates a real world spout based off of statistics about it.static class
-
Uses of IRichSpout in org.apache.storm.perf.spout
Classes in org.apache.storm.perf.spout that implement IRichSpoutModifier and TypeClassDescriptionclass
class
class
Spout pre-computes a list with 30k fixed length random strings.class
-
Uses of IRichSpout in org.apache.storm.redis.topology
Classes in org.apache.storm.redis.topology that implement IRichSpout -
Uses of IRichSpout in org.apache.storm.spout
Classes in org.apache.storm.spout that implement IRichSpoutModifier and TypeClassDescriptionclass
Emits checkpoint tuples which is used to save the state of theIStatefulComponent
across the topology. -
Uses of IRichSpout in org.apache.storm.sql.runtime
Methods 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.spout
Classes in org.apache.storm.sql.runtime.datasource.socket.spout that implement IRichSpout -
Uses of IRichSpout in org.apache.storm.st.topology.window
Classes in org.apache.storm.st.topology.window that implement IRichSpout -
Uses of IRichSpout in org.apache.storm.starter
Classes in org.apache.storm.starter that implement IRichSpoutModifier and TypeClassDescriptionstatic class
static class
static class
static class
static class
-
Uses of IRichSpout in org.apache.storm.starter.spout
Classes in org.apache.storm.starter.spout that implement IRichSpoutModifier and TypeClassDescriptionclass
Emits a random integer and a timestamp value (offset by one day), every 100 ms.class
static class
-
Uses of IRichSpout in org.apache.storm.streams
Methods in org.apache.storm.streams with parameters of type IRichSpoutModifier and TypeMethodDescriptionStreamBuilder.newStream
(IRichSpout spout) Creates a newStream
of tuples from the givenIRichSpout
.StreamBuilder.newStream
(IRichSpout spout, int parallelism) Creates a newStream
of tuples from the givenIRichSpout
with the given parallelism.<K,
V> PairStream<K, V> StreamBuilder.newStream
(IRichSpout spout, PairValueMapper<K, V> pairValueMapper) Creates a newPairStream
of key-value pairs from the givenIRichSpout
by 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 newPairStream
of key-value pairs from the givenIRichSpout
by extracting key and value from tuples via the suppliedPairValueMapper
and with the given value of parallelism.<T> Stream<T>
StreamBuilder.newStream
(IRichSpout spout, TupleValueMapper<T> valueMapper) Creates a newStream
of values from the givenIRichSpout
by extracting field(s) from tuples via the suppliedTupleValueMapper
.<T> Stream<T>
StreamBuilder.newStream
(IRichSpout spout, TupleValueMapper<T> valueMapper, int parallelism) Creates a newStream
of values from the givenIRichSpout
by extracting field(s) from tuples via the suppliedTupleValueMapper
with the given parallelism. -
Uses of IRichSpout in org.apache.storm.testing
Classes in org.apache.storm.testing that implement IRichSpoutModifier and TypeClassDescriptionclass
class
class
class
class
class
class
Constructors in org.apache.storm.testing with parameters of type IRichSpout -
Uses of IRichSpout in org.apache.storm.topology
Methods 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.base
Classes in org.apache.storm.topology.base that implement IRichSpout -
Uses of IRichSpout in org.apache.storm.trident
Methods in org.apache.storm.trident with parameters of type IRichSpout -
Uses of IRichSpout in org.apache.storm.trident.spout
Classes 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.topology
Classes 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)