public static interface IPartitionedTridentSpout.Emitter<Partitions,Partition extends ISpoutPartition,X>
Modifier and Type | Method and Description |
---|---|
void |
close() |
void |
emitPartitionBatch(TransactionAttempt tx,
TridentCollector collector,
Partition 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 |
emitPartitionBatchNew(TransactionAttempt tx,
TridentCollector collector,
Partition partition,
X lastPartitionMeta)
Emit a batch of tuples for a partition/transaction that’s never been emitted before.
|
List<Partition> |
getOrderedPartitions(Partitions allPartitionInfo) |
void |
refreshPartitions(List<Partition> partitionResponsibilities)
This method is called when this task is responsible for a new set of partitions.
|
List<Partition> getOrderedPartitions(Partitions allPartitionInfo)
X emitPartitionBatchNew(TransactionAttempt tx, TridentCollector collector, Partition partition, X lastPartitionMeta)
Emit a batch of tuples for a partition/transaction that’s never been emitted before. Return the metadata that can be used to reconstruct this partition/batch in the future.
void refreshPartitions(List<Partition> partitionResponsibilities)
This method is called when this task is responsible for a new set of partitions. Should be used to manage things like connections to brokers.
void emitPartitionBatch(TransactionAttempt tx, TridentCollector collector, Partition 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.
void close()
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.