Class TopicAssigner

    • Constructor Detail

      • TopicAssigner

        public TopicAssigner()
    • Method Detail

      • 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