Modifier and Type | Class and Description |
---|---|
static class |
TridentEsTopology.FixedBatchSpout |
Modifier and Type | Class and Description |
---|---|
class |
OpaqueTridentEventHubSpout
Opaque Trident EventHubs Spout
|
class |
TransactionalTridentEventHubSpout
Transactional Trident EventHub Spout
|
Modifier and Type | Class and Description |
---|---|
static class |
TridentHiveTopology.FixedBatchSpout |
Modifier and Type | Class and Description |
---|---|
class |
TridentJmsSpout
Trident implementation of the JmsSpout
|
Modifier and Type | Class and Description |
---|---|
class |
KafkaTridentSpoutOpaque<K,V> |
class |
KafkaTridentSpoutTransactional |
Modifier and Type | Class and Description |
---|---|
class |
OpaqueTridentKafkaSpout
Deprecated.
storm-kafka has been deprecated and will be removed in a future Storm release. Please upgrade to storm-kafka-client. If you need to migrate the committed offsets to the new spout, consider using the storm-kafka-migration tool.
|
class |
TransactionalTridentKafkaSpout
Deprecated.
storm-kafka has been deprecated and will be removed in a future Storm release. Please upgrade to storm-kafka-client. If you need to migrate the committed offsets to the new spout, consider using the storm-kafka-migration tool.
|
Modifier and Type | Method and Description |
---|---|
static StormTopology |
TridentKafkaConsumerTopology.newTopology(ITridentDataSource tridentSpout)
|
static StormTopology |
TridentKafkaConsumerTopology.newTopology(org.apache.storm.LocalDRPC drpc,
ITridentDataSource tridentSpout) |
Modifier and Type | Class and Description |
---|---|
class |
MetricGenBatchSpout
BatchSpout implementation for metrics generation.
|
Modifier and Type | Method and Description |
---|---|
ITridentDataSource |
ISqlTridentDataSource.getProducer()
Provides instance of ITridentDataSource which can be used as producer in Trident.
|
Modifier and Type | Class and Description |
---|---|
class |
TridentSocketSpout
Trident Spout for Socket data.
|
Modifier and Type | Class and Description |
---|---|
class |
RandomNumberGeneratorSpout
This spout generates random whole numbers with given
maxNumber value as maximum with the given fields . |
Modifier and Type | Method and Description |
---|---|
Stream |
TridentTopology.newStream(String txId,
ITridentDataSource dataSource) |
Modifier and Type | Interface and Description |
---|---|
interface |
IBatchSpout |
interface |
ICommitterTridentSpout<X> |
interface |
IOpaquePartitionedTridentSpout<Partitions,Partition extends ISpoutPartition,M>
This defines a transactional spout which does not necessarily replay the same batch every time it emits a batch for a transaction id.
|
interface |
IPartitionedTridentSpout<Partitions,Partition extends ISpoutPartition,T>
This interface defines a transactional spout that reads its tuples from a partitioned set of brokers.
|
interface |
ITridentSpout<T> |
Modifier and Type | Class and Description |
---|---|
class |
BatchSpoutExecutor |
class |
OpaquePartitionedTridentSpoutExecutor |
class |
PartitionedTridentSpoutExecutor |
class |
RichSpoutBatchExecutor |
Modifier and Type | Class and Description |
---|---|
class |
FeederBatchSpout |
class |
FeederCommitterBatchSpout |
class |
FixedBatchSpout |
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.