Serialized Form
- 
Package org.apache.kafka.clients.consumer- 
Exception org.apache.kafka.clients.consumer.CommitFailedExceptionclass CommitFailedException extends KafkaException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.clients.consumer.InvalidOffsetExceptionclass InvalidOffsetException extends KafkaException implements Serializable
- 
Exception org.apache.kafka.clients.consumer.LogTruncationExceptionclass LogTruncationException extends OffsetOutOfRangeException implements Serializable- 
Serialized Fields- 
divergentOffsetsMap<TopicPartition, OffsetAndMetadata> divergentOffsets 
 
- 
 
- 
- 
Exception org.apache.kafka.clients.consumer.NoOffsetForPartitionExceptionclass NoOffsetForPartitionException extends InvalidOffsetException implements Serializable- serialVersionUID:
- 1L
 - 
Serialized Fields- 
partitionsSet<TopicPartition> partitions 
 
- 
 
- 
Class org.apache.kafka.clients.consumer.OffsetAndMetadataclass OffsetAndMetadata extends Object implements Serializable- serialVersionUID:
- 2019555404968089681L
 
- 
Exception org.apache.kafka.clients.consumer.OffsetOutOfRangeExceptionclass OffsetOutOfRangeException extends InvalidOffsetException implements Serializable- serialVersionUID:
- 1L
 - 
Serialized Fields- 
offsetOutOfRangePartitionsMap<TopicPartition, Long> offsetOutOfRangePartitions 
 
- 
 
- 
Exception org.apache.kafka.clients.consumer.RetriableCommitFailedExceptionclass RetriableCommitFailedException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
 
- 
- 
Package org.apache.kafka.clients.producer- 
Exception org.apache.kafka.clients.producer.BufferExhaustedExceptionclass BufferExhaustedException extends TimeoutException implements Serializable- serialVersionUID:
- 1L
 
 
- 
- 
Package org.apache.kafka.common- 
Exception org.apache.kafka.common.InvalidRecordExceptionclass InvalidRecordException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.KafkaExceptionclass KafkaException extends RuntimeException implements Serializable- serialVersionUID:
- 1L
 
- 
Class org.apache.kafka.common.TopicPartitionclass TopicPartition extends Object implements Serializable- serialVersionUID:
- -613627415771699627L
 - 
Serialized Fields- 
hashint hash 
- 
partitionint partition 
- 
topicString topic 
 
- 
 
- 
Class org.apache.kafka.common.TopicPartitionReplicaclass TopicPartitionReplica extends Object implements Serializable- 
Serialized Fields- 
brokerIdint brokerId 
- 
hashint hash 
- 
partitionint partition 
- 
topicString topic 
 
- 
 
- 
 
- 
- 
Package org.apache.kafka.common.config- 
Exception org.apache.kafka.common.config.ConfigExceptionclass ConfigException extends KafkaException implements Serializable- serialVersionUID:
- 1L
 
 
- 
- 
Package org.apache.kafka.common.errors- 
Exception org.apache.kafka.common.errors.ApiExceptionclass ApiException extends KafkaException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.AuthenticationExceptionclass AuthenticationException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.AuthorizationExceptionclass AuthorizationException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.AuthorizerNotReadyExceptionclass AuthorizerNotReadyException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.BrokerIdNotRegisteredExceptionclass BrokerIdNotRegisteredException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.BrokerNotAvailableExceptionclass BrokerNotAvailableException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.ClusterAuthorizationExceptionclass ClusterAuthorizationException extends AuthorizationException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.ConcurrentTransactionsExceptionclass ConcurrentTransactionsException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.ControllerMovedExceptionclass ControllerMovedException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.CoordinatorLoadInProgressExceptionclass CoordinatorLoadInProgressException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.CoordinatorNotAvailableExceptionclass CoordinatorNotAvailableException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.CorruptRecordExceptionclass CorruptRecordException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.DelegationTokenAuthorizationExceptionclass DelegationTokenAuthorizationException extends AuthorizationException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.DelegationTokenDisabledExceptionclass DelegationTokenDisabledException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.DelegationTokenExpiredExceptionclass DelegationTokenExpiredException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.DelegationTokenNotFoundExceptionclass DelegationTokenNotFoundException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.DelegationTokenOwnerMismatchExceptionclass DelegationTokenOwnerMismatchException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.DisconnectExceptionclass DisconnectException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.DuplicateBrokerRegistrationExceptionclass DuplicateBrokerRegistrationException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.DuplicateResourceExceptionclass DuplicateResourceException extends ApiException implements Serializable- serialVersionUID:
- 1L
 - 
