| Package | Description | 
|---|---|
| org.apache.storm.eventhubs.trident | |
| org.apache.storm.kafka.spout.trident | |
| org.apache.storm.trident.spout | 
| Modifier and Type | Method and Description | 
|---|---|
| Map | OpaqueTridentEventHubEmitter. emitPartitionBatch(TransactionAttempt attempt,
                  TridentCollector collector,
                  Partition partition,
                  Map meta) | 
| void | TransactionalTridentEventHubEmitter. emitPartitionBatch(TransactionAttempt attempt,
                  TridentCollector collector,
                  Partition partition,
                  Map<String,Object> meta) | 
| Map<String,Object> | TransactionalTridentEventHubEmitter. emitPartitionBatchNew(TransactionAttempt attempt,
                     TridentCollector collector,
                     Partition partition,
                     Map<String,Object> meta) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ICommitterTridentSpout.Emitter. commit(TransactionAttempt attempt) | 
| void | OpaquePartitionedTridentSpoutExecutor.Emitter. commit(TransactionAttempt attempt) | 
| void | OpaquePartitionedTridentSpoutExecutor.Emitter. emitBatch(TransactionAttempt tx,
         Object coordinatorMeta,
         TridentCollector collector) | 
| void | BatchSpoutExecutor.BatchSpoutEmitter. emitBatch(TransactionAttempt tx,
         Object coordinatorMeta,
         TridentCollector collector) | 
| void | ITridentSpout.Emitter. emitBatch(TransactionAttempt tx,
         X coordinatorMeta,
         TridentCollector collector)Emit a batch for the specified transaction attempt and metadata for the transaction. | 
| M | IOpaquePartitionedTridentSpout.Emitter. emitPartitionBatch(TransactionAttempt tx,
                  TridentCollector collector,
                  PartitionT partition,
                  M lastPartitionMeta)Emit a batch of tuples for a partition/transaction. | 
| void | IPartitionedTridentSpout.Emitter. emitPartitionBatch(TransactionAttempt tx,
                  TridentCollector collector,
                  PartitionT partition,
                  X partitionMeta)Emit a batch of tuples for a partition/transaction that has been emitted before, using the metadata created when it was first emitted. | 
| X | IPartitionedTridentSpout.Emitter. emitPartitionBatchNew(TransactionAttempt tx,
                     TridentCollector collector,
                     PartitionT partition,
                     X lastPartitionMeta)Emit a batch of tuples for a partition/transaction that’s never been emitted before. | 
| void | ITridentSpout.Emitter. success(TransactionAttempt tx)This attempt committed successfully, so all state for this commit and before can be safely cleaned up. | 
| void | OpaquePartitionedTridentSpoutExecutor.Emitter. success(TransactionAttempt tx) | 
| void | BatchSpoutExecutor.BatchSpoutEmitter. success(TransactionAttempt tx) | 
Copyright © 2022 The Apache Software Foundation. All rights reserved.