Package org.apache.kafka.clients.consumer
-
Interface Summary Interface Description Consumer<K,V> ConsumerInterceptor<K,V> A plugin interface that allows you to intercept (and possibly mutate) records received by the consumer.ConsumerPartitionAssignor This interface is used to define custom partition assignment for use inKafkaConsumer
.ConsumerRebalanceListener A callback interface that the user can implement to trigger custom actions when the set of partitions assigned to the consumer changes.OffsetCommitCallback A callback interface that the user can implement to trigger custom actions when a commit request completes. -
Class Summary Class Description ConsumerConfig The consumer configuration keysConsumerGroupMetadata A metadata struct containing the consumer group information.ConsumerPartitionAssignor.Assignment ConsumerPartitionAssignor.GroupAssignment ConsumerPartitionAssignor.GroupSubscription ConsumerPartitionAssignor.Subscription 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.CooperativeStickyAssignor A cooperative version of theAbstractStickyAssignor
.KafkaConsumer<K,V> A client that consumes records from a Kafka cluster.MockConsumer<K,V> This class is not supported.OffsetAndMetadata The Kafka offset commit API allows users to provide additional metadata (in the form of a string) when an offset is committed.OffsetAndTimestamp A container class for offset and timestamp.RangeAssignor This class is not supported.RoundRobinAssignor This class is not supported.StickyAssignor This class is not supported. -
Enum Summary Enum Description ConsumerPartitionAssignor.RebalanceProtocol The rebalance protocol defines partition assignment and revocation semantics.OffsetResetStrategy -
Exception Summary Exception Description CommitFailedException This exception is raised when an offset commit withKafkaConsumer.commitSync()
fails with an unrecoverable error.InvalidOffsetException Thrown when the offset for a set of partitions is invalid (either undefined or out of range), and no reset policy has been configured.LogTruncationException 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.NoOffsetForPartitionException Indicates that there is no stored offset for a partition and no defined offset reset policy.OffsetOutOfRangeException 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.RetriableCommitFailedException