Serialized Fields- 
resourceString resource 
 
- 
 
- 
Exception org.apache.kafka.common.errors.DuplicateSequenceExceptionclass DuplicateSequenceException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.DuplicateVoterExceptionclass DuplicateVoterException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.ElectionNotNeededExceptionclass ElectionNotNeededException extends InvalidMetadataException implements Serializable
- 
Exception org.apache.kafka.common.errors.EligibleLeadersNotAvailableExceptionclass EligibleLeadersNotAvailableException extends InvalidMetadataException implements Serializable
- 
Exception org.apache.kafka.common.errors.FeatureUpdateFailedExceptionclass FeatureUpdateFailedException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.FencedInstanceIdExceptionclass FencedInstanceIdException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.FencedLeaderEpochExceptionclass FencedLeaderEpochException extends InvalidMetadataException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.FencedMemberEpochExceptionclass FencedMemberEpochException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.FencedStateEpochExceptionclass FencedStateEpochException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.FetchSessionIdNotFoundExceptionclass FetchSessionIdNotFoundException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.FetchSessionTopicIdExceptionclass FetchSessionTopicIdException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.GroupAuthorizationExceptionclass GroupAuthorizationException extends AuthorizationException implements Serializable- 
Serialized Fields- 
groupIdString groupId 
 
- 
 
