| 123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607 | package kafkaimport (	"errors"	"fmt"	"io"	"syscall")// Error represents the different error codes that may be returned by kafka.// https://kafka.apache.org/protocol#protocol_error_codestype Error intconst (	Unknown                            Error = -1	OffsetOutOfRange                   Error = 1	InvalidMessage                     Error = 2	UnknownTopicOrPartition            Error = 3	InvalidMessageSize                 Error = 4	LeaderNotAvailable                 Error = 5	NotLeaderForPartition              Error = 6	RequestTimedOut                    Error = 7	BrokerNotAvailable                 Error = 8	ReplicaNotAvailable                Error = 9	MessageSizeTooLarge                Error = 10	StaleControllerEpoch               Error = 11	OffsetMetadataTooLarge             Error = 12	NetworkException                   Error = 13	GroupLoadInProgress                Error = 14	GroupCoordinatorNotAvailable       Error = 15	NotCoordinatorForGroup             Error = 16	InvalidTopic                       Error = 17	RecordListTooLarge                 Error = 18	NotEnoughReplicas                  Error = 19	NotEnoughReplicasAfterAppend       Error = 20	InvalidRequiredAcks                Error = 21	IllegalGeneration                  Error = 22	InconsistentGroupProtocol          Error = 23	InvalidGroupId                     Error = 24	UnknownMemberId                    Error = 25	InvalidSessionTimeout              Error = 26	RebalanceInProgress                Error = 27	InvalidCommitOffsetSize            Error = 28	TopicAuthorizationFailed           Error = 29	GroupAuthorizationFailed           Error = 30	ClusterAuthorizationFailed         Error = 31	InvalidTimestamp                   Error = 32	UnsupportedSASLMechanism           Error = 33	IllegalSASLState                   Error = 34	UnsupportedVersion                 Error = 35	TopicAlreadyExists                 Error = 36	InvalidPartitionNumber             Error = 37	InvalidReplicationFactor           Error = 38	InvalidReplicaAssignment           Error = 39	InvalidConfiguration               Error = 40	NotController                      Error = 41	InvalidRequest                     Error = 42	UnsupportedForMessageFormat        Error = 43	PolicyViolation                    Error = 44	OutOfOrderSequenceNumber           Error = 45	DuplicateSequenceNumber            Error = 46	InvalidProducerEpoch               Error = 47	InvalidTransactionState            Error = 48	InvalidProducerIDMapping           Error = 49	InvalidTransactionTimeout          Error = 50	ConcurrentTransactions             Error = 51	TransactionCoordinatorFenced       Error = 52	TransactionalIDAuthorizationFailed Error = 53	SecurityDisabled                   Error = 54	BrokerAuthorizationFailed          Error = 55	KafkaStorageError                  Error = 56	LogDirNotFound                     Error = 57	SASLAuthenticationFailed           Error = 58	UnknownProducerId                  Error = 59	ReassignmentInProgress             Error = 60	DelegationTokenAuthDisabled        Error = 61	DelegationTokenNotFound            Error = 62	DelegationTokenOwnerMismatch       Error = 63	DelegationTokenRequestNotAllowed   Error = 64	DelegationTokenAuthorizationFailed Error = 65	DelegationTokenExpired             Error = 66	InvalidPrincipalType               Error = 67	NonEmptyGroup                      Error = 68	GroupIdNotFound                    Error = 69	FetchSessionIDNotFound             Error = 70	InvalidFetchSessionEpoch           Error = 71	ListenerNotFound                   Error = 72	TopicDeletionDisabled              Error = 73	FencedLeaderEpoch                  Error = 74	UnknownLeaderEpoch                 Error = 75	UnsupportedCompressionType         Error = 76	StaleBrokerEpoch                   Error = 77	OffsetNotAvailable                 Error = 78	MemberIDRequired                   Error = 79	PreferredLeaderNotAvailable        Error = 80	GroupMaxSizeReached                Error = 81	FencedInstanceID                   Error = 82	EligibleLeadersNotAvailable        Error = 83	ElectionNotNeeded                  Error = 84	NoReassignmentInProgress           Error = 85	GroupSubscribedToTopic             Error = 86	InvalidRecord                      Error = 87	UnstableOffsetCommit               Error = 88)// Error satisfies the error interface.func (e Error) Error() string {	return fmt.Sprintf("[%d] %s: %s", e, e.Title(), e.Description())}// Timeout returns true if the error was due to a timeout.func (e Error) Timeout() bool {	return e == RequestTimedOut}// Temporary returns true if the operation that generated the error may succeed// if retried at a later time.// Kafka error documentation specifies these as "retriable"// https://kafka.apache.org/protocol#protocol_error_codesfunc (e Error) Temporary() bool {	switch e {	case InvalidMessage,		UnknownTopicOrPartition,		LeaderNotAvailable,		NotLeaderForPartition,		RequestTimedOut,		NetworkException,		GroupLoadInProgress,		GroupCoordinatorNotAvailable,		NotCoordinatorForGroup,		NotEnoughReplicas,		NotEnoughReplicasAfterAppend,		NotController,		KafkaStorageError,		FetchSessionIDNotFound,		InvalidFetchSessionEpoch,		ListenerNotFound,		FencedLeaderEpoch,		UnknownLeaderEpoch,		OffsetNotAvailable,		PreferredLeaderNotAvailable,		EligibleLeadersNotAvailable,		ElectionNotNeeded,		NoReassignmentInProgress,		GroupSubscribedToTopic,		UnstableOffsetCommit:		return true	default:		return false	}}// Title returns a human readable title for the error.func (e Error) Title() string {	switch e {	case Unknown:		return "Unknown"	case OffsetOutOfRange:		return "Offset Out Of Range"	case InvalidMessage:		return "Invalid Message"	case UnknownTopicOrPartition:		return "Unknown Topic Or Partition"	case InvalidMessageSize:		return "Invalid Message Size"	case LeaderNotAvailable:		return "Leader Not Available"	case NotLeaderForPartition:		return "Not Leader For Partition"	case RequestTimedOut:		return "Request Timed Out"	case BrokerNotAvailable:		return "Broker Not Available"	case ReplicaNotAvailable:		return "Replica Not Available"	case MessageSizeTooLarge:		return "Message Size Too Large"	case StaleControllerEpoch:		return "Stale Controller Epoch"	case OffsetMetadataTooLarge:		return "Offset Metadata Too Large"	case GroupLoadInProgress:		return "Group Load In Progress"	case GroupCoordinatorNotAvailable:		return "Group Coordinator Not Available"	case NotCoordinatorForGroup:		return "Not Coordinator For Group"	case InvalidTopic:		return "Invalid Topic"	case RecordListTooLarge:		return "Record List Too Large"	case NotEnoughReplicas:		return "Not Enough Replicas"	case NotEnoughReplicasAfterAppend:		return "Not Enough Replicas After Append"	case InvalidRequiredAcks:		return "Invalid Required Acks"	case IllegalGeneration:		return "Illegal Generation"	case InconsistentGroupProtocol:		return "Inconsistent Group Protocol"	case InvalidGroupId:		return "Invalid Group ID"	case UnknownMemberId:		return "Unknown Member ID"	case InvalidSessionTimeout:		return "Invalid Session Timeout"	case RebalanceInProgress:		return "Rebalance In Progress"	case InvalidCommitOffsetSize:		return "Invalid Commit Offset Size"	case TopicAuthorizationFailed:		return "Topic Authorization Failed"	case GroupAuthorizationFailed:		return "Group Authorization Failed"	case ClusterAuthorizationFailed:		return "Cluster Authorization Failed"	case InvalidTimestamp:		return "Invalid Timestamp"	case UnsupportedSASLMechanism:		return "Unsupported SASL Mechanism"	case IllegalSASLState:		return "Illegal SASL State"	case UnsupportedVersion:		return "Unsupported Version"	case TopicAlreadyExists:		return "Topic Already Exists"	case InvalidPartitionNumber:		return "Invalid Partition Number"	case InvalidReplicationFactor:		return "Invalid Replication Factor"	case InvalidReplicaAssignment:		return "Invalid Replica Assignment"	case InvalidConfiguration:		return "Invalid Configuration"	case NotController:		return "Not Controller"	case InvalidRequest:		return "Invalid Request"	case UnsupportedForMessageFormat:		return "Unsupported For Message Format"	case PolicyViolation:		return "Policy Violation"	case OutOfOrderSequenceNumber:		return "Out Of Order Sequence Number"	case DuplicateSequenceNumber:		return "Duplicate Sequence Number"	case InvalidProducerEpoch:		return "Invalid Producer Epoch"	case InvalidTransactionState:		return "Invalid Transaction State"	case InvalidProducerIDMapping:		return "Invalid Producer ID Mapping"	case InvalidTransactionTimeout:		return "Invalid Transaction Timeout"	case ConcurrentTransactions:		return "Concurrent Transactions"	case TransactionCoordinatorFenced:		return "Transaction Coordinator Fenced"	case TransactionalIDAuthorizationFailed:		return "Transactional ID Authorization Failed"	case SecurityDisabled:		return "Security Disabled"	case BrokerAuthorizationFailed:		return "Broker Authorization Failed"	case KafkaStorageError:		return "Kafka Storage Error"	case LogDirNotFound:		return "Log Dir Not Found"	case SASLAuthenticationFailed:		return "SASL Authentication Failed"	case UnknownProducerId:		return "Unknown Producer ID"	case ReassignmentInProgress:		return "Reassignment In Progress"	case DelegationTokenAuthDisabled:		return "Delegation Token Auth Disabled"	case DelegationTokenNotFound:		return "Delegation Token Not Found"	case DelegationTokenOwnerMismatch:		return "Delegation Token Owner Mismatch"	case DelegationTokenRequestNotAllowed:		return "Delegation Token Request Not Allowed"	case DelegationTokenAuthorizationFailed:		return "Delegation Token Authorization Failed"	case DelegationTokenExpired:		return "Delegation Token Expired"	case InvalidPrincipalType:		return "Invalid Principal Type"	case NonEmptyGroup:		return "Non Empty Group"	case GroupIdNotFound:		return "Group ID Not Found"	case FetchSessionIDNotFound:		return "Fetch Session ID Not Found"	case InvalidFetchSessionEpoch:		return "Invalid Fetch Session Epoch"	case ListenerNotFound:		return "Listener Not Found"	case TopicDeletionDisabled:		return "Topic Deletion Disabled"	case FencedLeaderEpoch:		return "Fenced Leader Epoch"	case UnknownLeaderEpoch:		return "Unknown Leader Epoch"	case UnsupportedCompressionType:		return "Unsupported Compression Type"	case EligibleLeadersNotAvailable:		return "Eligible Leader Not Available"	case ElectionNotNeeded:		return "Election Not Needed"	case NoReassignmentInProgress:		return "No Reassignment In Progress"	case GroupSubscribedToTopic:		return "Group Subscribed To Topic"	case InvalidRecord:		return "Invalid Record"	case UnstableOffsetCommit:		return "Unstable Offset Commit"	}	return ""}// Description returns a human readable description of cause of the error.func (e Error) Description() string {	switch e {	case Unknown:		return "an unexpected server error occurred"	case OffsetOutOfRange:		return "the requested offset is outside the range of offsets maintained by the server for the given topic/partition"	case InvalidMessage:		return "the message contents does not match its CRC"	case UnknownTopicOrPartition:		return "the request is for a topic or partition that does not exist on this broker"	case InvalidMessageSize:		return "the message has a negative size"	case LeaderNotAvailable:		return "the cluster is in the middle of a leadership election and there is currently no leader for this partition and hence it is unavailable for writes"	case NotLeaderForPartition:		return "the client attempted to send messages to a replica that is not the leader for some partition, the client's metadata are likely out of date"	case RequestTimedOut:		return "the request exceeded the user-specified time limit in the request"	case BrokerNotAvailable:		return "not a client facing error and is used mostly by tools when a broker is not alive"	case ReplicaNotAvailable:		return "a replica is expected on a broker, but is not (this can be safely ignored)"	case MessageSizeTooLarge:		return "the server has a configurable maximum message size to avoid unbounded memory allocation and the client attempted to produce a message larger than this maximum"	case StaleControllerEpoch:		return "internal error code for broker-to-broker communication"	case OffsetMetadataTooLarge:		return "the client specified a string larger than configured maximum for offset metadata"	case GroupLoadInProgress:		return "the broker returns this error code for an offset fetch request if it is still loading offsets (after a leader change for that offsets topic partition), or in response to group membership requests (such as heartbeats) when group metadata is being loaded by the coordinator"	case GroupCoordinatorNotAvailable:		return "the broker returns this error code for group coordinator requests, offset commits, and most group management requests if the offsets topic has not yet been created, or if the group coordinator is not active"	case NotCoordinatorForGroup:		return "the broker returns this error code if it receives an offset fetch or commit request for a group that it is not a coordinator for"	case InvalidTopic:		return "a request which attempted to access an invalid topic (e.g. one which has an illegal name), or if an attempt was made to write to an internal topic (such as the consumer offsets topic)"	case RecordListTooLarge:		return "a message batch in a produce request exceeds the maximum configured segment size"	case NotEnoughReplicas:		return "the number of in-sync replicas is lower than the configured minimum and requiredAcks is -1"	case NotEnoughReplicasAfterAppend:		return "the message was written to the log, but with fewer in-sync replicas than required."	case InvalidRequiredAcks:		return "the requested requiredAcks is invalid (anything other than -1, 1, or 0)"	case IllegalGeneration:		return "the generation id provided in the request is not the current generation"	case InconsistentGroupProtocol:		return "the member provided a protocol type or set of protocols which is not compatible with the current group"	case InvalidGroupId:		return "the group id is empty or null"	case UnknownMemberId:		return "the member id is not in the current generation"	case InvalidSessionTimeout:		return "the requested session timeout is outside of the allowed range on the broker"	case RebalanceInProgress:		return "the coordinator has begun rebalancing the group, the client should rejoin the group"	case InvalidCommitOffsetSize:		return "an offset commit was rejected because of oversize metadata"	case TopicAuthorizationFailed:		return "the client is not authorized to access the requested topic"	case GroupAuthorizationFailed:		return "the client is not authorized to access a particular group id"	case ClusterAuthorizationFailed:		return "the client is not authorized to use an inter-broker or administrative API"	case InvalidTimestamp:		return "the timestamp of the message is out of acceptable range"	case UnsupportedSASLMechanism:		return "the broker does not support the requested SASL mechanism"	case IllegalSASLState:		return "the request is not valid given the current SASL state"	case UnsupportedVersion:		return "the version of API is not supported"	case TopicAlreadyExists:		return "a topic with this name already exists"	case InvalidPartitionNumber:		return "the number of partitions is invalid"	case InvalidReplicationFactor:		return "the replication-factor is invalid"	case InvalidReplicaAssignment:		return "the replica assignment is invalid"	case InvalidConfiguration:		return "the configuration is invalid"	case NotController:		return "this is not the correct controller for this cluster"	case InvalidRequest:		return "this most likely occurs because of a request being malformed by the client library or the message was sent to an incompatible broker, se the broker logs for more details"	case UnsupportedForMessageFormat:		return "the message format version on the broker does not support the request"	case PolicyViolation:		return "the request parameters do not satisfy the configured policy"	case OutOfOrderSequenceNumber:		return "the broker received an out of order sequence number"	case DuplicateSequenceNumber:		return "the broker received a duplicate sequence number"	case InvalidProducerEpoch:		return "the producer attempted an operation with an old epoch, either there is a newer producer with the same transactional ID, or the producer's transaction has been expired by the broker"	case InvalidTransactionState:		return "the producer attempted a transactional operation in an invalid state"	case InvalidProducerIDMapping:		return "the producer attempted to use a producer id which is not currently assigned to its transactional ID"	case InvalidTransactionTimeout:		return "the transaction timeout is larger than the maximum value allowed by the broker (as configured by max.transaction.timeout.ms)"	case ConcurrentTransactions:		return "the producer attempted to update a transaction while another concurrent operation on the same transaction was ongoing"	case TransactionCoordinatorFenced:		return "the transaction coordinator sending a WriteTxnMarker is no longer the current coordinator for a given producer"	case TransactionalIDAuthorizationFailed:		return "the transactional ID authorization failed"	case SecurityDisabled:		return "the security features are disabled"	case BrokerAuthorizationFailed:		return "the broker authorization failed"	case KafkaStorageError:		return "disk error when trying to access log file on the disk"	case LogDirNotFound:		return "the user-specified log directory is not found in the broker config"	case SASLAuthenticationFailed:		return "SASL Authentication failed"	case UnknownProducerId:		return "the broker could not locate the producer metadata associated with the producer ID"	case ReassignmentInProgress:		return "a partition reassignment is in progress"	case DelegationTokenAuthDisabled:		return "delegation token feature is not enabled"	case DelegationTokenNotFound:		return "delegation token is not found on server"	case DelegationTokenOwnerMismatch:		return "specified principal is not valid owner/renewer"	case DelegationTokenRequestNotAllowed:		return "delegation token requests are not allowed on plaintext/1-way ssl channels and on delegation token authenticated channels"	case DelegationTokenAuthorizationFailed:		return "delegation token authorization failed"	case DelegationTokenExpired:		return "delegation token is expired"	case InvalidPrincipalType:		return "supplied principaltype is not supported"	case NonEmptyGroup:		return "the group is not empty"	case GroupIdNotFound:		return "the group ID does not exist"	case FetchSessionIDNotFound:		return "the fetch session ID was not found"	case InvalidFetchSessionEpoch:		return "the fetch session epoch is invalid"	case ListenerNotFound:		return "there is no listener on the leader broker that matches the listener on which metadata request was processed"	case TopicDeletionDisabled:		return "topic deletion is disabled"	case FencedLeaderEpoch:		return "the leader epoch in the request is older than the epoch on the broker"	case UnknownLeaderEpoch:		return "the leader epoch in the request is newer than the epoch on the broker"	case UnsupportedCompressionType:		return "the requesting client does not support the compression type of given partition"	case EligibleLeadersNotAvailable:		return "eligible topic partition leaders are not available"	case ElectionNotNeeded:		return "leader election not needed for topic partition"	case NoReassignmentInProgress:		return "no partition reassignment is in progress"	case GroupSubscribedToTopic:		return "deleting offsets of a topic is forbidden while the consumer group is actively subscribed to it"	case InvalidRecord:		return "this record has failed the validation on broker and hence be rejected"	case UnstableOffsetCommit:		return "there are unstable offsets that need to be cleared"	}	return ""}func isTimeout(err error) bool {	var timeoutError interface{ Timeout() bool }	if errors.As(err, &timeoutError) {		return timeoutError.Timeout()	}	return false}func isTemporary(err error) bool {	var tempError interface{ Temporary() bool }	if errors.As(err, &tempError) {		return tempError.Temporary()	}	return false}func isTransientNetworkError(err error) bool {	return errors.Is(err, io.ErrUnexpectedEOF) ||		errors.Is(err, syscall.ECONNREFUSED) ||		errors.Is(err, syscall.ECONNRESET) ||		errors.Is(err, syscall.EPIPE)}func silentEOF(err error) error {	if err == io.EOF {		err = nil	}	return err}func dontExpectEOF(err error) error {	if err == io.EOF {		err = io.ErrUnexpectedEOF	}	return err}func coalesceErrors(errs ...error) error {	for _, err := range errs {		if err != nil {			return err		}	}	return nil}type MessageTooLargeError struct {	Message   Message	Remaining []Message}func messageTooLarge(msgs []Message, i int) MessageTooLargeError {	remain := make([]Message, 0, len(msgs)-1)	remain = append(remain, msgs[:i]...)	remain = append(remain, msgs[i+1:]...)	return MessageTooLargeError{		Message:   msgs[i],		Remaining: remain,	}}func (e MessageTooLargeError) Error() string {	return MessageSizeTooLarge.Error()}func makeError(code int16, message string) error {	if code == 0 {		return nil	}	if message == "" {		return Error(code)	}	return fmt.Errorf("%w: %s", Error(code), message)}// WriteError is returned by kafka.(*Writer).WriteMessages when the writer is// not configured to write messages asynchronously. WriteError values contain// a list of errors where each entry matches the position of a message in the// WriteMessages call. The program can determine the status of each message by// looping over the error:////	switch err := w.WriteMessages(ctx, msgs...).(type) {//	case nil://	case kafka.WriteErrors://		for i := range msgs {//			if err[i] != nil {//				// handle the error writing msgs[i]//				...//			}//		}//	default://		// handle other errors//		...//	}//type WriteErrors []error// Count counts the number of non-nil errors in err.func (err WriteErrors) Count() int {	n := 0	for _, e := range err {		if e != nil {			n++		}	}	return n}func (err WriteErrors) Error() string {	return fmt.Sprintf("kafka write errors (%d/%d)", err.Count(), len(err))}
 |