Uses of Interface
org.apache.storm.topology.IRichSpout
-
-
Uses of IRichSpout in org.apache.storm
Classes in org.apache.storm that implement IRichSpout Modifier and Type Class Description static class
ExclamationTopology.FixedOrderWordSpout
Methods in org.apache.storm that return IRichSpout Modifier and Type Method Description IRichSpout
Thrift.SpoutDetails. getSpout()
Methods in org.apache.storm with parameters of type IRichSpout Modifier and Type Method Description static 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 IRichSpout Constructor Description SpoutDetails(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 Modifier and Type Class Description class
ClojureSpout
class
RichShellSpout
-
Uses of IRichSpout in org.apache.storm.drpc
Classes in org.apache.storm.drpc that implement IRichSpout Modifier and Type Class Description class
DRPCSpout
-
Uses of IRichSpout in org.apache.storm.flux.model
Methods in org.apache.storm.flux.model with parameters of type IRichSpout Modifier and Type Method Description void
ExecutionContext. addSpout(String id, IRichSpout spout)
-
Uses of IRichSpout in org.apache.storm.flux.wrappers.spouts
Classes in org.apache.storm.flux.wrappers.spouts that implement IRichSpout Modifier and Type Class Description class
FluxShellSpout
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 IRichSpout Modifier and Type Class Description static class
HdfsFileTopology.SentenceSpout
static class
SequenceFileTopology.SentenceSpout
-
Uses of IRichSpout in org.apache.storm.hdfs.spout
Classes in org.apache.storm.hdfs.spout that implement IRichSpout Modifier and Type Class Description class
HdfsSpout
-
Uses of IRichSpout in org.apache.storm.hive.bolt
Classes in org.apache.storm.hive.bolt that implement IRichSpout Modifier and Type Class Description static class
BucketTestHiveTopology.UserDataSpout
static class
HiveTopology.UserDataSpout
static class
HiveTopologyPartitioned.UserDataSpout
-
Uses of IRichSpout in org.apache.storm.jdbc.spout
Classes in org.apache.storm.jdbc.spout that implement IRichSpout Modifier and Type Class Description class
UserSpout
-
Uses of IRichSpout in org.apache.storm.jms.spout
Classes in org.apache.storm.jms.spout that implement IRichSpout Modifier and Type Class Description class
JmsSpout
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 Modifier and Type Class Description class
KafkaSpout<K,V>
-
Uses of IRichSpout in org.apache.storm.lambda
Classes in org.apache.storm.lambda that implement IRichSpout Modifier and Type Class Description class
LambdaSpout
-
Uses of IRichSpout in org.apache.storm.loadgen
Classes in org.apache.storm.loadgen that implement IRichSpout Modifier and Type Class Description class
LoadSpout
A spout that simulates a real world spout based off of statistics about it.static class
ThroughputVsLatency.FastRandomSentenceSpout
-
Uses of IRichSpout in org.apache.storm.perf.spout
Classes in org.apache.storm.perf.spout that implement IRichSpout Modifier and Type Class Description class
ConstSpout
class
FileReadSpout
class
StringGenSpout
Spout pre-computes a list with 30k fixed length random strings.class
WordGenSpout
-
Uses of IRichSpout in org.apache.storm.redis.topology
Classes in org.apache.storm.redis.topology that implement IRichSpout Modifier and Type Class Description class
WordSpout
-
Uses of IRichSpout in org.apache.storm.spout
Classes in org.apache.storm.spout that implement IRichSpout Modifier and Type Class Description class
CheckpointSpout
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 IRichSpout Modifier and Type Method Description IRichSpout
ISqlStreamsDataSource. 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 Modifier and Type Class Description class
SocketSpout
Spout for Socket data. -
Uses of IRichSpout in org.apache.storm.st.topology.window
Classes in org.apache.storm.st.topology.window that implement IRichSpout Modifier and Type Class Description class
IncrementingSpout
class
TimeDataIncrementingSpout
-
Uses of IRichSpout in org.apache.storm.starter
Classes in org.apache.storm.starter that implement IRichSpout Modifier and Type Class Description static class
AnchoredWordCount.RandomSentenceSpout
static class
BlobStoreAPIWordCountTopology.RandomSentenceSpout
static class
FastWordCountTopology.FastRandomSentenceSpout
static class
InOrderDeliveryTest.InOrderSpout
static class
WordCountTopologyNode.RandomSentence
-
Uses of IRichSpout in org.apache.storm.starter.spout
Classes in org.apache.storm.starter.spout that implement IRichSpout Modifier and Type Class Description class
RandomIntegerSpout
Emits a random integer and a timestamp value (offset by one day), every 100 ms.class
RandomSentenceSpout
static class
RandomSentenceSpout.TimeStamped
-
Uses of IRichSpout in org.apache.storm.streams
Methods in org.apache.storm.streams with parameters of type IRichSpout Modifier and Type Method Description Stream<Tuple>
StreamBuilder. newStream(IRichSpout spout)
Creates a newStream
of tuples from the givenIRichSpout
.Stream<Tuple>
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 IRichSpout Modifier and Type Class Description class
FeederSpout
class
FixedTupleSpout
class
PythonShellMetricsSpout
class
SpoutTracker
class
TestEventLogSpout
class
TestPlannerSpout
class
TestWordSpout
Constructors in org.apache.storm.testing with parameters of type IRichSpout Constructor Description SpoutTracker(IRichSpout delegate, String trackId)
-
Uses of IRichSpout in org.apache.storm.topology
Methods in org.apache.storm.topology with parameters of type IRichSpout Modifier and Type Method Description SpoutDeclarer
TopologyBuilder. setSpout(String id, IRichSpout spout)
Define a new spout in this topology.SpoutDeclarer
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 Modifier and Type Class Description class
BaseRichSpout
-
Uses of IRichSpout in org.apache.storm.trident
Methods in org.apache.storm.trident with parameters of type IRichSpout Modifier and Type Method Description Stream
TridentTopology. newStream(String txId, IRichSpout spout)
-
Uses of IRichSpout in org.apache.storm.trident.spout
Classes in org.apache.storm.trident.spout that implement IRichSpout Modifier and Type Class Description class
RichSpoutBatchTriggerer
Constructors in org.apache.storm.trident.spout with parameters of type IRichSpout Constructor Description RichSpoutBatchExecutor(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 IRichSpout Modifier and Type Class Description class
MasterBatchCoordinator
Methods in org.apache.storm.trident.topology with parameters of type IRichSpout Modifier and Type Method Description SpoutDeclarer
TridentTopologyBuilder. setBatchPerTupleSpout(String id, String streamName, IRichSpout spout, Integer parallelism, String batchGroup)
-