- 
- 
Exception org.apache.kafka.common.errors.GroupIdNotFoundExceptionclass GroupIdNotFoundException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.GroupMaxSizeReachedExceptionclass GroupMaxSizeReachedException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.GroupNotEmptyExceptionclass GroupNotEmptyException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.GroupSubscribedToTopicExceptionclass GroupSubscribedToTopicException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.IllegalGenerationExceptionclass IllegalGenerationException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.IllegalSaslStateExceptionclass IllegalSaslStateException extends AuthenticationException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InconsistentClusterIdExceptionclass InconsistentClusterIdException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.InconsistentGroupProtocolExceptionclass InconsistentGroupProtocolException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InconsistentTopicIdExceptionclass InconsistentTopicIdException extends InvalidMetadataException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InconsistentVoterSetExceptionclass InconsistentVoterSetException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.IneligibleReplicaExceptionclass IneligibleReplicaException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.InterruptExceptionclass InterruptException extends KafkaException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidCommitOffsetSizeExceptionclass InvalidCommitOffsetSizeException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidConfigurationExceptionclass InvalidConfigurationException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidFetchSessionEpochExceptionclass InvalidFetchSessionEpochException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidFetchSizeExceptionclass InvalidFetchSizeException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidGroupIdExceptionclass InvalidGroupIdException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidMetadataExceptionclass InvalidMetadataException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidOffsetExceptionclass InvalidOffsetException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidPartitionsExceptionclass InvalidPartitionsException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidPidMappingExceptionclass InvalidPidMappingException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.InvalidPrincipalTypeExceptionclass InvalidPrincipalTypeException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidProducerEpochExceptionclass InvalidProducerEpochException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidRecordStateExceptionclass InvalidRecordStateException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidRegistrationExceptionclass InvalidRegistrationException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidReplicaAssignmentExceptionclass InvalidReplicaAssignmentException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidReplicaDirectoriesExceptionclass InvalidReplicaDirectoriesException extends InvalidMetadataException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidReplicationFactorExceptionclass InvalidReplicationFactorException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidRequestExceptionclass InvalidRequestException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidRequiredAcksExceptionclass InvalidRequiredAcksException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidSessionTimeoutExceptionclass InvalidSessionTimeoutException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidTimestampExceptionclass InvalidTimestampException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidTopicExceptionclass InvalidTopicException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidTxnStateExceptionclass InvalidTxnStateException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.InvalidTxnTimeoutExceptionclass InvalidTxnTimeoutException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.InvalidUpdateVersionExceptionclass InvalidUpdateVersionException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.InvalidVoterKeyExceptionclass InvalidVoterKeyException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.KafkaStorageExceptionclass KafkaStorageException extends InvalidMetadataException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.LeaderNotAvailableExceptionclass LeaderNotAvailableException extends InvalidMetadataException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.ListenerNotFoundExceptionclass ListenerNotFoundException extends InvalidMetadataException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.LogDirNotFoundExceptionclass LogDirNotFoundException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.MemberIdRequiredExceptionclass MemberIdRequiredException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.MismatchedEndpointTypeExceptionclass MismatchedEndpointTypeException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.NetworkExceptionclass NetworkException extends InvalidMetadataException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.NewLeaderElectedExceptionclass NewLeaderElectedException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.NoReassignmentInProgressExceptionclass NoReassignmentInProgressException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.NotControllerExceptionclass NotControllerException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.NotCoordinatorExceptionclass NotCoordinatorException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.NotEnoughReplicasAfterAppendExceptionclass NotEnoughReplicasAfterAppendException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.NotEnoughReplicasExceptionclass NotEnoughReplicasException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.NotLeaderForPartitionExceptionclass NotLeaderForPartitionException extends InvalidMetadataException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.NotLeaderOrFollowerExceptionclass NotLeaderOrFollowerException extends NotLeaderForPartitionException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.OffsetMetadataTooLargeclass OffsetMetadataTooLarge extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.OffsetMovedToTieredStorageExceptionclass OffsetMovedToTieredStorageException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.OffsetNotAvailableExceptionclass OffsetNotAvailableException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.OffsetOutOfRangeExceptionclass OffsetOutOfRangeException extends InvalidOffsetException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.OperationNotAttemptedExceptionclass OperationNotAttemptedException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.OutOfOrderSequenceExceptionclass OutOfOrderSequenceException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.PolicyViolationExceptionclass PolicyViolationException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.PositionOutOfRangeExceptionclass PositionOutOfRangeException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.PreferredLeaderNotAvailableExceptionclass PreferredLeaderNotAvailableException extends InvalidMetadataException implements Serializable
- 
Exception org.apache.kafka.common.errors.PrincipalDeserializationExceptionclass PrincipalDeserializationException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.ProducerFencedExceptionclass ProducerFencedException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.ReassignmentInProgressExceptionclass ReassignmentInProgressException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.RebalanceInProgressExceptionclass RebalanceInProgressException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.RecordBatchTooLargeExceptionclass RecordBatchTooLargeException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.RecordDeserializationExceptionclass RecordDeserializationException extends SerializationException implements Serializable- serialVersionUID:
- 2L
 - 
Serialized Fields- 
headersHeaders headers 
- 
keyBufferByteBuffer keyBuffer 
- 
offsetlong offset 
- 
originRecordDeserializationException.DeserializationExceptionOrigin origin 
- 
partitionTopicPartition partition 
- 
timestamplong timestamp 
- 
timestampTypeorg.apache.kafka.common.record.TimestampType timestampType 
- 
valueBufferByteBuffer valueBuffer 
 
- 
 
- 
Exception org.apache.kafka.common.errors.RecordTooLargeExceptionclass RecordTooLargeException extends ApiException implements Serializable- serialVersionUID:
- 1L
 - 
Serialized Fields- 
recordTooLargePartitionsMap<TopicPartition, Long> recordTooLargePartitions 
 
- 
 
- 
Exception org.apache.kafka.common.errors.ReplicaNotAvailableExceptionclass ReplicaNotAvailableException extends InvalidMetadataException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.ResourceNotFoundExceptionclass ResourceNotFoundException extends ApiException implements Serializable- serialVersionUID:
- 1L
 - 
Serialized Fields- 
resourceString resource 
 
- 
 
