[−][src]Enum rdkafka::error::RDKafkaError
Errors enum Error from the underlying rdkafka library.
Variants
BadMessage
Received message is incorrect
BadCompression
Bad/unknown compression
BrokerDestroy
Broker is going away
Fail
Generic failure
BrokerTransportFailure
Broker transport failure
CriticalSystemResource
Critical system resource
Resolve
Failed to resolve broker
MessageTimedOut
Produced message timed out
PartitionEOF
Reached the end of the topic+partition queue on the broker. Not really an error.
UnknownPartition
Permanent: Partition does not exist in cluster.
FileSystem
File or filesystem error
UnknownTopic
Permanent: Topic does not exist in cluster.
AllBrokersDown
All broker connections are down.
InvalidArgument
Invalid argument, or invalid configuration
OperationTimedOut
Operation timed out
QueueFull
Queue is full
ISRInsufficient
ISR count < required.acks
NodeUpdate
Broker node update
SSL
SSL error
WaitingForCoordinator
Waiting for coordinator to become available.
UnknownGroup
Unknown client group
InProgress
Operation in progress
PreviousInProgress
Previous operation in progress, wait for it to finish.
ExistingSubscription
This operation would interfere with an existing subscription
AssignPartitions
Assigned partitions (rebalance_cb)
RevokePartitions
Revoked partitions (rebalance_cb)
Conflict
Conflicting use
State
Wrong state
UnknownProtocol
Unknown protocol
NotImplemented
Not implemented
Authentication
Authentication failure
NoOffset
No stored offset
Outdated
Outdated
TimedOutQueue
Timed out in queue
UnsupportedFeature
Feature not supported by broker
WaitCache
Awaiting cache update
Interrupted
Operation interrupted (e.g., due to yield))
KeySerialization
Key serialization error
ValueSerialization
Value serialization error
KeyDeserialization
Key deserialization error
ValueDeserialization
Value deserialization error
Partial
Partial response
ReadOnly
Modification attempted on read-only object
NoEnt
No such entry or item not found
Underflow
Read underflow
InvalidType
Invalid type
Unknown
Unknown broker error
NoError
Success
OffsetOutOfRange
Offset out of range
InvalidMessage
Invalid message
UnknownTopicOrPartition
Unknown topic or partition
InvalidMessageSize
Invalid message size
LeaderNotAvailable
Leader not available
NotLeaderForPartition
Not leader for partition
RequestTimedOut
Request timed out
BrokerNotAvailable
Broker not available
ReplicaNotAvailable
Replica not available
MessageSizeTooLarge
Message size too large
StaleControllerEpoch
Stale controller epoch code
OffsetMetadataTooLarge
Offset metadata string too large
NetworkException
Broker disconnected before response received
GroupLoadInProgress
Group coordinator load in progress
GroupCoordinatorNotAvailable
Group coordinator not available
NotCoordinatorForGroup
Not coordinator for group
InvalidTopic
Invalid topic
MessageBatchTooLarge
Message batch larger than configured server segment size
NotEnoughReplicas
Not enough in-sync replicas
NotEnoughReplicasAfterAppend
Message(s) written to insufficient number of in-sync replicas
InvalidRequiredAcks
Invalid required acks value
IllegalGeneration
Specified group generation id is not valid
InconsistentGroupProtocol
Inconsistent group protocol
InvalidGroupId
Invalid group.id
UnknownMemberId
Unknown member
InvalidSessionTimeout
Invalid session timeout
RebalanceInProgress
Group rebalance in progress
InvalidCommitOffsetSize
Commit offset data size is not valid
TopicAuthorizationFailed
Topic authorization failed
GroupAuthorizationFailed
Group authorization failed
ClusterAuthorizationFailed
Cluster authorization failed
InvalidTimestamp
Invalid timestamp
UnsupportedSASLMechanism
Unsupported SASL mechanism
IllegalSASLState
Illegal SASL state
UnsupportedVersion
Unsupported version
TopicAlreadyExists
Topic already exists
InvalidPartitions
Invalid number of partitions
InvalidReplicationFactor
Invalid replication factor
InvalidReplicaAssignment
Invalid replica assignment
InvalidConfig
Invalid config */
NotController
Not controller for cluster
InvalidRequest
Invalid request
UnsupportedForMessageFormat
Message format on broker does not support request
PolicyViolation
Policy violation
OutOfOrderSequenceNumber
Broker received an out of order sequence number
DuplicateSequenceNumber
Broker received a duplicate sequence number
InvalidProducerEpoch
Producer attempted an operation with an old epoch
InvalidTransactionalState
Producer attempted a transactional operation in an invalid state
InvalidProducerIdMapping
Producer attempted to use a producer id which is currently assigned to its transactional id
InvalidTransactionTimeout
Transaction timeout is larger than the maxi value allowed by the broker's max.transaction.timeout.ms
ConcurrentTransactions
Producer attempted to update a transaction while another concurrent operation on the same transaction was ongoing
TransactionCoordinatorFenced
Indicates that the transaction coordinator sending a WriteTxnMarker is no longer the current coordinator for a given producer
TransactionalIdAuthorizationFailed
Transactional Id authorization failed
SecurityDisabled
Security features are disabled
OperationNotAttempted
Operation not attempted
Trait Implementations
impl Copy for RDKafkaError
[src]
impl Display for RDKafkaError
[src]
impl Eq for RDKafkaError
[src]
impl From<rd_kafka_resp_err_t> for RDKafkaError
[src]
fn from(err: rd_kafka_resp_err_t) -> RDKafkaError
[src]
impl Error for RDKafkaError
[src]
fn description(&self) -> &str
[src]
fn cause(&self) -> Option<&dyn Error>
1.0.0[src]
replaced by Error::source, which can support downcasting
The lower-level cause of this error, if any. Read more
fn source(&self) -> Option<&(dyn Error + 'static)>
1.30.0[src]
The lower-level source of this error, if any. Read more
impl PartialEq<RDKafkaError> for RDKafkaError
[src]
fn eq(&self, other: &RDKafkaError) -> bool
[src]
#[must_use]
fn ne(&self, other: &Rhs) -> bool
1.0.0[src]
This method tests for !=
.
impl Debug for RDKafkaError
[src]
impl Clone for RDKafkaError
[src]
fn clone(&self) -> RDKafkaError
[src]
fn clone_from(&mut self, source: &Self)
1.0.0[src]
Performs copy-assignment from source
. Read more
Auto Trait Implementations
impl Send for RDKafkaError
impl Sync for RDKafkaError
Blanket Implementations
impl<T, U> Into for T where
U: From<T>,
[src]
U: From<T>,
impl<T> ToOwned for T where
T: Clone,
[src]
T: Clone,
impl<T> ToString for T where
T: Display + ?Sized,
[src]
T: Display + ?Sized,
impl<T> From for T
[src]
impl<T, U> TryFrom for T where
U: Into<T>,
[src]
U: Into<T>,
type Error = !
try_from
)The type returned in the event of a conversion error.
fn try_from(value: U) -> Result<T, <T as TryFrom<U>>::Error>
[src]
impl<T> Borrow for T where
T: ?Sized,
[src]
T: ?Sized,
impl<T, U> TryInto for T where
U: TryFrom<T>,
[src]
U: TryFrom<T>,
type Error = <U as TryFrom<T>>::Error
try_from
)The type returned in the event of a conversion error.
fn try_into(self) -> Result<U, <U as TryFrom<T>>::Error>
[src]
impl<T> Any for T where
T: 'static + ?Sized,
[src]
T: 'static + ?Sized,
impl<T> BorrowMut for T where
T: ?Sized,
[src]
T: ?Sized,