| ApiException | 
 Any API exception that is part of the public protocol and should be a subclass of this class and be part of this
 package. 
 | 
| AuthenticationException | 
 This exception indicates that SASL authentication has failed. 
 | 
| AuthorizationException | 
  | 
| BrokerNotAvailableException | 
  | 
| ClusterAuthorizationException | 
  | 
| ConcurrentTransactionsException | 
  | 
| ControllerMovedException | 
  | 
| CoordinatorLoadInProgressException | 
 In the context of the group coordinator, the broker returns this error code for any coordinator request if
 it is still loading the group metadata (e.g. 
 | 
| CoordinatorNotAvailableException | 
 In the context of the group coordinator, the broker returns this error code for metadata or offset commit
 requests if the group metadata topic has not been created yet. 
 | 
| CorruptRecordException | 
 This exception indicates a record has failed its internal CRC check, this generally indicates network or disk
 corruption. 
 | 
| DelegationTokenAuthorizationException | 
  | 
| DelegationTokenDisabledException | 
  | 
| DelegationTokenExpiredException | 
  | 
| DelegationTokenNotFoundException | 
  | 
| DelegationTokenOwnerMismatchException | 
  | 
| DisconnectException | 
 Server disconnected before a request could be completed. 
 | 
| DuplicateSequenceException | 
  | 
| ElectionNotNeededException | 
  | 
| EligibleLeadersNotAvailableException | 
  | 
| FencedInstanceIdException | 
  | 
| FencedLeaderEpochException | 
 The request contained a leader epoch which is smaller than that on the broker that received the
 request. 
 | 
| FetchSessionIdNotFoundException | 
  | 
| GroupAuthorizationException | 
  | 
| GroupIdNotFoundException | 
  | 
| GroupMaxSizeReachedException | 
 Indicates that a consumer group is already at its configured maximum capacity and cannot accommodate more members 
 | 
| GroupNotEmptyException | 
  | 
| GroupSubscribedToTopicException | 
  | 
| IllegalGenerationException | 
  | 
| IllegalSaslStateException | 
 This exception indicates unexpected requests prior to SASL authentication. 
 | 
| InconsistentGroupProtocolException | 
  | 
| InterruptException | 
 An unchecked wrapper for InterruptedException 
 | 
| InvalidCommitOffsetSizeException | 
  | 
| InvalidConfigurationException | 
  | 
| InvalidFetchSessionEpochException | 
  | 
| InvalidFetchSizeException | 
  | 
| InvalidGroupIdException | 
  | 
| InvalidMetadataException | 
 An exception that may indicate the client's metadata is out of date 
 | 
| 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. 
 | 
| InvalidPartitionsException | 
  | 
| InvalidPidMappingException | 
  | 
| InvalidPrincipalTypeException | 
  | 
| InvalidReplicaAssignmentException | 
  | 
| InvalidReplicationFactorException | 
  | 
| InvalidRequestException | 
 Thrown when a request breaks basic wire protocol rules. 
 | 
| InvalidRequiredAcksException | 
  | 
| InvalidSessionTimeoutException | 
  | 
| InvalidTimestampException | 
 Indicate the timestamp of a record is invalid. 
 | 
| InvalidTopicException | 
 The client has attempted to perform an operation on an invalid topic. 
 | 
| InvalidTxnStateException | 
  | 
| InvalidTxnTimeoutException | 
 The transaction coordinator returns this error code if the timeout received via the InitProducerIdRequest is larger than
 the `transaction.max.timeout.ms` config value. 
 | 
| KafkaStorageException | 
 Miscellaneous disk-related IOException occurred when handling a request. 
 | 
| 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). 
 | 
| ListenerNotFoundException | 
 The leader does not have an endpoint corresponding to the listener on which metadata was requested. 
 | 
| LogDirNotFoundException | 
 Thrown when a request is made for a log directory that is not present on the broker 
 | 
| MemberIdRequiredException | 
  | 
| NetworkException | 
 A misc. 
 | 
| NoReassignmentInProgressException | 
 Thrown if a reassignment cannot be cancelled because none is in progress. 
 | 
| NotControllerException | 
  | 