- 
Exception org.apache.kafka.common.errors.RetriableExceptionclass RetriableException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.SaslAuthenticationExceptionclass SaslAuthenticationException extends AuthenticationException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.SecurityDisabledExceptionclass SecurityDisabledException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.SerializationExceptionclass SerializationException extends KafkaException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.SnapshotNotFoundExceptionclass SnapshotNotFoundException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.SslAuthenticationExceptionclass SslAuthenticationException extends AuthenticationException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.StaleBrokerEpochExceptionclass StaleBrokerEpochException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.StaleMemberEpochExceptionclass StaleMemberEpochException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.TelemetryTooLargeExceptionclass TelemetryTooLargeException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.ThrottlingQuotaExceededExceptionclass ThrottlingQuotaExceededException extends RetriableException implements Serializable- 
Serialized Fields- 
throttleTimeMsint throttleTimeMs 
 
- 
 
- 
- 
Exception org.apache.kafka.common.errors.TimeoutExceptionclass TimeoutException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.TopicAuthorizationExceptionclass TopicAuthorizationException extends AuthorizationException implements Serializable
- 
Exception org.apache.kafka.common.errors.TopicDeletionDisabledExceptionclass TopicDeletionDisabledException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.TopicExistsExceptionclass TopicExistsException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.TransactionAbortableExceptionclass TransactionAbortableException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.TransactionAbortedExceptionclass TransactionAbortedException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.TransactionalIdAuthorizationExceptionclass TransactionalIdAuthorizationException extends AuthorizationException implements Serializable
- 
Exception org.apache.kafka.common.errors.TransactionalIdNotFoundExceptionclass TransactionalIdNotFoundException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.TransactionCoordinatorFencedExceptionclass TransactionCoordinatorFencedException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.UnacceptableCredentialExceptionclass UnacceptableCredentialException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.UnknownControllerIdExceptionclass UnknownControllerIdException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.UnknownLeaderEpochExceptionclass UnknownLeaderEpochException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.UnknownMemberIdExceptionclass UnknownMemberIdException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.UnknownProducerIdExceptionclass UnknownProducerIdException extends OutOfOrderSequenceException implements Serializable
- 
Exception org.apache.kafka.common.errors.UnknownServerExceptionclass UnknownServerException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.UnknownSubscriptionIdExceptionclass UnknownSubscriptionIdException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.UnknownTopicIdExceptionclass UnknownTopicIdException extends InvalidMetadataException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.UnknownTopicOrPartitionExceptionclass UnknownTopicOrPartitionException extends InvalidMetadataException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.UnreleasedInstanceIdExceptionclass UnreleasedInstanceIdException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.UnstableOffsetCommitExceptionclass UnstableOffsetCommitException extends RetriableException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.UnsupportedAssignorExceptionclass UnsupportedAssignorException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.UnsupportedByAuthenticationExceptionclass UnsupportedByAuthenticationException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.UnsupportedCompressionTypeExceptionclass UnsupportedCompressionTypeException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.UnsupportedEndpointTypeExceptionclass UnsupportedEndpointTypeException extends ApiException implements Serializable
- 
Exception org.apache.kafka.common.errors.UnsupportedForMessageFormatExceptionclass UnsupportedForMessageFormatException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.UnsupportedSaslMechanismExceptionclass UnsupportedSaslMechanismException extends AuthenticationException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.UnsupportedVersionExceptionclass UnsupportedVersionException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.VoterNotFoundExceptionclass VoterNotFoundException extends ApiException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.common.errors.WakeupExceptionclass WakeupException extends KafkaException implements Serializable- serialVersionUID:
- 1L
 
 
- 
- 
Package org.apache.kafka.common.metrics- 
Exception org.apache.kafka.common.metrics.QuotaViolationExceptionclass QuotaViolationException extends KafkaException implements Serializable- serialVersionUID:
- 1L
 - 
Serialized Fields- 
bounddouble bound 
- 
metricKafkaMetric metric 
- 
valuedouble value 
 
