Enum ErrorCode
Enumeration of local and broker generated error codes.
Namespace: Confluent.Kafka
Assembly: Confluent.Kafka.dll
Syntax
public enum ErrorCode
  Remarks
Error codes that relate to locally produced errors in librdkafka are prefixed with Local_
Fields
| Name | Description | 
|---|---|
| BrokerNotAvailable | Broker not available  | 
      
| ClusterAuthorizationFailed | Cluster authorization failed  | 
      
| ConcurrentTransactions | Producer attempted to update a transaction while another concurrent operation on the same transaction was ongoing  | 
      
| DelegationTokenAuthDisabled | Delegation Token feature is not enabled.  | 
      
| DelegationTokenAuthorizationFailed | Delegation Token authorization failed.  | 
      
| DelegationTokenExpired | Delegation Token is expired.  | 
      
| DelegationTokenNotFound | Delegation Token is not found on server.  | 
      
| DelegationTokenOwnerMismatch | Specified Principal is not valid Owner/Renewer.  | 
      
| DelegationTokenRequestNotAllowed | Delegation Token requests are not allowed on this connection.  | 
      
| DuplicateResource | Request illegally referred to the same resource twice.  | 
      
| DuplicateSequenceNumber | Broker received a duplicate sequence number  | 
      
| ElectionNotNeeded | Leader election not needed for topic partition.  | 
      
| EligibleLeadersNotAvailable | Eligible partition leaders are not available.  | 
      
| FeatureUpdateFailed | Unable to update finalized features due to server error.  | 
      
| FencedInstanceId | Static consumer fenced by other consumer with same group.instance.id.  | 
      
| FencedLeaderEpoch | Leader epoch is older than broker epoch.  | 
      
| FencedMemberEpoch | The member epoch is fenced by the group coordinator.  | 
      
| FetchSessionIdNotFound | The fetch session ID was not found.  | 
      
| GroupAuthorizationFailed | Group authorization failed  | 
      
| GroupCoordinatorNotAvailable | Group coordinator not available  | 
      
| GroupIdNotFound | The group id does not exist.  | 
      
| GroupLoadInProgress | Group coordinator load in progress  | 
      
| GroupLoadInProress | Group coordinator load in progress  | 
      
| GroupMaxSizeReached | Consumer group has reached maximum size.  | 
      
| GroupSubscribedToTopic | Deleting offsets of a topic while the consumer group is subscribed to it.  | 
      
| IllegalGeneration | Specified group generation id is not valid  | 
      
| IllegalSaslState | Illegal SASL state  | 
      
| InconsistentGroupProtocol | Inconsistent group protocol  | 
      
| InconsistentVoterSet | Indicates that the either the sender or recipient of a voter-only request is not one of the expected voters.  | 
      
| InvalidCommitOffsetSize | Commit offset data size is not valid  | 
      
| InvalidConfig | Invalid config  | 
      
| InvalidFetchSessionEpoch | The fetch session epoch is invalid.  | 
      
| InvalidGroupId | Invalid group.id  | 
      
| InvalidMsg | Invalid message  | 
      
| InvalidMsgSize | Invalid message size  | 
      
| InvalidPartitions | Invalid number of partitions  | 
      
| InvalidPrincipalType | Supplied principalType is not supported.  | 
      
| InvalidProducerEpoch | Producer attempted an operation with an old epoch  | 
      
| InvalidProducerIdMapping | Producer attempted to use a producer id which is not currently assigned to its transactional id  | 
      
| InvalidRecord | Broker failed to validate record.  | 
      
| InvalidReplicaAssignment | Invalid replica assignment  | 
      
| InvalidReplicationFactor | Invalid replication factor  | 
      
| InvalidRequest | Invalid request  | 
      
| InvalidRequiredAcks | Invalid required acks value  | 
      
| InvalidSessionTimeout | Invalid session timeout  | 
      
| InvalidTimestamp | Invalid timestamp  | 
      
| InvalidTransactionTimeout | Transaction timeout is larger than the maximum value allowed by the broker's max.transaction.timeout.ms  | 
      
| InvalidTxnState | Producer attempted a transactional operation in an invalid state  | 
      
