Exception | Description |
---|---|
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 | |
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.
|
DisconnectException |
Server disconnected before a request could be completed.
|
DuplicateSequenceNumberException | |
GroupAuthorizationException | |
GroupCoordinatorNotAvailableException | Deprecated
As of Kafka 0.11, this has been replaced by
CoordinatorNotAvailableException |
GroupLoadInProgressException | Deprecated
As of Kafka 0.11, this has been replaced by
CoordinatorLoadInProgressException |
IllegalGenerationException | |
IllegalSaslStateException | |
InconsistentGroupProtocolException | |
InterruptException |
An unchecked wrapper for InterruptedException
|
InvalidCommitOffsetSizeException | |
InvalidConfigurationException | |
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 | |
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 `max.transaction.timeout.ms` config value.
|
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).
|
NetworkException |
A misc.
|
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.
|
NotCoordinatorForGroupException | Deprecated
As of Kafka 0.11, this has been replaced by
NotCoordinatorException |
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 |
This server is not the leader for the given partition
|
OffsetMetadataTooLarge |
The client has tried to save its offset with associated metadata larger than the maximum size allowed by the server.
|
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.
|
ProducerFencedException |
This fatal exception indicates that another producer with the same
transactional.id has been
started. |
RebalanceInProgressException | |
RecordBatchTooLargeException |
This record batch is larger than the maximum allowable size
|
RecordTooLargeException |
This record is larger than the maximum allowable size
|
ReplicaNotAvailableException | |
RetriableException |
A retryable exception is a transient exception that if retried may succeed.
|
SecurityDisabledException |
An error indicating that security is disabled on the broker.
|
SerializationException |
Any exception during serialization in the producer
|
TimeoutException |
Indicates that a request timed out.
|
TopicAuthorizationException | |
TopicExistsException | |
TransactionalIdAuthorizationException | |
TransactionCoordinatorFencedException | |
UnknownMemberIdException | |
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
|
UnsupportedForMessageFormatException |
The message format version does not support the requested function.
|
UnsupportedSaslMechanismException | |
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.
|