Class KafkaTridentOpaqueSpoutEmitter<K,V> 
java.lang.Object
org.apache.storm.kafka.spout.trident.KafkaTridentOpaqueSpoutEmitter<K,V> 
- All Implemented Interfaces:
- Serializable,- IOpaquePartitionedTridentSpout.Emitter<List<Map<String,- Object>>, - KafkaTridentSpoutTopicPartition, - Map<String, - Object>> 
public class KafkaTridentOpaqueSpoutEmitter<K,V> 
extends Object
implements IOpaquePartitionedTridentSpout.Emitter<List<Map<String,Object>>,KafkaTridentSpoutTopicPartition,Map<String,Object>>, Serializable    
- See Also:
- 
Constructor SummaryConstructors
- 
Method SummaryModifier and TypeMethodDescriptionvoidclose()emitBatchNew(TransactionAttempt tx, TridentCollector collector, Set<KafkaTridentSpoutTopicPartition> partitions, Map<KafkaTridentSpoutTopicPartition, Map<String, Object>> lastBatchMetaMap) Emit a batch of tuples for a list of partitions/transactions.getOrderedPartitions(List<Map<String, Object>> allPartitionInfo) Sorts the partition info to produce an ordered list of partition.getPartitionsForTask(int taskId, int numTasks, List<KafkaTridentSpoutTopicPartition> allPartitionInfoSorted) Get the partitions assigned to this task.voidrefreshPartitions(List<KafkaTridentSpoutTopicPartition> partitionResponsibilities) This method is called when this task is responsible for a new set of partitions.
- 
Constructor Details- 
KafkaTridentOpaqueSpoutEmitter
 
- 
- 
Method Details- 
emitBatchNewpublic Map<KafkaTridentSpoutTopicPartition,Map<String, emitBatchNewObject>> (TransactionAttempt tx, TridentCollector collector, Set<KafkaTridentSpoutTopicPartition> partitions, Map<KafkaTridentSpoutTopicPartition, Map<String, Object>> lastBatchMetaMap) Description copied from interface:IOpaquePartitionedTridentSpout.EmitterEmit a batch of tuples for a list of partitions/transactions.Return the map of metadata describing this batch that will be used as lastPartitionMeta for defining the parameters of the next batch for each partition. - Specified by:
- emitBatchNewin interface- IOpaquePartitionedTridentSpout.Emitter<List<Map<String,- Object>>, - KafkaTridentSpoutTopicPartition, - Map<String, - Object>> 
 
- 
refreshPartitionsDescription copied from interface:IOpaquePartitionedTridentSpout.EmitterThis method is called when this task is responsible for a new set of partitions. Should be used to manage things like connections to brokers.- Specified by:
- refreshPartitionsin interface- IOpaquePartitionedTridentSpout.Emitter<List<Map<String,- Object>>, - KafkaTridentSpoutTopicPartition, - Map<String, - Object>> 
- Parameters:
- partitionResponsibilities- The partitions assigned to this task
 
- 
getOrderedPartitionspublic List<KafkaTridentSpoutTopicPartition> getOrderedPartitions(List<Map<String, Object>> allPartitionInfo) Description copied from interface:IOpaquePartitionedTridentSpout.EmitterSorts the partition info to produce an ordered list of partition.- Specified by:
- getOrderedPartitionsin interface- IOpaquePartitionedTridentSpout.Emitter<List<Map<String,- Object>>, - KafkaTridentSpoutTopicPartition, - Map<String, - Object>> 
- Parameters:
- allPartitionInfo- The partition info for all partitions being processed by all spout tasks
- Returns:
- The ordered list of partitions being processed by all the tasks. The ordering must be consistent for all tasks.
 
- 
getPartitionsForTaskpublic List<KafkaTridentSpoutTopicPartition> getPartitionsForTask(int taskId, int numTasks, List<KafkaTridentSpoutTopicPartition> allPartitionInfoSorted) Description copied from interface:IOpaquePartitionedTridentSpout.EmitterGet the partitions assigned to this task.- Specified by:
- getPartitionsForTaskin interface- IOpaquePartitionedTridentSpout.Emitter<List<Map<String,- Object>>, - KafkaTridentSpoutTopicPartition, - Map<String, - Object>> 
- Parameters:
- taskId- The id of this task
- numTasks- The number of tasks for this spout
- allPartitionInfoSorted- The partition info for all partitions being processed by all spout tasks, sorted according to- IOpaquePartitionedTridentSpout.Emitter.getOrderedPartitions(java.lang.Object)
- Returns:
- The list of partitions that are to be processed by the task with id taskId
 
- 
closepublic void close()- Specified by:
- closein interface- IOpaquePartitionedTridentSpout.Emitter<List<Map<String,- Object>>, - KafkaTridentSpoutTopicPartition, - Map<String, - Object>> 
 
 
-