Modifier and Type | Class and Description |
---|---|
static class |
ExclamationTopology.FixedOrderWordSpout |
Modifier and Type | Method and Description |
---|---|
IRichSpout |
Thrift.SpoutDetails.getSpout() |
Modifier and Type | Method and 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) |
Constructor and Description |
---|
SpoutDetails(IRichSpout spout,
Integer parallelism,
Map<String,Object> conf) |
Modifier and Type | Class and Description |
---|---|
class |
ClojureSpout |
class |
RichShellSpout |
Modifier and Type | Class and Description |
---|---|
class |
DRPCSpout |
Modifier and Type | Class and Description |
---|---|
static class |
EsIndexTopology.UserDataSpout
The user data spout.
|
Modifier and Type | Class and Description |
---|---|
class |
EventHubSpout |
Modifier and Type | Method and Description |
---|---|
void |
ExecutionContext.addSpout(String id,
IRichSpout spout) |
Modifier and Type | Class and Description |
---|---|
class |
FluxShellSpout
A generic
ShellSpout implementation that allows you specify output fields and even streams without having to subclass ShellSpout to do so. |
Modifier and Type | Class and Description |
---|---|
static class |
HdfsFileTopology.SentenceSpout |
static class |
SequenceFileTopology.SentenceSpout |
Modifier and Type | Class and Description |
---|---|
class |
HdfsSpout |
Modifier and Type | Class and Description |
---|---|
static class |
BucketTestHiveTopology.UserDataSpout |
static class |
HiveTopology.UserDataSpout |
static class |
HiveTopologyPartitioned.UserDataSpout |
Modifier and Type | Class and Description |
---|---|
class |
UserSpout |
Modifier and Type | Class and Description |
---|---|
class |
JmsSpout
A Storm
Spout implementation that listens to a JMS topic or queue and outputs tuples based on the messages it receives. |
Modifier and Type | Class and Description |
---|---|
class |
KafkaSpout<K,V> |
Modifier and Type | Class and Description |
---|---|
class |
KinesisSpout |
Modifier and Type | Class and Description |
---|---|
class |
LambdaSpout |
Modifier and Type | Class and Description |
---|---|
class |
LoadSpout
A spout that simulates a real world spout based off of statistics about it.
|
static class |
ThroughputVsLatency.FastRandomSentenceSpout |
Modifier and Type | Class and Description |
---|---|
class |
WordSpout |
Modifier and Type | Class and Description |
---|---|
class |
MqttSpout |
Modifier and Type | Class and Description |
---|---|
class |
MetricGenSpout
Spout to generate tuples containing metric data.
|
Modifier and Type | Class and Description |
---|---|
class |
ConstSpout |
class |
FileReadSpout |
class |
StringGenSpout
Spout pre-computes a list with 30k fixed length random strings.
|
class |
WordGenSpout |
Modifier and Type | Class and Description |
---|---|
class |
RawInputFromCSVSpout |
Modifier and Type | Class and Description |
---|---|
class |
RocketMqSpout
RocketMqSpout uses MQPushConsumer as the default implementation.
|
Modifier and Type | Class and Description |
---|---|
class |
SolrFieldsSpout |
class |
SolrJsonSpout |
Modifier and Type | Class and Description |
---|---|
class |
CheckpointSpout
Emits checkpoint tuples which is used to save the state of the
IStatefulComponent across the topology. |
Modifier and Type | Method and Description |
---|---|
IRichSpout |
ISqlStreamsDataSource.getProducer()
Provides instance of IRichSpout which can be used as producer in topology.
|
Modifier and Type | Class and Description |
---|---|
class |
SocketSpout
Spout for Socket data.
|
Modifier and Type | Class and Description |
---|---|
class |
IncrementingSpout |
class |
TimeDataIncrementingSpout |
Modifier and Type | Class and Description |
---|---|
static class |
AnchoredWordCount.RandomSentenceSpout |
static class |
BlobStoreAPIWordCountTopology.RandomSentenceSpout |
static class |
FastWordCountTopology.FastRandomSentenceSpout |
static class |
InOrderDeliveryTest.InOrderSpout |
static class |
WordCountTopologyNode.RandomSentence |
Modifier and Type | Class and Description |
---|---|
class |
RandomIntegerSpout
Emits a random integer and a timestamp value (offset by one day), every 100 ms.
|
class |
RandomSentenceSpout |
static class |
RandomSentenceSpout.TimeStamped |
Modifier and Type | Method and Description |
---|---|
Stream<Tuple> |
StreamBuilder.newStream(IRichSpout spout)
Creates a new
Stream of tuples from the given IRichSpout . |
Stream<Tuple> |
StreamBuilder.newStream(IRichSpout spout,
int parallelism)
Creates a new
Stream of tuples from the given IRichSpout with the given parallelism. |
<K,V> PairStream<K,V> |
StreamBuilder.newStream(IRichSpout spout,
PairValueMapper<K,V> pairValueMapper)
Creates a new
PairStream of key-value pairs from the given IRichSpout by extracting key and value from tuples via the supplied PairValueMapper . |
<K,V> PairStream<K,V> |
StreamBuilder.newStream(IRichSpout spout,
PairValueMapper<K,V> pairValueMapper,
int parallelism)
Creates a new
PairStream of key-value pairs from the given IRichSpout by extracting key and value from tuples via the supplied PairValueMapper and with the given value of parallelism. |
<T> Stream<T> |
StreamBuilder.newStream(IRichSpout spout,
TupleValueMapper<T> valueMapper)
Creates a new
Stream of values from the given IRichSpout by extracting field(s) from tuples via the supplied TupleValueMapper . |
<T> Stream<T> |
StreamBuilder.newStream(IRichSpout spout,
TupleValueMapper<T> valueMapper,
int parallelism)
Creates a new
Stream of values from the given IRichSpout by extracting field(s) from tuples via the supplied TupleValueMapper with the given parallelism. |
Modifier and Type | Class and Description |
---|---|
class |
FeederSpout |
class |
FixedTupleSpout |
class |
PythonShellMetricsSpout |
class |
SpoutTracker |
class |
TestEventLogSpout |
class |
TestPlannerSpout |
class |
TestWordSpout |
Constructor and Description |
---|
SpoutTracker(IRichSpout delegate,
String trackId) |
Modifier and Type | Method and 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.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseRichSpout |
Modifier and Type | Method and Description |
---|---|
Stream |
TridentTopology.newStream(String txId,
IRichSpout spout) |
Modifier and Type | Class and Description |
---|---|
class |
RichSpoutBatchTriggerer |
Constructor and Description |
---|
RichSpoutBatchExecutor(IRichSpout spout) |
RichSpoutBatchTriggerer(IRichSpout delegate,
String streamName,
String batchGroup) |
Modifier and Type | Class and Description |
---|---|
class |
MasterBatchCoordinator |
Modifier and Type | Method and Description |
---|---|
SpoutDeclarer |
TridentTopologyBuilder.setBatchPerTupleSpout(String id,
String streamName,
IRichSpout spout,
Integer parallelism,
String batchGroup) |
Copyright © 2022 The Apache Software Foundation. All rights reserved.