Class TopicAssigner

java.lang.Object
org.apache.storm.kafka.spout.subscription.TopicAssigner
All Implemented Interfaces:
Serializable

public class TopicAssigner extends Object implements Serializable
Handles assigning partitions to the consumer and updating the rebalance listener.
See Also:
  • Constructor Summary

    Constructors
    Constructor
    Description
     
  • Method Summary

    Modifier and Type
    Method
    Description
    <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.

    Methods inherited from class java.lang.Object

    clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
  • 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 to
      newAssignment - 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