github.com/confluentinc/confluent-kafka-go@v1.9.2/kafka/generated_errors.go (about)

     1  package kafka
     2  // Copyright 2016-2022 Confluent Inc.
     3  // AUTOMATICALLY GENERATED ON 2022-08-01 22:56:19.86222475 +0200 CEST m=+0.000294735 USING librdkafka 1.9.2
     4  
     5  /*
     6  #include "select_rdkafka.h"
     7  */
     8  import "C"
     9  
    10  // ErrorCode is the integer representation of local and broker error codes
    11  type ErrorCode int
    12  
    13  // String returns a human readable representation of an error code
    14  func (c ErrorCode) String() string {
    15        return C.GoString(C.rd_kafka_err2str(C.rd_kafka_resp_err_t(c)))
    16  }
    17  
    18  const (
    19      // ErrBadMsg Local: Bad message format
    20      ErrBadMsg ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__BAD_MSG)
    21      // ErrBadCompression Local: Invalid compressed data
    22      ErrBadCompression ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__BAD_COMPRESSION)
    23      // ErrDestroy Local: Broker handle destroyed
    24      ErrDestroy ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__DESTROY)
    25      // ErrFail Local: Communication failure with broker
    26      ErrFail ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__FAIL)
    27      // ErrTransport Local: Broker transport failure
    28      ErrTransport ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__TRANSPORT)
    29      // ErrCritSysResource Local: Critical system resource failure
    30      ErrCritSysResource ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__CRIT_SYS_RESOURCE)
    31      // ErrResolve Local: Host resolution failure
    32      ErrResolve ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__RESOLVE)
    33      // ErrMsgTimedOut Local: Message timed out
    34      ErrMsgTimedOut ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__MSG_TIMED_OUT)
    35      // ErrPartitionEOF Broker: No more messages
    36      ErrPartitionEOF ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__PARTITION_EOF)
    37      // ErrUnknownPartition Local: Unknown partition
    38      ErrUnknownPartition ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__UNKNOWN_PARTITION)
    39      // ErrFs Local: File or filesystem error
    40      ErrFs ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__FS)
    41      // ErrUnknownTopic Local: Unknown topic
    42      ErrUnknownTopic ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__UNKNOWN_TOPIC)
    43      // ErrAllBrokersDown Local: All broker connections are down
    44      ErrAllBrokersDown ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__ALL_BROKERS_DOWN)
    45      // ErrInvalidArg Local: Invalid argument or configuration
    46      ErrInvalidArg ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__INVALID_ARG)
    47      // ErrTimedOut Local: Timed out
    48      ErrTimedOut ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__TIMED_OUT)
    49      // ErrQueueFull Local: Queue full
    50      ErrQueueFull ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__QUEUE_FULL)
    51      // ErrIsrInsuff Local: ISR count insufficient
    52      ErrIsrInsuff ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__ISR_INSUFF)
    53      // ErrNodeUpdate Local: Broker node update
    54      ErrNodeUpdate ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__NODE_UPDATE)
    55      // ErrSsl Local: SSL error
    56      ErrSsl ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__SSL)
    57      // ErrWaitCoord Local: Waiting for coordinator
    58      ErrWaitCoord ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__WAIT_COORD)
    59      // ErrUnknownGroup Local: Unknown group
    60      ErrUnknownGroup ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__UNKNOWN_GROUP)
    61      // ErrInProgress Local: Operation in progress
    62      ErrInProgress ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__IN_PROGRESS)
    63      // ErrPrevInProgress Local: Previous operation in progress
    64      ErrPrevInProgress ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__PREV_IN_PROGRESS)
    65      // ErrExistingSubscription Local: Existing subscription
    66      ErrExistingSubscription ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__EXISTING_SUBSCRIPTION)
    67      // ErrAssignPartitions Local: Assign partitions
    68      ErrAssignPartitions ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__ASSIGN_PARTITIONS)
    69      // ErrRevokePartitions Local: Revoke partitions
    70      ErrRevokePartitions ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__REVOKE_PARTITIONS)
    71      // ErrConflict Local: Conflicting use
    72      ErrConflict ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__CONFLICT)
    73      // ErrState Local: Erroneous state
    74      ErrState ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__STATE)
    75      // ErrUnknownProtocol Local: Unknown protocol
    76      ErrUnknownProtocol ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__UNKNOWN_PROTOCOL)
    77      // ErrNotImplemented Local: Not implemented
    78      ErrNotImplemented ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__NOT_IMPLEMENTED)
    79      // ErrAuthentication Local: Authentication failure
    80      ErrAuthentication ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__AUTHENTICATION)
    81      // ErrNoOffset Local: No offset stored
    82      ErrNoOffset ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__NO_OFFSET)
    83      // ErrOutdated Local: Outdated
    84      ErrOutdated ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__OUTDATED)
    85      // ErrTimedOutQueue Local: Timed out in queue
    86      ErrTimedOutQueue ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__TIMED_OUT_QUEUE)
    87      // ErrUnsupportedFeature Local: Required feature not supported by broker
    88      ErrUnsupportedFeature ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__UNSUPPORTED_FEATURE)
    89      // ErrWaitCache Local: Awaiting cache update
    90      ErrWaitCache ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__WAIT_CACHE)
    91      // ErrIntr Local: Operation interrupted
    92      ErrIntr ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__INTR)
    93      // ErrKeySerialization Local: Key serialization error
    94      ErrKeySerialization ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__KEY_SERIALIZATION)
    95      // ErrValueSerialization Local: Value serialization error
    96      ErrValueSerialization ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__VALUE_SERIALIZATION)
    97      // ErrKeyDeserialization Local: Key deserialization error
    98      ErrKeyDeserialization ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__KEY_DESERIALIZATION)
    99      // ErrValueDeserialization Local: Value deserialization error
   100      ErrValueDeserialization ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__VALUE_DESERIALIZATION)
   101      // ErrPartial Local: Partial response
   102      ErrPartial ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__PARTIAL)
   103      // ErrReadOnly Local: Read-only object
   104      ErrReadOnly ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__READ_ONLY)
   105      // ErrNoent Local: No such entry
   106      ErrNoent ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__NOENT)
   107      // ErrUnderflow Local: Read underflow
   108      ErrUnderflow ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__UNDERFLOW)
   109      // ErrInvalidType Local: Invalid type
   110      ErrInvalidType ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__INVALID_TYPE)
   111      // ErrRetry Local: Retry operation
   112      ErrRetry ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__RETRY)
   113      // ErrPurgeQueue Local: Purged in queue
   114      ErrPurgeQueue ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__PURGE_QUEUE)
   115      // ErrPurgeInflight Local: Purged in flight
   116      ErrPurgeInflight ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__PURGE_INFLIGHT)
   117      // ErrFatal Local: Fatal error
   118      ErrFatal ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__FATAL)
   119      // ErrInconsistent Local: Inconsistent state
   120      ErrInconsistent ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__INCONSISTENT)
   121      // ErrGaplessGuarantee Local: Gap-less ordering would not be guaranteed if proceeding
   122      ErrGaplessGuarantee ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__GAPLESS_GUARANTEE)
   123      // ErrMaxPollExceeded Local: Maximum application poll interval (max.poll.interval.ms) exceeded
   124      ErrMaxPollExceeded ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__MAX_POLL_EXCEEDED)
   125      // ErrUnknownBroker Local: Unknown broker
   126      ErrUnknownBroker ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__UNKNOWN_BROKER)
   127      // ErrNotConfigured Local: Functionality not configured
   128      ErrNotConfigured ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__NOT_CONFIGURED)
   129      // ErrFenced Local: This instance has been fenced by a newer instance
   130      ErrFenced ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__FENCED)
   131      // ErrApplication Local: Application generated error
   132      ErrApplication ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__APPLICATION)
   133      // ErrAssignmentLost Local: Group partition assignment lost
   134      ErrAssignmentLost ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__ASSIGNMENT_LOST)
   135      // ErrNoop Local: No operation performed
   136      ErrNoop ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__NOOP)
   137      // ErrAutoOffsetReset Local: No offset to automatically reset to
   138      ErrAutoOffsetReset ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR__AUTO_OFFSET_RESET)
   139      // ErrUnknown Unknown broker error
   140      ErrUnknown ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_UNKNOWN)
   141      // ErrNoError Success
   142      ErrNoError ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_NO_ERROR)
   143      // ErrOffsetOutOfRange Broker: Offset out of range
   144      ErrOffsetOutOfRange ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_OFFSET_OUT_OF_RANGE)
   145      // ErrInvalidMsg Broker: Invalid message
   146      ErrInvalidMsg ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_MSG)
   147      // ErrUnknownTopicOrPart Broker: Unknown topic or partition
   148      ErrUnknownTopicOrPart ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_UNKNOWN_TOPIC_OR_PART)
   149      // ErrInvalidMsgSize Broker: Invalid message size
   150      ErrInvalidMsgSize ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_MSG_SIZE)
   151      // ErrLeaderNotAvailable Broker: Leader not available
   152      ErrLeaderNotAvailable ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_LEADER_NOT_AVAILABLE)
   153      // ErrNotLeaderForPartition Broker: Not leader for partition
   154      ErrNotLeaderForPartition ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_NOT_LEADER_FOR_PARTITION)
   155      // ErrRequestTimedOut Broker: Request timed out
   156      ErrRequestTimedOut ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_REQUEST_TIMED_OUT)
   157      // ErrBrokerNotAvailable Broker: Broker not available
   158      ErrBrokerNotAvailable ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_BROKER_NOT_AVAILABLE)
   159      // ErrReplicaNotAvailable Broker: Replica not available
   160      ErrReplicaNotAvailable ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_REPLICA_NOT_AVAILABLE)
   161      // ErrMsgSizeTooLarge Broker: Message size too large
   162      ErrMsgSizeTooLarge ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_MSG_SIZE_TOO_LARGE)
   163      // ErrStaleCtrlEpoch Broker: StaleControllerEpochCode
   164      ErrStaleCtrlEpoch ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_STALE_CTRL_EPOCH)
   165      // ErrOffsetMetadataTooLarge Broker: Offset metadata string too large
   166      ErrOffsetMetadataTooLarge ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_OFFSET_METADATA_TOO_LARGE)
   167      // ErrNetworkException Broker: Broker disconnected before response received
   168      ErrNetworkException ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_NETWORK_EXCEPTION)
   169      // ErrCoordinatorLoadInProgress Broker: Coordinator load in progress
   170      ErrCoordinatorLoadInProgress ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_COORDINATOR_LOAD_IN_PROGRESS)
   171      // ErrCoordinatorNotAvailable Broker: Coordinator not available
   172      ErrCoordinatorNotAvailable ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_COORDINATOR_NOT_AVAILABLE)
   173      // ErrNotCoordinator Broker: Not coordinator
   174      ErrNotCoordinator ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_NOT_COORDINATOR)
   175      // ErrTopicException Broker: Invalid topic
   176      ErrTopicException ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_TOPIC_EXCEPTION)
   177      // ErrRecordListTooLarge Broker: Message batch larger than configured server segment size
   178      ErrRecordListTooLarge ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_RECORD_LIST_TOO_LARGE)
   179      // ErrNotEnoughReplicas Broker: Not enough in-sync replicas
   180      ErrNotEnoughReplicas ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_NOT_ENOUGH_REPLICAS)
   181      // ErrNotEnoughReplicasAfterAppend Broker: Message(s) written to insufficient number of in-sync replicas
   182      ErrNotEnoughReplicasAfterAppend ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_NOT_ENOUGH_REPLICAS_AFTER_APPEND)
   183      // ErrInvalidRequiredAcks Broker: Invalid required acks value
   184      ErrInvalidRequiredAcks ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_REQUIRED_ACKS)
   185      // ErrIllegalGeneration Broker: Specified group generation id is not valid
   186      ErrIllegalGeneration ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_ILLEGAL_GENERATION)
   187      // ErrInconsistentGroupProtocol Broker: Inconsistent group protocol
   188      ErrInconsistentGroupProtocol ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INCONSISTENT_GROUP_PROTOCOL)
   189      // ErrInvalidGroupID Broker: Invalid group.id
   190      ErrInvalidGroupID ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_GROUP_ID)
   191      // ErrUnknownMemberID Broker: Unknown member
   192      ErrUnknownMemberID ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_UNKNOWN_MEMBER_ID)
   193      // ErrInvalidSessionTimeout Broker: Invalid session timeout
   194      ErrInvalidSessionTimeout ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_SESSION_TIMEOUT)
   195      // ErrRebalanceInProgress Broker: Group rebalance in progress
   196      ErrRebalanceInProgress ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_REBALANCE_IN_PROGRESS)
   197      // ErrInvalidCommitOffsetSize Broker: Commit offset data size is not valid
   198      ErrInvalidCommitOffsetSize ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_COMMIT_OFFSET_SIZE)
   199      // ErrTopicAuthorizationFailed Broker: Topic authorization failed
   200      ErrTopicAuthorizationFailed ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_TOPIC_AUTHORIZATION_FAILED)
   201      // ErrGroupAuthorizationFailed Broker: Group authorization failed
   202      ErrGroupAuthorizationFailed ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_GROUP_AUTHORIZATION_FAILED)
   203      // ErrClusterAuthorizationFailed Broker: Cluster authorization failed
   204      ErrClusterAuthorizationFailed ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_CLUSTER_AUTHORIZATION_FAILED)
   205      // ErrInvalidTimestamp Broker: Invalid timestamp
   206      ErrInvalidTimestamp ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_TIMESTAMP)
   207      // ErrUnsupportedSaslMechanism Broker: Unsupported SASL mechanism
   208      ErrUnsupportedSaslMechanism ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_UNSUPPORTED_SASL_MECHANISM)
   209      // ErrIllegalSaslState Broker: Request not valid in current SASL state
   210      ErrIllegalSaslState ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_ILLEGAL_SASL_STATE)
   211      // ErrUnsupportedVersion Broker: API version not supported
   212      ErrUnsupportedVersion ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_UNSUPPORTED_VERSION)
   213      // ErrTopicAlreadyExists Broker: Topic already exists
   214      ErrTopicAlreadyExists ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_TOPIC_ALREADY_EXISTS)
   215      // ErrInvalidPartitions Broker: Invalid number of partitions
   216      ErrInvalidPartitions ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_PARTITIONS)
   217      // ErrInvalidReplicationFactor Broker: Invalid replication factor
   218      ErrInvalidReplicationFactor ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_REPLICATION_FACTOR)
   219      // ErrInvalidReplicaAssignment Broker: Invalid replica assignment
   220      ErrInvalidReplicaAssignment ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_REPLICA_ASSIGNMENT)
   221      // ErrInvalidConfig Broker: Configuration is invalid
   222      ErrInvalidConfig ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_CONFIG)
   223      // ErrNotController Broker: Not controller for cluster
   224      ErrNotController ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_NOT_CONTROLLER)
   225      // ErrInvalidRequest Broker: Invalid request
   226      ErrInvalidRequest ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_REQUEST)
   227      // ErrUnsupportedForMessageFormat Broker: Message format on broker does not support request
   228      ErrUnsupportedForMessageFormat ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_UNSUPPORTED_FOR_MESSAGE_FORMAT)
   229      // ErrPolicyViolation Broker: Policy violation
   230      ErrPolicyViolation ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_POLICY_VIOLATION)
   231      // ErrOutOfOrderSequenceNumber Broker: Broker received an out of order sequence number
   232      ErrOutOfOrderSequenceNumber ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_OUT_OF_ORDER_SEQUENCE_NUMBER)
   233      // ErrDuplicateSequenceNumber Broker: Broker received a duplicate sequence number
   234      ErrDuplicateSequenceNumber ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_DUPLICATE_SEQUENCE_NUMBER)
   235      // ErrInvalidProducerEpoch Broker: Producer attempted an operation with an old epoch
   236      ErrInvalidProducerEpoch ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_PRODUCER_EPOCH)
   237      // ErrInvalidTxnState Broker: Producer attempted a transactional operation in an invalid state
   238      ErrInvalidTxnState ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_TXN_STATE)
   239      // ErrInvalidProducerIDMapping Broker: Producer attempted to use a producer id which is not currently assigned to its transactional id
   240      ErrInvalidProducerIDMapping ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_PRODUCER_ID_MAPPING)
   241      // ErrInvalidTransactionTimeout Broker: Transaction timeout is larger than the maximum value allowed by the broker's max.transaction.timeout.ms
   242      ErrInvalidTransactionTimeout ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_TRANSACTION_TIMEOUT)
   243      // ErrConcurrentTransactions Broker: Producer attempted to update a transaction while another concurrent operation on the same transaction was ongoing
   244      ErrConcurrentTransactions ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_CONCURRENT_TRANSACTIONS)
   245      // ErrTransactionCoordinatorFenced Broker: Indicates that the transaction coordinator sending a WriteTxnMarker is no longer the current coordinator for a given producer
   246      ErrTransactionCoordinatorFenced ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_TRANSACTION_COORDINATOR_FENCED)
   247      // ErrTransactionalIDAuthorizationFailed Broker: Transactional Id authorization failed
   248      ErrTransactionalIDAuthorizationFailed ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_TRANSACTIONAL_ID_AUTHORIZATION_FAILED)
   249      // ErrSecurityDisabled Broker: Security features are disabled
   250      ErrSecurityDisabled ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_SECURITY_DISABLED)
   251      // ErrOperationNotAttempted Broker: Operation not attempted
   252      ErrOperationNotAttempted ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_OPERATION_NOT_ATTEMPTED)
   253      // ErrKafkaStorageError Broker: Disk error when trying to access log file on disk
   254      ErrKafkaStorageError ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_KAFKA_STORAGE_ERROR)
   255      // ErrLogDirNotFound Broker: The user-specified log directory is not found in the broker config
   256      ErrLogDirNotFound ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_LOG_DIR_NOT_FOUND)
   257      // ErrSaslAuthenticationFailed Broker: SASL Authentication failed
   258      ErrSaslAuthenticationFailed ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_SASL_AUTHENTICATION_FAILED)
   259      // ErrUnknownProducerID Broker: Unknown Producer Id
   260      ErrUnknownProducerID ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_UNKNOWN_PRODUCER_ID)
   261      // ErrReassignmentInProgress Broker: Partition reassignment is in progress
   262      ErrReassignmentInProgress ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_REASSIGNMENT_IN_PROGRESS)
   263      // ErrDelegationTokenAuthDisabled Broker: Delegation Token feature is not enabled
   264      ErrDelegationTokenAuthDisabled ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_AUTH_DISABLED)
   265      // ErrDelegationTokenNotFound Broker: Delegation Token is not found on server
   266      ErrDelegationTokenNotFound ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_NOT_FOUND)
   267      // ErrDelegationTokenOwnerMismatch Broker: Specified Principal is not valid Owner/Renewer
   268      ErrDelegationTokenOwnerMismatch ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_OWNER_MISMATCH)
   269      // ErrDelegationTokenRequestNotAllowed Broker: Delegation Token requests are not allowed on this connection
   270      ErrDelegationTokenRequestNotAllowed ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_REQUEST_NOT_ALLOWED)
   271      // ErrDelegationTokenAuthorizationFailed Broker: Delegation Token authorization failed
   272      ErrDelegationTokenAuthorizationFailed ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_AUTHORIZATION_FAILED)
   273      // ErrDelegationTokenExpired Broker: Delegation Token is expired
   274      ErrDelegationTokenExpired ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_EXPIRED)
   275      // ErrInvalidPrincipalType Broker: Supplied principalType is not supported
   276      ErrInvalidPrincipalType ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_PRINCIPAL_TYPE)
   277      // ErrNonEmptyGroup Broker: The group is not empty
   278      ErrNonEmptyGroup ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_NON_EMPTY_GROUP)
   279      // ErrGroupIDNotFound Broker: The group id does not exist
   280      ErrGroupIDNotFound ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_GROUP_ID_NOT_FOUND)
   281      // ErrFetchSessionIDNotFound Broker: The fetch session ID was not found
   282      ErrFetchSessionIDNotFound ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_FETCH_SESSION_ID_NOT_FOUND)
   283      // ErrInvalidFetchSessionEpoch Broker: The fetch session epoch is invalid
   284      ErrInvalidFetchSessionEpoch ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_FETCH_SESSION_EPOCH)
   285      // ErrListenerNotFound Broker: No matching listener
   286      ErrListenerNotFound ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_LISTENER_NOT_FOUND)
   287      // ErrTopicDeletionDisabled Broker: Topic deletion is disabled
   288      ErrTopicDeletionDisabled ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_TOPIC_DELETION_DISABLED)
   289      // ErrFencedLeaderEpoch Broker: Leader epoch is older than broker epoch
   290      ErrFencedLeaderEpoch ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_FENCED_LEADER_EPOCH)
   291      // ErrUnknownLeaderEpoch Broker: Leader epoch is newer than broker epoch
   292      ErrUnknownLeaderEpoch ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_UNKNOWN_LEADER_EPOCH)
   293      // ErrUnsupportedCompressionType Broker: Unsupported compression type
   294      ErrUnsupportedCompressionType ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_UNSUPPORTED_COMPRESSION_TYPE)
   295      // ErrStaleBrokerEpoch Broker: Broker epoch has changed
   296      ErrStaleBrokerEpoch ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_STALE_BROKER_EPOCH)
   297      // ErrOffsetNotAvailable Broker: Leader high watermark is not caught up
   298      ErrOffsetNotAvailable ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_OFFSET_NOT_AVAILABLE)
   299      // ErrMemberIDRequired Broker: Group member needs a valid member ID
   300      ErrMemberIDRequired ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_MEMBER_ID_REQUIRED)
   301      // ErrPreferredLeaderNotAvailable Broker: Preferred leader was not available
   302      ErrPreferredLeaderNotAvailable ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_PREFERRED_LEADER_NOT_AVAILABLE)
   303      // ErrGroupMaxSizeReached Broker: Consumer group has reached maximum size
   304      ErrGroupMaxSizeReached ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_GROUP_MAX_SIZE_REACHED)
   305      // ErrFencedInstanceID Broker: Static consumer fenced by other consumer with same group.instance.id
   306      ErrFencedInstanceID ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_FENCED_INSTANCE_ID)
   307      // ErrEligibleLeadersNotAvailable Broker: Eligible partition leaders are not available
   308      ErrEligibleLeadersNotAvailable ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_ELIGIBLE_LEADERS_NOT_AVAILABLE)
   309      // ErrElectionNotNeeded Broker: Leader election not needed for topic partition
   310      ErrElectionNotNeeded ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_ELECTION_NOT_NEEDED)
   311      // ErrNoReassignmentInProgress Broker: No partition reassignment is in progress
   312      ErrNoReassignmentInProgress ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_NO_REASSIGNMENT_IN_PROGRESS)
   313      // ErrGroupSubscribedToTopic Broker: Deleting offsets of a topic while the consumer group is subscribed to it
   314      ErrGroupSubscribedToTopic ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_GROUP_SUBSCRIBED_TO_TOPIC)
   315      // ErrInvalidRecord Broker: Broker failed to validate record
   316      ErrInvalidRecord ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_RECORD)
   317      // ErrUnstableOffsetCommit Broker: There are unstable offsets that need to be cleared
   318      ErrUnstableOffsetCommit ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_UNSTABLE_OFFSET_COMMIT)
   319      // ErrThrottlingQuotaExceeded Broker: Throttling quota has been exceeded
   320      ErrThrottlingQuotaExceeded ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_THROTTLING_QUOTA_EXCEEDED)
   321      // ErrProducerFenced Broker: There is a newer producer with the same transactionalId which fences the current one
   322      ErrProducerFenced ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_PRODUCER_FENCED)
   323      // ErrResourceNotFound Broker: Request illegally referred to resource that does not exist
   324      ErrResourceNotFound ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_RESOURCE_NOT_FOUND)
   325      // ErrDuplicateResource Broker: Request illegally referred to the same resource twice
   326      ErrDuplicateResource ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_DUPLICATE_RESOURCE)
   327      // ErrUnacceptableCredential Broker: Requested credential would not meet criteria for acceptability
   328      ErrUnacceptableCredential ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_UNACCEPTABLE_CREDENTIAL)
   329      // ErrInconsistentVoterSet Broker: Indicates that the either the sender or recipient of a voter-only request is not one of the expected voters
   330      ErrInconsistentVoterSet ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INCONSISTENT_VOTER_SET)
   331      // ErrInvalidUpdateVersion Broker: Invalid update version
   332      ErrInvalidUpdateVersion ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_INVALID_UPDATE_VERSION)
   333      // ErrFeatureUpdateFailed Broker: Unable to update finalized features due to server error
   334      ErrFeatureUpdateFailed ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_FEATURE_UPDATE_FAILED)
   335      // ErrPrincipalDeserializationFailure Broker: Request principal deserialization failed during forwarding
   336      ErrPrincipalDeserializationFailure ErrorCode = ErrorCode(C.RD_KAFKA_RESP_ERR_PRINCIPAL_DESERIALIZATION_FAILURE)
   337  )