Class TopicAssigner
java.lang.Object
org.apache.storm.kafka.spout.subscription.TopicAssigner
- All Implemented Interfaces:
Serializable
Handles assigning partitions to the consumer and updating the rebalance listener.
- See Also:
-
Constructor Summary
-
Method Summary
Modifier and TypeMethodDescription<K,
V> boolean assignPartitions
(org.apache.kafka.clients.consumer.Consumer<K, V> consumer, Set<org.apache.kafka.common.TopicPartition> newAssignment, org.apache.kafka.clients.consumer.ConsumerRebalanceListener listener) Assign partitions to the KafkaConsumer.
-
Constructor Details
-
TopicAssigner
public TopicAssigner()
-
-
Method Details
-
assignPartitions
public <K,V> boolean assignPartitions(org.apache.kafka.clients.consumer.Consumer<K, V> consumer, Set<org.apache.kafka.common.TopicPartition> newAssignment, org.apache.kafka.clients.consumer.ConsumerRebalanceListener listener) Assign partitions to the KafkaConsumer.- Parameters:
consumer
- The Kafka consumer to assign partitions tonewAssignment
- The partitions to assign.listener
- The rebalance listener to call back on when the assignment changes- Returns:
- a boolean value indicating whether the partition assignment changed
-