| InvalidUpdateVersion | Invalid update version.  | 
      
| KafkaStorageError | Disk error when trying to access log file on the disk.  | 
      
| LeaderNotAvailable | Leader not available  | 
      
| ListenerNotFound | No matching listener.  | 
      
| Local_AllBrokersDown | All broker connections are down.  | 
      
| Local_Application | Application generated exception.  | 
      
| Local_AssignPartitions | Assigned partitions (rebalance_cb)  | 
      
| Local_AssignmentLost | Assignment lost  | 
      
| Local_Authentication | Authentication failure  | 
      
| Local_AutoOffsetReset | No offset to automatically reset to  | 
      
| Local_BadCompression | Bad/unknown compression  | 
      
| Local_BadMsg | Received message is incorrect  | 
      
| Local_Conflict | Conflicting use  | 
      
| Local_CritSysResource | Critical system resource  | 
      
| Local_Destroy | Broker is going away  | 
      
| Local_ExistingSubscription | This operation would interfere with an existing subscription  | 
      
| Local_FS | File or filesystem error  | 
      
| Local_Fail | Generic failure  | 
      
| Local_Fatal | Fatal error: see rd_kafka_fatal_error()  | 
      
| Local_Fenced | Instance has been fenced  | 
      
| Local_GaplessGuarantee | Gap-less ordering would not be guaranteed if proceeding  | 
      
| Local_InProgress | Operation in progress  | 
      
| Local_Inconsistent | Inconsistent state  | 
      
| Local_Intr | Operation interrupted  | 
      
| Local_InvalidArg | Invalid argument, or invalid configuration  | 
      
| Local_InvalidDifferentRecord | A different record in the batch was invalid and this message failed persisting  | 
      
| Local_InvalidType | Invalid type  | 
      
| Local_IsrInsuff | ISR count < required.acks  | 
      
| Local_KeyDeserialization | Key deserialization error  | 
      
| Local_KeySerialization | Key serialization error  | 
      
| Local_LogTruncation | Partition log truncation detected  | 
      
| Local_MaxPollExceeded | Maximum poll interval exceeded  | 
      
| Local_MsgTimedOut | Produced message timed out  | 
      
| Local_NoEnt | No such entry / item not found  | 
      
| Local_NoOffset | No stored offset  | 
      
| Local_NodeUpdate | Broker node update  | 
      
| Local_Noop | No operation performed  | 
      
| Local_NotConfigured | Functionality not configured  | 
      
| Local_NotImplemented | Not implemented  | 
      
| Local_Outdated | Outdated  | 
      
| Local_Partial | Partial response  | 
      
| Local_PartitionEOF | Reached the end of the topic+partition queue on the broker. Not really an error.  | 
      
| Local_PrevInProgress | Previous operation in progress, wait for it to finish.  | 
      
| Local_PurgeInflight | Purged in flight  | 
      
| Local_PurgeQueue | Purged in queue  | 
      
| Local_QueueFull | Queue is full  | 
      
| Local_ReadOnly | Modification attempted on read-only object  | 
      
| Local_Resolve | Failed to resolve broker  | 
      
| Local_Retry | Retry operation.  | 
      
| Local_RevokePartitions | Revoked partitions (rebalance_cb)  | 
      
| Local_Ssl | SSL error  | 
      
| Local_State | Wrong state  | 
      
| Local_TimedOut | Operation timed out  | 
      
| Local_TimedOutQueue | Timed out in queue  | 
      
| Local_Transport | Broker transport failure  | 
      
| Local_Underflow | Read underflow  | 
      
| Local_UnknownBroker | Unknown broker  | 
      
| Local_UnknownGroup | Unknown client group  | 
      
| Local_UnknownPartition | Permanent: Partition does not exist in cluster.  | 
      
| Local_UnknownProtocol | Unknown protocol  | 
      
| Local_UnknownTopic | Permanent: Topic does not exist in cluster.  | 
      
| Local_UnsupportedFeature | Feature not supported by broker  | 
      
| Local_ValueDeserialization | Value deserialization error  | 
      
| Local_ValueSerialization | Value serialization error  | 
      
| Local_WaitCache | Awaiting cache update  | 
      
