| Name | Description | Type | Package | Framework |
| LongDeserializer | Class | org.apache.kafka.common.serialization | Apache Kafka | |
| LeaderNotAvailableException | There is no currently available leader for the given partition (either because a leadership election is in progress or because all replicas are down). | Class | org.apache.kafka.common.errors | Apache Kafka |
| KafkaProducer | A Kafka client that publishes records to the Kafka cluster. | Class | org.apache.kafka.clients.producer | Apache Kafka |
| KafkaException | The base class of all other Kafka exceptionsSee Also:Serialized Form | Class | org.apache.kafka.common | Apache Kafka |
| KafkaConsumer | A Kafka client that consumes records from a Kafka cluster. | Class | org.apache.kafka.clients.consumer | Apache Kafka |
| InvalidTopicException | The client has attempted to perform an operation on an invalid topic. | Class | org.apache.kafka.common.errors | Apache Kafka |
| InvalidRequiredAcksException | Class | org.apache.kafka.common.errors | Apache Kafka | |
| 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. | Class | org.apache.kafka.clients.consumer | Apache Kafka |
| InvalidMetadataException | An exception that may indicate the client's metadata is out of dateSee Also:Serialized Form | Class | org.apache.kafka.common.errors | Apache Kafka |
| InterruptException | An unchecked wrapper for InterruptedExceptionSee Also:Serialized Form | Class | org.apache.kafka.common.errors | Apache Kafka |
| IntegerSerializer | Class | org.apache.kafka.common.serialization | Apache Kafka | |
| IntegerDeserializer | Class | org.apache.kafka.common.serialization | Apache Kafka | |
| IllegalGenerationException | Class | org.apache.kafka.common.errors | Apache Kafka | |
| GroupLoadInProgressException | The broker returns this error code for any coordiantor request if it is still loading the metadata (after a leader change for that offsets topic partition) for this group. | Class | org.apache.kafka.common.errors | Apache Kafka |
| GroupCoordinatorNotAvailableException | The broker returns this error code for consumer metadata requests or offset commit requests if the offsets topic has not yet been created. | Class | org.apache.kafka.common.errors | Apache Kafka |
| GroupAuthorizationException | Class | org.apache.kafka.common.errors | Apache Kafka | |
| Deserializer | Interface | org.apache.kafka.common.serialization | Apache Kafka | |
| DisconnectException | Server disconnected before a request could be completed. | Class | org.apache.kafka.common.errors | Apache Kafka |
| CorruptRecordException | This exception indicates a record has failed its internal CRC check, this generally indicates network or diskSee Also:Serialized Form | Class | org.apache.kafka.common.errors | Apache Kafka |
| ControllerMovedException | Class | org.apache.kafka.common.errors | Apache Kafka | |
| ConsumerRecords | A container that holds the list ConsumerRecord per partition for a particular topic. | Class | org.apache.kafka.clients.consumer | Apache Kafka |
| ConsumerRecord | A key/value pair to be received from Kafka. | Class | org.apache.kafka.clients.consumer | Apache Kafka |
| ConsumerRebalanceListener | A callback interface that the user can implement to trigger custom actions when the set of partitions assigned to the This is applicable when the consumer is having Kafka auto-manage group membership. | Interface | org.apache.kafka.clients.consumer | Apache Kafka |
| ConsumerConfig | Class | org.apache.kafka.clients.consumer | Apache Kafka | |
| Consumer | Interface | org.apache.kafka.clients.consumer | Apache Kafka | |
| Configurable | Interface | org.apache.kafka.common | Apache Kafka | |
| CommitFailedException | This exception is raised when an offset commit with KafkaConsumer. | Class | org.apache.kafka.clients.consumer | Apache Kafka |
| Cluster | A representation of a subset of the nodes, topics, and partitions in the Kafka cluster. | Class | org.apache.kafka.common | Apache Kafka |
| Callback | A callback interface that the user can implement to allow code to execute when the request is complete. | Interface | org.apache.kafka.clients.producer | Apache Kafka |
| ByteArraySerializer | Class | org.apache.kafka.common.serialization | Apache Kafka | |
| ByteArrayDeserializer | Class | org.apache.kafka.common.serialization | Apache Kafka | |
| BufferExhaustedException | This exception is thrown if the producer is in non-blocking mode and the rate of data production exceeds the rate at which data can be sent for long enough for the alloted buffer to be exhausted. | Class | org.apache.kafka.clients.producer | Apache Kafka |
| BrokerNotAvailableException | Class | org.apache.kafka.common.errors | Apache Kafka | |
| ApiException | Any API exception that is part of the public protocol and should be a subclass of this class and be part of thisSee Also:Serialized Form | Class | org.apache.kafka.common.errors | Apache Kafka |
| AuthorizationException | Class | org.apache.kafka.common.errors | Apache Kafka | |
| LongSerializer | Class | org.apache.kafka.common.serialization | Apache Kafka | |
| Metric | Interface | org.apache.kafka.common | Apache Kafka | |
| MetricName | The MetricName class encapsulates a metric's name, logical group and its related attributes This class captures the following parameters | Class | org.apache.kafka.common | Apache Kafka |
| MockConsumer | A mock of the Consumer interface you can use for testing code that uses Kafka. | Class | org.apache.kafka.clients.consumer | Apache Kafka |
| MockProducer | A mock of the producer interface you can use for testing code that uses Kafka. | Class | org.apache.kafka.clients.producer | Apache Kafka |
| NetworkException | A misc. | Class | org.apache.kafka.common.errors | Apache Kafka |
| Node | Class | org.apache.kafka.common | Apache Kafka | |
| NoOffsetForPartitionException | Indicates that there is no stored offset for a partition and no defined offsetSee Also:Serialized Form | Class | org.apache.kafka.clients.consumer | Apache Kafka |
| NotCoordinatorForGroupException | The broker returns this error code if it receives an offset fetch or commit request for a consumer group that it is not a coordinator for. | Class | org.apache.kafka.common.errors | Apache Kafka |
| NotEnoughReplicasAfterAppendException | Number of insync replicas for the partition is lower than min. | Class | org.apache.kafka.common.errors | Apache Kafka |
| NotEnoughReplicasException | Number of insync replicas for the partition is lower than min. | Class | org.apache.kafka.common.errors | Apache Kafka |
| NotLeaderForPartitionException | This server is not the leader for the given partitionSee Also:Serialized Form | Class | org.apache.kafka.common.errors | Apache Kafka |
| OffsetAndMetadata | The Kafka offset commit API allows users to provide additional metadata (in the form of a string) when an offset is committed. | Class | org.apache.kafka.clients.consumer | Apache Kafka |
| OffsetCommitCallback | A callback interface that the user can implement to trigger custom actions when a commit request completes. | Interface | org.apache.kafka.clients.consumer | Apache Kafka |
| OffsetMetadataTooLarge | The client has tried to save its offset with associated metadata larger than the maximum size allowed by the server. | Class | org.apache.kafka.common.errors | Apache Kafka |
| 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. | Class | org.apache.kafka.clients.consumer | Apache Kafka |
| OffsetResetStrategy | enum OffsetResetStrategyEnum Constant Summary | Class | org.apache.kafka.clients.consumer | Apache Kafka |
| Partitioner | Interface | org.apache.kafka.clients.producer | Apache Kafka | |
| PartitionInfo | Information about a topic-partition. | Class | org.apache.kafka.common | Apache Kafka |
| Producer | The interface for the KafkaProducerSee Also:KafkaProducer, | Interface | org.apache.kafka.clients.producer | Apache Kafka |
| ProducerConfig | Configuration for the Kafka Producer. | Class | org.apache.kafka.clients.producer | Apache Kafka |
| ProducerRecord | A key/value pair to be sent to Kafka. | Class | org.apache.kafka.clients.producer | Apache Kafka |
| RangeAssignor | The range assignor works on a per-topic basis. | Class | org.apache.kafka.clients.consumer | Apache Kafka |
| RebalanceInProgressException | Class | org.apache.kafka.common.errors | Apache Kafka | |
| RecordBatchTooLargeException | This record batch is larger than the maximum allowable sizeSee Also:Serialized Form | Class | org.apache.kafka.common.errors | Apache Kafka |
| RecordMetadata | Class | org.apache.kafka.clients.producer | Apache Kafka | |
| RecordTooLargeException | This record is larger than the maximum allowable sizeSee Also:Serialized Form | Class | org.apache.kafka.common.errors | Apache Kafka |
| RetriableException | A retryable exception is a transient exception that if retried may succeed. | Class | org.apache.kafka.common.errors | Apache Kafka |
| RoundRobinAssignor | The roundrobin assignor lays out all the available partitions and all the available consumers. | Class | org.apache.kafka.clients.consumer | Apache Kafka |
| SerializationException | Any exception during serialization in the producerSee Also:Serialized Form | Class | org.apache.kafka.common.errors | Apache Kafka |
| Serializer | Interface | org.apache.kafka.common.serialization | Apache Kafka | |
| StringDeserializer | String encoding defaults to UTF8 and can be customized by setting the property key. | Class | org.apache.kafka.common.serialization | Apache Kafka |
| StringSerializer | String encoding defaults to UTF8 and can be customized by setting the property key. | Class | org.apache.kafka.common.serialization | Apache Kafka |
| TimeoutException | Indicates that a request timed out. | Class | org.apache.kafka.common.errors | Apache Kafka |
| TopicAuthorizationException | Class | org.apache.kafka.common.errors | Apache Kafka | |
| TopicPartition | A topic name and partition numberSee Also:Serialized Form | Class | org.apache.kafka.common | Apache Kafka |
| UnknownMemberIdException | Class | org.apache.kafka.common.errors | Apache Kafka | |
| UnknownServerException | An error occurred on the server for which the client doesn't have a corresponding error code. | Class | org.apache.kafka.common.errors | Apache Kafka |
| UnknownTopicOrPartitionException | This topic/partition doesn't existSee Also:Serialized Form | Class | org.apache.kafka.common.errors | Apache Kafka |
| WakeupException | Exception used to indicate preemption of a blocking operation by an external thread. | Class | org.apache.kafka.common.errors | Apache Kafka |