Package org.apache.kafka.clients.consumer
package org.apache.kafka.clients.consumer
-
ClassDescriptionThis exception is raised when an offset commit with
KafkaConsumer.commitSync()
fails with an unrecoverable error.Consumer<K,V> The consumer configuration keysA metadata struct containing the consumer group information.ConsumerInterceptor<K,V> A plugin interface that allows you to intercept (and possibly mutate) records received by the consumer.This interface is used to define custom partition assignment for use inKafkaConsumer
.The rebalance protocol defines partition assignment and revocation semantics.A callback interface that the user can implement to trigger custom actions when the set of partitions assigned to the consumer changes.ConsumerRecord<K,V> A key/value pair to be received from Kafka.ConsumerRecords<K,V> A container that holds the listConsumerRecord
per partition for a particular topic.A cooperative version of theAbstractStickyAssignor
.Thrown when the offset for a set of partitions is invalid (either undefined or out of range), and no reset policy has been configured.KafkaConsumer<K,V> A client that consumes records from a Kafka cluster.In the event of an unclean leader election, the log will be truncated, previously committed data will be lost, and new data will be written over these offsets.MockConsumer<K,V> A mock of theConsumer
interface you can use for testing code that uses Kafka.Indicates that there is no stored offset for a partition and no defined offset reset policy.The Kafka offset commit API allows users to provide additional metadata (in the form of a string) when an offset is committed.A container class for offset and timestamp.A callback interface that the user can implement to trigger custom actions when a commit request completes.No reset policy has been defined, and the offsets for these partitions are either larger or smaller than the range of offsets the server has for the given partition.The range assignor works on a per-topic basis.The round robin assignor lays out all the available partitions and all the available consumers.The sticky assignor serves two purposes.