Class KafkaTridentSpoutEmitter<K,V>
java.lang.Object
org.apache.storm.kafka.spout.trident.KafkaTridentSpoutEmitter<K,V>
- All Implemented Interfaces:
Serializable
- See Also:
-
Constructor Summary
ConstructorDescriptionKafkaTridentSpoutEmitter
(KafkaTridentSpoutConfig<K, V> kafkaSpoutConfig, TopologyContext topologyContext) Create a new Kafka spout emitter. -
Method Summary
Modifier and TypeMethodDescriptionvoid
close()
emitPartitionBatchNew
(TransactionAttempt tx, TridentCollector collector, KafkaTridentSpoutTopicPartition currBatchPartition, Map<String, Object> lastBatch) Emit a new batch.getOrderedPartitions
(List<Map<String, Object>> allPartitionInfo) Get the input partitions in sorted order.getPartitionsForTask
(int taskId, int numTasks, List<KafkaTridentSpoutTopicPartition> allPartitionInfoSorted) Get the partitions that should be handled by this task.void
reEmitPartitionBatch
(TransactionAttempt tx, TridentCollector collector, KafkaTridentSpoutTopicPartition currBatchPartition, Map<String, Object> currBatch) Emit a batch that has already been emitted.void
refreshPartitions
(List<KafkaTridentSpoutTopicPartition> partitionResponsibilities) Prepare the emitter to handle the input partitions.final String
toString()
-
Constructor Details
-
KafkaTridentSpoutEmitter
public KafkaTridentSpoutEmitter(KafkaTridentSpoutConfig<K, V> kafkaSpoutConfig, TopologyContext topologyContext) Create a new Kafka spout emitter.- Parameters:
kafkaSpoutConfig
- The kafka spout configtopologyContext
- The topology context
-
-
Method Details
-
reEmitPartitionBatch
public void reEmitPartitionBatch(TransactionAttempt tx, TridentCollector collector, KafkaTridentSpoutTopicPartition currBatchPartition, Map<String, Object> currBatch) Emit a batch that has already been emitted. -
emitPartitionBatchNew
public Map<String,Object> emitPartitionBatchNew(TransactionAttempt tx, TridentCollector collector, KafkaTridentSpoutTopicPartition currBatchPartition, Map<String, Object> lastBatch) Emit a new batch. -
getOrderedPartitions
public List<KafkaTridentSpoutTopicPartition> getOrderedPartitions(List<Map<String, Object>> allPartitionInfo) Get the input partitions in sorted order. -
getPartitionsForTask
public List<KafkaTridentSpoutTopicPartition> getPartitionsForTask(int taskId, int numTasks, List<KafkaTridentSpoutTopicPartition> allPartitionInfoSorted) Get the partitions that should be handled by this task. -
refreshPartitions
Prepare the emitter to handle the input partitions. -
close
public void close() -
toString
-