Uses of Interface
org.apache.storm.topology.IRichSpout
Package
Description
ElasticSearch examples classes.
-
Uses of IRichSpout in org.apache.storm
Modifier 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) ModifierConstructorDescriptionSpoutDetails
(IRichSpout spout, Integer parallelism, Map<String, Object> conf) -
Uses of IRichSpout in org.apache.storm.clojure
-
Uses of IRichSpout in org.apache.storm.drpc
-
Uses of IRichSpout in org.apache.storm.elasticsearch.bolt
-
Uses of IRichSpout in org.apache.storm.flux.model
-
Uses of IRichSpout in org.apache.storm.flux.wrappers.spouts
Modifier 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
Modifier and TypeClassDescriptionstatic class
static class
-
Uses of IRichSpout in org.apache.storm.hdfs.spout
-
Uses of IRichSpout in org.apache.storm.hive.bolt
Modifier and TypeClassDescriptionstatic class
static class
static class
-
Uses of IRichSpout in org.apache.storm.jdbc.spout
-
Uses of IRichSpout in org.apache.storm.jms.spout
Modifier 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
-
Uses of IRichSpout in org.apache.storm.lambda
-
Uses of IRichSpout in org.apache.storm.loadgen
Modifier 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
Modifier 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
-
Uses of IRichSpout in org.apache.storm.spout
Modifier 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
Modifier 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
-
Uses of IRichSpout in org.apache.storm.st.topology.window
-
Uses of IRichSpout in org.apache.storm.starter
Modifier and TypeClassDescriptionstatic class
static class
static class
static class
static class
-
Uses of IRichSpout in org.apache.storm.starter.spout
Modifier 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
Modifier 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
Modifier and TypeClassDescriptionclass
class
class
class
class
class
class
-
Uses of IRichSpout in org.apache.storm.topology
Modifier 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
-
Uses of IRichSpout in org.apache.storm.trident
-
Uses of IRichSpout in org.apache.storm.trident.spout
ModifierConstructorDescriptionRichSpoutBatchExecutor
(IRichSpout spout) RichSpoutBatchTriggerer
(IRichSpout delegate, String streamName, String batchGroup) -
Uses of IRichSpout in org.apache.storm.trident.topology
Modifier and TypeMethodDescriptionTridentTopologyBuilder.setBatchPerTupleSpout
(String id, String streamName, IRichSpout spout, Integer parallelism, String batchGroup)