Uses of Interface
org.apache.storm.trident.spout.ITridentDataSource
-
-
Uses of ITridentDataSource in org.apache.storm.hdfs.trident
Classes in org.apache.storm.hdfs.trident that implement ITridentDataSource Modifier and Type Class Description class
FixedBatchSpout
-
Uses of ITridentDataSource in org.apache.storm.hive.trident
Classes in org.apache.storm.hive.trident that implement ITridentDataSource Modifier and Type Class Description static class
TridentHiveTopology.FixedBatchSpout
-
Uses of ITridentDataSource in org.apache.storm.jms.trident
Classes in org.apache.storm.jms.trident that implement ITridentDataSource Modifier and Type Class Description class
TridentJmsSpout
Trident implementation of the JmsSpout. -
Uses of ITridentDataSource in org.apache.storm.kafka.spout.trident
Classes in org.apache.storm.kafka.spout.trident that implement ITridentDataSource Modifier and Type Class Description class
KafkaTridentSpoutOpaque<K,V>
class
KafkaTridentSpoutTransactional<K,V>
-
Uses of ITridentDataSource in org.apache.storm.kafka.trident
Methods in org.apache.storm.kafka.trident with parameters of type ITridentDataSource Modifier and Type Method Description static StormTopology
TridentKafkaConsumerTopology. newTopology(ITridentDataSource tridentSpout)
Creates a new topology that prints inputs to stdout. -
Uses of ITridentDataSource in org.apache.storm.starter.spout
Classes in org.apache.storm.starter.spout that implement ITridentDataSource Modifier and Type Class Description class
RandomNumberGeneratorSpout
This spout generates random whole numbers with givenmaxNumber
value as maximum with the givenfields
. -
Uses of ITridentDataSource in org.apache.storm.trident
Methods in org.apache.storm.trident with parameters of type ITridentDataSource Modifier and Type Method Description Stream
TridentTopology. newStream(String txId, ITridentDataSource dataSource)
-
Uses of ITridentDataSource in org.apache.storm.trident.spout
Subinterfaces of ITridentDataSource in org.apache.storm.trident.spout Modifier and Type Interface Description interface
IBatchSpout
interface
ICommitterTridentSpout<X>
interface
IOpaquePartitionedTridentSpout<PartitionsT,PartitionT 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<PartitionsT,PartitionT extends ISpoutPartition,T>
This interface defines a transactional spout that reads its tuples from a partitioned set of brokers.interface
ITridentSpout<T>
Classes in org.apache.storm.trident.spout that implement ITridentDataSource Modifier and Type Class Description class
BatchSpoutExecutor
class
OpaquePartitionedTridentSpoutExecutor
class
PartitionedTridentSpoutExecutor
class
RichSpoutBatchExecutor
-
Uses of ITridentDataSource in org.apache.storm.trident.testing
Classes in org.apache.storm.trident.testing that implement ITridentDataSource Modifier and Type Class Description class
FeederBatchSpout
class
FeederCommitterBatchSpout
class
FixedBatchSpout
-