Uses of Interface
org.apache.storm.spout.ISpout
-
-
Uses of ISpout in org.apache.storm
Classes in org.apache.storm that implement ISpout Modifier and Type Class Description static class
ExclamationTopology.FixedOrderWordSpout
-
Uses of ISpout in org.apache.storm.clojure
Classes in org.apache.storm.clojure that implement ISpout Modifier and Type Class Description class
ClojureSpout
class
RichShellSpout
-
Uses of ISpout in org.apache.storm.drpc
Classes in org.apache.storm.drpc that implement ISpout Modifier and Type Class Description class
DRPCSpout
-
Uses of ISpout in org.apache.storm.executor.spout
Constructors in org.apache.storm.executor.spout with parameters of type ISpout Constructor Description SpoutOutputCollectorImpl(ISpout spout, SpoutExecutor executor, Task taskData, MutableLong emittedCount, boolean hasAckers, Random random, Boolean isEventLoggers, Boolean isDebug, RotatingMap<Long,TupleInfo> pending)
-
Uses of ISpout in org.apache.storm.flux.wrappers.spouts
Classes in org.apache.storm.flux.wrappers.spouts that implement ISpout 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 ISpout in org.apache.storm.hdfs.bolt
Classes in org.apache.storm.hdfs.bolt that implement ISpout Modifier and Type Class Description static class
HdfsFileTopology.SentenceSpout
static class
SequenceFileTopology.SentenceSpout
-
Uses of ISpout in org.apache.storm.hdfs.spout
Classes in org.apache.storm.hdfs.spout that implement ISpout Modifier and Type Class Description class
HdfsSpout
-
Uses of ISpout in org.apache.storm.hive.bolt
Classes in org.apache.storm.hive.bolt that implement ISpout Modifier and Type Class Description static class
BucketTestHiveTopology.UserDataSpout
static class
HiveTopology.UserDataSpout
static class
HiveTopologyPartitioned.UserDataSpout
-
Uses of ISpout in org.apache.storm.jdbc.spout
Classes in org.apache.storm.jdbc.spout that implement ISpout Modifier and Type Class Description class
UserSpout
-
Uses of ISpout in org.apache.storm.jms.spout
Classes in org.apache.storm.jms.spout that implement ISpout 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 ISpout in org.apache.storm.kafka.spout
Classes in org.apache.storm.kafka.spout that implement ISpout Modifier and Type Class Description class
KafkaSpout<K,V>
-
Uses of ISpout in org.apache.storm.lambda
Classes in org.apache.storm.lambda that implement ISpout Modifier and Type Class Description class
LambdaSpout
-
Uses of ISpout in org.apache.storm.loadgen
Classes in org.apache.storm.loadgen that implement ISpout 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 ISpout in org.apache.storm.perf.spout
Classes in org.apache.storm.perf.spout that implement ISpout 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 ISpout in org.apache.storm.redis.topology
Classes in org.apache.storm.redis.topology that implement ISpout Modifier and Type Class Description class
WordSpout
-
Uses of ISpout in org.apache.storm.spout
Classes in org.apache.storm.spout that implement ISpout Modifier and Type Class Description class
CheckpointSpout
Emits checkpoint tuples which is used to save the state of theIStatefulComponent
across the topology.class
ShellSpout
-
Uses of ISpout in org.apache.storm.sql.runtime.datasource.socket.spout
Classes in org.apache.storm.sql.runtime.datasource.socket.spout that implement ISpout Modifier and Type Class Description class
SocketSpout
Spout for Socket data. -
Uses of ISpout in org.apache.storm.st.topology.window
Classes in org.apache.storm.st.topology.window that implement ISpout Modifier and Type Class Description class
IncrementingSpout
class
TimeDataIncrementingSpout
-
Uses of ISpout in org.apache.storm.starter
Classes in org.apache.storm.starter that implement ISpout 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 ISpout in org.apache.storm.starter.spout
Classes in org.apache.storm.starter.spout that implement ISpout 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 ISpout in org.apache.storm.testing
Classes in org.apache.storm.testing that implement ISpout Modifier and Type Class Description class
FeederSpout
class
FixedTupleSpout
class
PythonShellMetricsSpout
class
SpoutTracker
class
TestEventLogSpout
class
TestPlannerSpout
class
TestWordSpout
-
Uses of ISpout in org.apache.storm.topology
Subinterfaces of ISpout in org.apache.storm.topology Modifier and Type Interface Description interface
IRichSpout
When writing topologies using Java,IRichBolt
andIRichSpout
are the main interfaces to use to implement components of the topology. -
Uses of ISpout in org.apache.storm.topology.base
Classes in org.apache.storm.topology.base that implement ISpout Modifier and Type Class Description class
BaseRichSpout
-
Uses of ISpout in org.apache.storm.trident.spout
Classes in org.apache.storm.trident.spout that implement ISpout Modifier and Type Class Description class
RichSpoutBatchTriggerer
-
Uses of ISpout in org.apache.storm.trident.topology
Classes in org.apache.storm.trident.topology that implement ISpout Modifier and Type Class Description class
MasterBatchCoordinator
-