| NotCoordinatorException | 
 In the context of the group coordinator, the broker returns this error code if it receives an offset fetch
 or commit request for a group it's not the coordinator of. 
 | 
| NotEnoughReplicasAfterAppendException | 
 Number of insync replicas for the partition is lower than min.insync.replicas This exception is raised when the low
 ISR size is discovered *after* the message was already appended to the log. 
 | 
| NotEnoughReplicasException | 
 Number of insync replicas for the partition is lower than min.insync.replicas 
 | 
| NotLeaderForPartitionException | 
Deprecated.
 | 
| NotLeaderOrFollowerException | 
 Broker returns this error if a request could not be processed because the broker is not the leader
 or follower for a topic partition. 
 | 
| OffsetMetadataTooLarge | 
 The client has tried to save its offset with associated metadata larger than the maximum size allowed by the server. 
 | 
| OffsetNotAvailableException | 
 Indicates that the leader is not able to guarantee monotonically increasing offsets
 due to the high watermark lagging behind the epoch start offset after a recent leader election 
 | 
| 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. 
 | 
| OperationNotAttemptedException | 
 Indicates that the broker did not attempt to execute this operation. 
 | 
| OutOfOrderSequenceException | 
 This exception indicates that the broker received an unexpected sequence number from the producer,
 which means that data may have been lost. 
 | 
| PolicyViolationException | 
 Exception thrown if a create topics request does not satisfy the configured policy for a topic. 
 | 
| PreferredLeaderNotAvailableException | 
  | 
| ProducerFencedException | 
 This fatal exception indicates that another producer with the same transactional.id has been
 started. 
 | 
| ReassignmentInProgressException | 
 Thrown if a request cannot be completed because a partition reassignment is in progress. 
 | 
| RebalanceInProgressException | 
  | 
| RecordBatchTooLargeException | 
 This record batch is larger than the maximum allowable size 
 | 
| RecordTooLargeException | 
 This record is larger than the maximum allowable size 
 | 
| ReplicaNotAvailableException | 
 The replica is not available for the requested topic partition. 
 | 
| RetriableException | 
 A retryable exception is a transient exception that if retried may succeed. 
 | 
| SaslAuthenticationException | 
 This exception indicates that SASL authentication has failed. 
 | 
| SecurityDisabledException | 
 An error indicating that security is disabled on the broker. 
 | 
| SerializationException | 
 Any exception during serialization in the producer 
 | 
| SslAuthenticationException | 
 This exception indicates that SSL handshake has failed. 
 | 
| StaleBrokerEpochException | 
  | 
| TimeoutException | 
 Indicates that a request timed out. 
 | 
| TopicAuthorizationException | 
  | 
| TopicDeletionDisabledException | 
  | 
| TopicExistsException | 
  | 
| TransactionalIdAuthorizationException | 
  | 
| TransactionCoordinatorFencedException | 
  | 
| UnknownLeaderEpochException | 
 The request contained a leader epoch which is larger than that on the broker that received the
 request. 
 | 
| UnknownMemberIdException | 
  | 
| UnknownProducerIdException | 
 This exception is raised by the broker if it could not locate the producer metadata associated with the producerId
 in question. 
 | 
| UnknownServerException | 
 An error occurred on the server for which the client doesn't have a corresponding error code. 
 | 
| UnknownTopicOrPartitionException | 
 This topic/partition doesn't exist. 
 | 
| UnstableOffsetCommitException | 
 Exception thrown when there are unstable offsets for the requested topic partitions. 
 | 
| UnsupportedByAuthenticationException | 
 Authentication mechanism does not support the requested function. 
 | 
| UnsupportedCompressionTypeException | 
 The requesting client does not support the compression type of given partition. 
 | 
| UnsupportedForMessageFormatException | 
 The message format version does not support the requested function. 
 | 
| UnsupportedSaslMechanismException | 
 This exception indicates that the SASL mechanism requested by the client
 is not enabled on the broker. 
 | 
| UnsupportedVersionException | 
 Indicates that a request API or version needed by the client is not supported by the broker. 
 | 
| WakeupException | 
 Exception used to indicate preemption of a blocking operation by an external thread. 
 |