- 
 
 
- 
- 
Package org.apache.kafka.connect.errors- 
Exception org.apache.kafka.connect.errors.AlreadyExistsExceptionclass AlreadyExistsException extends ConnectException implements Serializable
- 
Exception org.apache.kafka.connect.errors.ConnectExceptionclass ConnectException extends KafkaException implements Serializable
- 
Exception org.apache.kafka.connect.errors.DataExceptionclass DataException extends ConnectException implements Serializable
- 
Exception org.apache.kafka.connect.errors.IllegalWorkerStateExceptionclass IllegalWorkerStateException extends ConnectException implements Serializable
- 
Exception org.apache.kafka.connect.errors.NotFoundExceptionclass NotFoundException extends ConnectException implements Serializable
- 
Exception org.apache.kafka.connect.errors.RetriableExceptionclass RetriableException extends ConnectException implements Serializable
- 
Exception org.apache.kafka.connect.errors.SchemaBuilderExceptionclass SchemaBuilderException extends DataException implements Serializable
- 
Exception org.apache.kafka.connect.errors.SchemaProjectorExceptionclass SchemaProjectorException extends DataException implements Serializable
 
- 
- 
Package org.apache.kafka.coordinator.group.api.assignor- 
Exception org.apache.kafka.coordinator.group.api.assignor.PartitionAssignorExceptionclass PartitionAssignorException extends ApiException implements Serializable
 
- 
- 
Package org.apache.kafka.server.log.remote.storage- 
Exception org.apache.kafka.server.log.remote.storage.RemoteResourceNotFoundExceptionclass RemoteResourceNotFoundException extends RemoteStorageException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.server.log.remote.storage.RemoteStorageExceptionclass RemoteStorageException extends Exception implements Serializable- serialVersionUID:
- 1L
 
 
- 
- 
Package org.apache.kafka.streams.errors- 
Exception org.apache.kafka.streams.errors.BrokerNotFoundExceptionclass BrokerNotFoundException extends StreamsException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.streams.errors.InvalidStateStoreExceptionclass InvalidStateStoreException extends StreamsException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.streams.errors.InvalidStateStorePartitionExceptionclass InvalidStateStorePartitionException extends InvalidStateStoreException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.streams.errors.LockExceptionclass LockException extends StreamsException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.streams.errors.MissingSourceTopicExceptionclass MissingSourceTopicException extends StreamsException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.streams.errors.ProcessorStateExceptionclass ProcessorStateException extends StreamsException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.streams.errors.StateStoreMigratedExceptionclass StateStoreMigratedException extends InvalidStateStoreException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.streams.errors.StateStoreNotAvailableExceptionclass StateStoreNotAvailableException extends InvalidStateStoreException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.streams.errors.StreamsExceptionclass StreamsException extends KafkaException implements Serializable- serialVersionUID:
- 1L
 - 
Serialized Fields- 
taskIdTaskId taskId 
 
- 
 
- 
Exception org.apache.kafka.streams.errors.StreamsNotStartedExceptionclass StreamsNotStartedException extends InvalidStateStoreException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.streams.errors.StreamsRebalancingExceptionclass StreamsRebalancingException extends InvalidStateStoreException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.streams.errors.StreamsStoppedExceptionclass StreamsStoppedException extends InvalidStateStoreException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.streams.errors.TaskAssignmentExceptionclass TaskAssignmentException extends StreamsException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.streams.errors.TaskCorruptedExceptionclass TaskCorruptedException extends StreamsException implements Serializable
- 
Exception org.apache.kafka.streams.errors.TaskIdFormatExceptionclass TaskIdFormatException extends StreamsException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.streams.errors.TaskMigratedExceptionclass TaskMigratedException extends StreamsException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.streams.errors.TopologyExceptionclass TopologyException extends StreamsException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.streams.errors.UnknownStateStoreExceptionclass UnknownStateStoreException extends InvalidStateStoreException implements Serializable- serialVersionUID:
- 1L
 
- 
Exception org.apache.kafka.streams.errors.UnknownTopologyExceptionclass UnknownTopologyException extends StreamsException implements Serializable- serialVersionUID:
- 1L
 
 
-