| Local_WaitCoord | Waiting for coordinator to become available.  | 
      
| LogDirNotFound | The user-specified log directory is not found in the broker config.  | 
      
| MemberIdRequired | Group member needs a valid member ID.  | 
      
| MsgSizeTooLarge | Message size too large  | 
      
| NetworkException | Broker disconnected before response received  | 
      
| NoError | Success  | 
      
| NoReassignmentInProgress | No partition reassignment is in progress.  | 
      
| NonEmptyGroup | The group is not empty.  | 
      
| NotController | Not controller for cluster  | 
      
| NotCoordinatorForGroup | Not coordinator for group  | 
      
| NotEnoughReplicas | Not enough in-sync replicas  | 
      
| NotEnoughReplicasAfterAppend | Message(s) written to insufficient number of in-sync replicas  | 
      
| NotLeaderForPartition | Not leader for partition  | 
      
| OffsetMetadataTooLarge | Offset metadata string too large  | 
      
| OffsetNotAvailable | Leader high watermark is not caught up.  | 
      
| OffsetOutOfRange | Offset out of range  | 
      
| OperationNotAttempted | Operation not attempted  | 
      
| OutOfOrderSequenceNumber | Broker received an out of order sequence number  | 
      
| PolicyViolation | Isolation policy violation  | 
      
| PreferredLeaderNotAvailable | Preferred leader was not available.  | 
      
| PrincipalDeserializationFailure | Request principal deserialization failed during forwarding.  | 
      
| ProducerFenced | There is a newer producer with the same transactionalId which fences the current one.  | 
      
| ReassignmentInProgress | Partition reassignment is in progress.  | 
      
| RebalanceInProgress | Group rebalance in progress  | 
      
| RecordListTooLarge | Message batch larger than configured server segment size  | 
      
| ReplicaNotAvailable | Replica not available  | 
      
| RequestTimedOut | Request timed out  | 
      
| ResourceNotFound | Request illegally referred to resource that does not exist.  | 
      
| SaslAuthenticationFailed | SASL Authentication failed.  | 
      
| SecurityDisabled | Security features are disabled  | 
      
| StaleBrokerEpoch | Broker epoch has changed.  | 
      
| StaleCtrlEpoch | StaleControllerEpochCode  | 
      
| StaleMemberEpoch | The member epoch is stale.  | 
      
| TelemetryTooLarge | Client sent a push telemetry request larger than the maximum size the broker will accept.  | 
      
| ThrottlingQuotaExceeded | Throttling quota has been exceeded.  | 
      
| TopicAlreadyExists | Topic already exists  | 
      
| TopicAuthorizationFailed | Topic authorization failed  | 
      
| TopicDeletionDisabled | Topic deletion is disabled.  | 
      
| TopicException | Invalid topic  | 
      
| TransactionCoordinatorFenced | Indicates that the transaction coordinator sending a WriteTxnMarker is no longer the current coordinator for a given producer  | 
      
| TransactionalIdAuthorizationFailed | Transactional Id authorization failed  | 
      
| UnacceptableCredential | Requested credential would not meet criteria for acceptability.  | 
      
| Unknown | Unknown broker error  | 
      
| UnknownLeaderEpoch | Leader epoch is newer than broker epoch.  | 
      
| UnknownMemberId | Unknown member  | 
      
| UnknownProducerId | Unknown Producer Id.  | 
      
| UnknownSubscriptionId | Client sent a push telemetry request with an invalid or outdated subscription ID.  | 
      
| UnknownTopicId | Unknown Topic Id.  | 
      
| UnknownTopicOrPart | Unknown topic or partition  | 
      
| UnreleasedInstanceId | The instance ID is still used by another member in the consumer group.  | 
      
| UnstableOffsetCommit | There are unstable offsets that need to be cleared.  | 
      
| UnsupportedAssignor | The assignor or its version range is not supported by the consumer group.  | 
      
| UnsupportedCompressionType | Unsupported compression type.  | 
      
| UnsupportedForMessageFormat | Message format on broker does not support request  | 
      
| UnsupportedSaslMechanism | Unsupported SASL mechanism  | 
      
| UnsupportedVersion | Unsupported version  |