All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary 
| Class | 
Description | 
| AbstractConfig | 
 A convenient base class for configurations to extend. 
 | 
| AbstractOptions<T extends AbstractOptions> | 
  | 
| AccessControlEntry | 
 Represents an access control entry. 
 | 
| AccessControlEntryFilter | 
 Represents a filter which matches access control entries. 
 | 
| AclBinding | 
 Represents a binding between a resource pattern and an access control entry. 
 | 
| AclBindingFilter | 
 A filter which can match AclBinding objects. 
 | 
| AclCreateResult | 
  | 
| AclDeleteResult | 
  | 
| AclDeleteResult.AclBindingDeleteResult | 
 Delete result for each ACL binding that matched a delete filter. 
 | 
| AclOperation | 
 Represents an operation which an ACL grants or denies permission to perform. 
 | 
| AclPermissionType | 
 Represents whether an ACL grants or denies permissions. 
 | 
| Action | 
  | 
| Admin | 
 The administrative client for Kafka, which supports managing and inspecting topics, brokers, configurations and ACLs. 
 | 
| AdminClient | 
 The base class for in-built admin clients. 
 | 
| AdminClientConfig | 
 The AdminClient configuration class, which also contains constants for configuration entry names. 
 | 
| AlterClientQuotasOptions | 
 | 
| AlterClientQuotasResult | 
 | 
| AlterConfigOp | 
 A class representing a alter configuration entry containing name, value and operation type. 
 | 
| AlterConfigOp.OpType | 
  | 
| AlterConfigPolicy | 
 An interface for enforcing a policy on alter configs requests. 
 | 
| AlterConfigPolicy.RequestMetadata | 
 Class containing the create request parameters. 
 | 
| AlterConfigsOptions | 
 | 
| AlterConfigsResult | 
 | 
| AlterConsumerGroupOffsetsOptions | 
 | 
| AlterConsumerGroupOffsetsResult | 
 | 
| AlterPartitionReassignmentsOptions | 
 | 
| AlterPartitionReassignmentsResult | 
 | 
| AlterReplicaLogDirsOptions | 
 | 
| AlterReplicaLogDirsResult | 
 | 
| ApiException | 
 Any API exception that is part of the public protocol and should be a subclass of this class and be part of this
 package. 
 | 
| AuthenticateCallbackHandler | 
  | 
| AuthenticationContext | 
 An object representing contextual information from the authentication session. 
 | 
| AuthenticationException | 
 This exception indicates that SASL authentication has failed. 
 | 
| AuthorizableRequestContext | 
 Request context interface that provides data from request header as well as connection
 and authentication information to plugins. 
 | 
| AuthorizationException | 
  | 
| AuthorizationResult | 
  | 
| Authorizer | 
 Pluggable authorizer interface for Kafka brokers. 
 | 
| AuthorizerServerInfo | 
 Runtime broker configuration metadata provided to authorizers during start up. 
 | 
| BrokerNotAvailableException | 
  | 
| BufferExhaustedException | 
 This exception is thrown if the producer cannot allocate memory for a record within max.block.ms due to the buffer
 being too full. 
 | 
| ByteArrayDeserializer | 
  | 
| ByteArraySerializer | 
  | 
| ByteBufferDeserializer | 
  | 
| ByteBufferSerializer | 
  | 
| BytesDeserializer | 
  | 
| BytesSerializer | 
  | 
| Callback | 
 A callback interface that the user can implement to allow code to execute when the request is complete. 
 | 
| ClientQuotaCallback | 
 Quota callback interface for brokers that enables customization of client quota computation. 
 | 
| ClientQuotaEntity | 
 The metadata for an entity for which quota is configured. 
 | 
| ClientQuotaEntity.ConfigEntity | 
 Interface representing a quota configuration entity. 
 | 
| ClientQuotaEntity.ConfigEntityType | 
 | 
| ClientQuotaType | 
 Types of quotas that may be configured on brokers for client requests. 
 | 
| Cluster | 
 An immutable representation of a subset of the nodes, topics, and partitions in the Kafka cluster. 
 | 
| ClusterAuthorizationException | 
  | 
| ClusterResource | 
 The ClusterResource class encapsulates metadata for a Kafka cluster. 
 | 
| ClusterResourceListener | 
 A callback interface that users can implement when they wish to get notified about changes in the Cluster metadata. 
 | 
| CommitFailedException | 
 | 
| ConcurrentTransactionsException | 
  | 
| Config | 
 A configuration object containing the configuration entries for a resource. 
 | 
| Config | 
  | 
| ConfigChangeCallback | 
 | 
| ConfigData | 
 | 
| ConfigDef | 
 This class is used for specifying the set of expected configurations. 
 | 
| ConfigDef.CaseInsensitiveValidString | 
  | 
| ConfigDef.CompositeValidator | 
  | 
| ConfigDef.ConfigKey | 
  | 
| ConfigDef.Importance | 
 The importance level for a configuration 
 | 
| ConfigDef.LambdaValidator | 
  | 
| ConfigDef.NonEmptyString | 
  | 
| ConfigDef.NonEmptyStringWithoutControlChars | 
  | 
| ConfigDef.NonNullValidator | 
  | 
| ConfigDef.Range | 
 Validation logic for numeric ranges 
 | 
| ConfigDef.Recommender | 
This is used by the  ConfigDef.validate(Map) to get valid values for a configuration given the current
 configuration values in order to perform full configuration validation and visibility modification.  
 | 
| ConfigDef.Type | 
 The config types 
 | 
| ConfigDef.Validator | 
 Validation logic the user may provide to perform single configuration validation. 
 | 
| ConfigDef.ValidList | 
  | 
| ConfigDef.ValidString | 
  | 
| ConfigDef.Width | 
 The width of a configuration value 
 | 
| ConfigEntry | 
 A class representing a configuration entry containing name, value and additional metadata. 
 | 
| ConfigEntry.ConfigSource | 
 Source of configuration entries. 
 | 
| ConfigEntry.ConfigSynonym | 
Class representing a configuration synonym of a  ConfigEntry.  
 | 
| ConfigEntry.ConfigType | 
 Data type of configuration entry. 
 | 
| ConfigException | 
 Thrown if the user supplies an invalid configuration 
 | 
| ConfigProvider | 
 A provider of configuration data, which may optionally support subscriptions to configuration changes. 
 | 
| ConfigResource | 
 A class representing resources that have configs. 
 | 
| ConfigResource.Type | 
 Type of resource. 
 | 
| ConfigTransformer | 
This class wraps a set of  ConfigProvider instances and uses them to perform
 transformations.  
 | 
| ConfigTransformerResult | 
 | 
| Configurable | 
 A Mix-in style interface for classes that are instantiated by reflection and need to take configuration parameters 
 | 
| ConfigValue | 
  | 
| Consumer<K,V> | 
  | 
| ConsumerConfig | 
 The consumer configuration keys 
 | 
| ConsumerGroupDescription | 
 A detailed description of a single consumer group in the cluster. 
 | 
| ConsumerGroupListing | 
 A listing of a consumer group in the cluster. 
 | 
| ConsumerGroupMetadata | 
 A metadata struct containing the consumer group information. 
 | 
| ConsumerGroupState | 
 The consumer group state. 
 | 
| ConsumerInterceptor<K,V> | 
 A plugin interface that allows you to intercept (and possibly mutate) records received by the consumer. 
 | 
| ConsumerPartitionAssignor | 
This interface is used to define custom partition assignment for use in
  KafkaConsumer.  
 | 
| ConsumerPartitionAssignor.Assignment | 
  | 
| ConsumerPartitionAssignor.GroupAssignment | 
  | 
| ConsumerPartitionAssignor.GroupSubscription | 
  | 
| ConsumerPartitionAssignor.RebalanceProtocol | 
 The rebalance protocol defines partition assignment and revocation semantics. 
 | 
| ConsumerPartitionAssignor.Subscription | 
  | 
| ConsumerRebalanceListener | 
 A callback interface that the user can implement to trigger custom actions when the set of partitions assigned to the
 consumer changes. 
 | 
| ConsumerRecord<K,V> | 
 A key/value pair to be received from Kafka. 
 | 
| ConsumerRecords<K,V> | 
A container that holds the list  ConsumerRecord per partition for a
 particular topic.  
 | 
| ControllerMovedException | 
  | 
| CooperativeStickyAssignor | 
 A cooperative version of the AbstractStickyAssignor. 
 | 
| CoordinatorLoadInProgressException | 
 In the context of the group coordinator, the broker returns this error code for any coordinator request if
 it is still loading the group metadata (e.g. 
 | 
| CoordinatorNotAvailableException | 
 In the context of the group coordinator, the broker returns this error code for metadata or offset commit
 requests if the group metadata topic has not been created yet. 
 | 
| CorruptRecordException | 
 This exception indicates a record has failed its internal CRC check, this generally indicates network or disk
 corruption. 
 | 
| CreateAclsOptions | 
 | 
| CreateAclsResult | 
 | 
| CreateDelegationTokenOptions | 
 | 
| CreateDelegationTokenResult | 
 | 
| CreatePartitionsOptions | 
 | 
| CreatePartitionsResult | 
 | 
| CreateTopicPolicy | 
 An interface for enforcing a policy on create topics requests. 
 | 
| CreateTopicPolicy.RequestMetadata | 
 Class containing the create request parameters. 
 | 
| CreateTopicsOptions | 
 | 
| CreateTopicsResult | 
 | 
| CreateTopicsResult.TopicMetadataAndConfig | 
  | 
| DefaultPrincipalBuilder | 
Deprecated.
 | 
| DefaultStreamsPartitioner | 
  | 
| DelegationToken | 
 A class representing a delegation token. 
 | 
| DelegationTokenAuthorizationException | 
  | 
| DelegationTokenDisabledException | 
  | 
| DelegationTokenExpiredException | 
  | 
| DelegationTokenNotFoundException | 
  | 
| DelegationTokenOwnerMismatchException | 
  | 
| DeleteAclsOptions | 
 | 
| DeleteAclsResult | 
 | 
| DeleteAclsResult.FilterResult | 
 A class containing either the deleted ACL binding or an exception if the delete failed. 
 | 
| DeleteAclsResult.FilterResults | 
 A class containing the results of the delete ACLs operation. 
 | 
| DeleteConsumerGroupOffsetsOptions | 
 | 
| DeleteConsumerGroupOffsetsResult | 
 | 
| DeleteConsumerGroupsOptions | 
 | 
| DeleteConsumerGroupsResult | 
 | 
| DeletedRecords | 
 Represents information about deleted records
 The API for this class is still evolving and we may break compatibility in minor releases, if necessary. 
 | 
| DeleteRecordsOptions | 
 | 
| DeleteRecordsResult | 
 | 
| DeleteTopicsOptions | 
 | 
| DeleteTopicsResult | 
 | 
| DescribeAclsOptions | 
 | 
| DescribeAclsResult | 
 | 
| DescribeClientQuotasOptions | 
 | 
| DescribeClientQuotasResult | 
 | 
| DescribeClusterOptions | 
 | 
| DescribeClusterResult | 
 | 
| DescribeConfigsOptions | 
 | 
| DescribeConfigsResult | 
 | 
| DescribeConsumerGroupsOptions | 
 | 
| DescribeConsumerGroupsResult | 
 | 
| DescribeDelegationTokenOptions | 
 | 
| DescribeDelegationTokenResult | 
 | 
| DescribeLogDirsOptions | 
 | 
| DescribeLogDirsResult | 
 | 
| DescribeReplicaLogDirsOptions | 
 | 
| DescribeReplicaLogDirsResult | 
 | 
| DescribeReplicaLogDirsResult.ReplicaLogDirInfo | 
  | 
| DescribeTopicsOptions | 
 | 
| DescribeTopicsResult | 
 | 
| Deserializer<T> | 
 An interface for converting bytes to objects. 
 | 
| DisconnectException | 
 Server disconnected before a request could be completed. 
 | 
| DoubleDeserializer | 
  | 
| DoubleSerializer | 
  | 
| DuplicateSequenceException | 
  | 
| ElectionNotNeededException | 
  | 
| ElectionType | 
 | 
| ElectLeadersOptions | 
 | 
| ElectLeadersResult | 
 | 
| ElectPreferredLeadersOptions | 
Deprecated.
 | 
| ElectPreferredLeadersResult | 
Deprecated.
 | 
| EligibleLeadersNotAvailableException | 
  | 
| Endpoint | 
 Represents a broker endpoint. 
 | 
| ExpireDelegationTokenOptions | 
 | 
| ExpireDelegationTokenResult | 
 | 
| ExtendedDeserializer<T> | 
Deprecated.
 | 
| ExtendedDeserializer.Wrapper<T> | 
  | 
| ExtendedSerializer<T> | 
Deprecated.
 | 
| ExtendedSerializer.Wrapper<T> | 
  | 
| FencedInstanceIdException | 
  | 
| FencedLeaderEpochException | 
 The request contained a leader epoch which is smaller than that on the broker that received the
 request. 
 | 
| FetchSessionIdNotFoundException | 
  | 
| FileConfigProvider | 
An implementation of  ConfigProvider that represents a Properties file.  
 | 
| FloatDeserializer | 
  | 
| FloatSerializer | 
  | 
| GenericCoordinator | 
  | 
| GroupAuthorizationException | 
  | 
| GroupIdNotFoundException | 
  | 
| GroupMaxSizeReachedException | 
 Indicates that a consumer group is already at its configured maximum capacity and cannot accommodate more members 
 | 
| GroupNotEmptyException | 
  | 
| GroupSubscribedToTopicException | 
  | 
| Header | 
  | 
| Headers | 
  | 
| IllegalGenerationException | 
  | 
| IllegalSaslStateException | 
 This exception indicates unexpected requests prior to SASL authentication. 
 | 
| InconsistentGroupProtocolException | 
  | 
| IntegerDeserializer | 
  | 
| IntegerSerializer | 
  | 
| InterfaceStability | 
 Annotation to inform users of how much to rely on a particular package, class or method not changing over time. 
 | 
| InterfaceStability.Evolving | 
 Compatibility may be broken at minor release (i.e. 
 | 
| InterfaceStability.Stable | 
 Compatibility is maintained in major, minor and patch releases with one exception: compatibility may be broken
 in a major release (i.e. 
 | 
| InterfaceStability.Unstable | 
 No guarantee is provided as to reliability or stability across any level of release granularity. 
 | 
| InterruptException | 
 An unchecked wrapper for InterruptedException 
 | 
| InvalidCommitOffsetSizeException | 
  | 
| InvalidConfigurationException | 
  | 
| InvalidFetchSessionEpochException | 
  | 
| InvalidFetchSizeException | 
  | 
| InvalidGroupIdException | 
  | 
| InvalidMetadataException | 
 An exception that may indicate the client's metadata is out of date 
 | 
| InvalidOffsetException | 
 Thrown when the offset for a set of partitions is invalid (either undefined or out of range),
 and no reset policy has been configured. 
 | 
| InvalidOffsetException | 
 Thrown when the offset for a set of partitions is invalid (either undefined or out of range),
 and no reset policy has been configured. 
 | 
| InvalidPartitionsException | 
  | 
| InvalidPidMappingException | 
  | 
| InvalidPrincipalTypeException | 
  | 
| InvalidRecordException | 
  | 
| InvalidReplicaAssignmentException | 
  | 
| InvalidReplicationFactorException | 
  | 
| InvalidRequestException | 
 Thrown when a request breaks basic wire protocol rules. 
 | 
| InvalidRequiredAcksException | 
  | 
| InvalidSessionTimeoutException | 
  | 
| InvalidTimestampException | 
 Indicate the timestamp of a record is invalid. 
 | 
| InvalidTopicException | 
 The client has attempted to perform an operation on an invalid topic. 
 | 
| InvalidTxnStateException | 
  | 
| InvalidTxnTimeoutException | 
 The transaction coordinator returns this error code if the timeout received via the InitProducerIdRequest is larger than
 the `transaction.max.timeout.ms` config value. 
 | 
| IsolationLevel | 
  | 
| KafkaAdminClient | 
The default implementation of  Admin.  
 | 
| KafkaConsumer<K,V> | 
 A client that consumes records from a Kafka cluster. 
 | 
| KafkaException | 
 The base class of all other Kafka exceptions 
 | 
| KafkaFuture<T> | 
 A flexible future which supports call chaining and other asynchronous programming patterns. 
 | 
| KafkaFuture.BaseFunction<A,B> | 
 A function which takes objects of type A and returns objects of type B. 
 | 
| KafkaFuture.BiConsumer<A,B> | 
 A consumer of two different types of object. 
 | 
| KafkaFuture.Function<A,B> | 
 A function which takes objects of type A and returns objects of type B. 
 | 
| KafkaPrincipal | 
 Principals in Kafka are defined by a type and a name. 
 | 
| KafkaPrincipalBuilder | 
 | 
| KafkaProducer<K,V> | 
 A Kafka client that publishes records to the Kafka cluster. 
 | 
| KafkaStorageException | 
 Miscellaneous disk-related IOException occurred when handling a request. 
 | 
| LeaderNotAvailableException | 
 There is no currently available leader for the given partition (either because a leadership election is in progress
 or because all replicas are down). 
 | 
| ListConsumerGroupOffsetsOptions | 
 | 
| ListConsumerGroupOffsetsResult | 
 | 
| ListConsumerGroupsOptions | 
 | 
| ListConsumerGroupsResult | 
 | 
| ListenerNotFoundException | 
 The leader does not have an endpoint corresponding to the listener on which metadata was requested. 
 | 
| ListOffsetsOptions | 
 | 
| ListOffsetsResult | 
 | 
| ListOffsetsResult.ListOffsetsResultInfo | 
  | 
| ListPartitionReassignmentsOptions | 
 | 
| ListPartitionReassignmentsResult | 
 | 
| ListTopicsOptions | 
 | 
| ListTopicsResult | 
 | 
| LogDirNotFoundException | 
 Thrown when a request is made for a log directory that is not present on the broker 
 | 
| Login | 
 Login interface for authentication. 
 | 
| LogLevelConfig | 
 This class holds definitions for log level configurations related to Kafka's application logging. 
 | 
| LogTruncationException | 
 In the event of an unclean leader election, the log will be truncated,
 previously committed data will be lost, and new data will be written
 over these offsets. 
 | 
| LongDeserializer | 
  | 
| LongSerializer | 
  | 
| MemberAssignment | 
 A description of the assignments of a specific group member. 
 | 
| MemberDescription | 
 A detailed description of a single group instance in the cluster. 
 | 
| MemberIdRequiredException | 
  | 
| MemberToRemove | 
 A struct containing information about the member to be removed. 
 | 
| Metric | 
 A metric tracked for monitoring purposes. 
 | 
| MetricName | 
 The MetricName class encapsulates a metric's name, logical group and its related attributes. 
 | 
| MetricNameTemplate | 
 A template for a MetricName. 
 | 
| MockConsumer<K,V> | 
 This class is not supported. 
 | 
| MockProducer<K,V> | 
 This class is not supported. 
 | 
| NetworkException | 
 A misc. 
 | 
| NewPartitionReassignment | 
 | 
| NewPartitions | 
 | 
| NewTopic | 
 | 
| Node | 
 Information about a Kafka node 
 | 
| NoOffsetForPartitionException | 
 Indicates that there is no stored offset for a partition and no defined offset
 reset policy. 
 | 
| NoReassignmentInProgressException | 
 Thrown if a reassignment cannot be cancelled because none is in progress. 
 | 
| NotControllerException | 
  | 
| NotCoordinatorException | 
 In the context of the group coordinator, the broker returns this error code if it receives an offset fetch
 or commit request for a group it's not the coordinator of. 
 | 
| NotEnoughReplicasAfterAppendException | 
 Number of insync replicas for the partition is lower than min.insync.replicas This exception is raised when the low
 ISR size is discovered *after* the message was already appended to the log. 
 | 
| NotEnoughReplicasException | 
 Number of insync replicas for the partition is lower than min.insync.replicas 
 | 
| NotLeaderForPartitionException | 
Deprecated.
 | 
| NotLeaderOrFollowerException | 
 Broker returns this error if a request could not be processed because the broker is not the leader
 or follower for a topic partition. 
 | 
| OAuthBearerExtensionsValidatorCallback | 
A  Callback for use by the  SaslServer implementation when it
 needs to validate the SASL extensions for the OAUTHBEARER mechanism
 Callback handlers should use the  OAuthBearerExtensionsValidatorCallback.valid(String)
 method to communicate valid extensions back to the SASL server.  
 | 
| OAuthBearerLoginModule | 
 The LoginModule for the SASL/OAUTHBEARER mechanism. 
 | 
| OAuthBearerToken | 
The  b64token value as defined in
  RFC 6750 Section
 2.1 along with the token's specific scope and lifetime and principal
 name.  
 | 
| OAuthBearerTokenCallback | 
 A Callback for use by the SaslClient and Login
 implementations when they require an OAuth 2 bearer token. 
 | 
| OAuthBearerValidatorCallback | 
 A Callback for use by the SaslServer implementation when it
 needs to provide an OAuth 2 bearer token compact serialization for
 validation. 
 | 
| OffsetAndMetadata | 
 The Kafka offset commit API allows users to provide additional metadata (in the form of a string)
 when an offset is committed. 
 | 
| OffsetAndTimestamp | 
 A container class for offset and timestamp. 
 | 
| OffsetCommitCallback | 
 A callback interface that the user can implement to trigger custom actions when a commit request completes. 
 | 
| OffsetMetadataTooLarge | 
 The client has tried to save its offset with associated metadata larger than the maximum size allowed by the server. 
 | 
| OffsetNotAvailableException | 
 Indicates that the leader is not able to guarantee monotonically increasing offsets
 due to the high watermark lagging behind the epoch start offset after a recent leader election 
 | 
| OffsetOutOfRangeException | 
 No reset policy has been defined, and the offsets for these partitions are either larger or smaller
 than the range of offsets the server has for the given partition. 
 | 
| OffsetOutOfRangeException | 
 No reset policy has been defined, and the offsets for these partitions are either larger or smaller
 than the range of offsets the server has for the given partition. 
 | 
| OffsetResetStrategy | 
  | 
| OffsetSpec | 
 | 
| OffsetSpec.EarliestSpec | 
  | 
| OffsetSpec.LatestSpec | 
  | 
| OffsetSpec.TimestampSpec | 
  | 
| OperationNotAttemptedException | 
 Indicates that the broker did not attempt to execute this operation. 
 | 
| OutOfOrderSequenceException | 
 This exception indicates that the broker received an unexpected sequence number from the producer,
 which means that data may have been lost. 
 | 
| Partitioner | 
 Partitioner Interface is not supported. 
 | 
| PartitionInfo | 
 This is used to describe per-partition state in the MetadataResponse. 
 | 
| PartitionReassignment | 
 | 
| PatternType | 
 Resource pattern type. 
 | 
| PlainAuthenticateCallback | 
  | 
| PlainLoginModule | 
  | 
| PlaintextAuthenticationContext | 
  | 
| PolicyViolationException | 
 Exception thrown if a create topics request does not satisfy the configured policy for a topic. 
 | 
| PreferredLeaderNotAvailableException | 
  | 
| PrincipalBuilder | 
Deprecated.
 | 
| Producer<K,V> | 
 | 
| ProducerConfig | 
 Configuration for the Kafka Producer. 
 | 
| ProducerFencedException | 
 This fatal exception indicates that another producer with the same transactional.id has been
 started. 
 | 
| ProducerInterceptor<K,V> | 
 A plugin interface that allows you to intercept (and possibly mutate) the records received by the producer before
 they are published to the Kafka cluster. 
 | 
| ProducerRecord<K,V> | 
 A key/value pair to be sent to Kafka. 
 | 
| RangeAssignor | 
 This class is not supported. 
 | 
| ReassignmentInProgressException | 
 Thrown if a request cannot be completed because a partition reassignment is in progress. 
 | 
| RebalanceInProgressException | 
  | 
| Reconfigurable | 
 Interface for reconfigurable classes that support dynamic configuration. 
 | 
| RecordBatchTooLargeException | 
 This record batch is larger than the maximum allowable size 
 | 
| RecordMetadata | 
 The metadata for a record that has been acknowledged by the server 
 | 
| RecordsToDelete | 
 | 
| RecordTooLargeException | 
 This record is larger than the maximum allowable size 
 | 
| RemoveMembersFromConsumerGroupOptions | 
 | 
| RemoveMembersFromConsumerGroupResult | 
 | 
| RenewDelegationTokenOptions | 
 | 
| RenewDelegationTokenResult | 
 | 
| ReplicaNotAvailableException | 
 The replica is not available for the requested topic partition. 
 | 
| Resource | 
 Represents a cluster resource with a tuple of (type, name). 
 | 
| ResourceFilter | 
 A filter which matches Resource objects. 
 | 
| ResourcePattern | 
Represents a pattern that is used by ACLs to match zero or more
  Resources.  
 | 
| ResourcePatternFilter | 
 | 
| ResourceType | 
 Represents a type of resource which an ACL can be applied to. 
 | 
| RetriableCommitFailedException | 
  | 
| RetriableException | 
 A retryable exception is a transient exception that if retried may succeed. 
 | 
| RoundRobinAssignor | 
 This class is not supported. 
 | 
| RoundRobinPartitioner | 
 The "Round-Robin" partitioner
 
 This partitioning strategy can be used when user wants 
 to distribute the writes to all partitions equally. 
 | 
| SaslAuthenticationContext | 
  | 
| SaslAuthenticationException | 
 This exception indicates that SASL authentication has failed. 
 | 
| SaslConfigs | 
  | 
| SaslExtensions | 
 A simple immutable value object class holding customizable SASL extensions 
 | 
| SaslExtensionsCallback | 
 Optional callback used for SASL mechanisms if any extensions need to be set
 in the SASL exchange. 
 | 
| ScramCredential | 
 SCRAM credential class that encapsulates the credential data persisted for each user that is
 accessible to the server. 
 | 
| ScramCredentialCallback | 
 Callback used for SCRAM mechanisms. 
 | 
| ScramExtensionsCallback | 
 Optional callback used for SCRAM mechanisms if any extensions need to be set
 in the SASL/SCRAM exchange. 
 | 
| ScramLoginModule | 
  | 
| SecurityConfig | 
 Contains the common security config for SSL and SASL 
 | 
| SecurityDisabledException | 
 An error indicating that security is disabled on the broker. 
 | 
| SecurityProtocol | 
  | 
| SecurityProviderCreator | 
 An interface for generating security providers. 
 | 
| Serde<T> | 
 The interface for wrapping a serializer and deserializer for the given data type. 
 | 
| Serdes | 
 Factory for creating serializers / deserializers. 
 | 
| Serdes.ByteArraySerde | 
  | 
| Serdes.ByteBufferSerde | 
  | 
| Serdes.BytesSerde | 
  | 
| Serdes.DoubleSerde | 
  | 
| Serdes.FloatSerde | 
  | 
| Serdes.IntegerSerde | 
  | 
| Serdes.LongSerde | 
  | 
| Serdes.ShortSerde | 
  | 
| Serdes.StringSerde | 
  | 
| Serdes.UUIDSerde | 
  | 
| Serdes.VoidSerde | 
  | 
| Serdes.WrapperSerde<T> | 
  | 
| SerializationException | 
 Any exception during serialization in the producer 
 | 
| Serializer<T> | 
 An interface for converting objects to bytes. 
 | 
| ShortDeserializer | 
  | 
| ShortSerializer | 
  | 
| SslAuthenticationContext | 
  | 
| SslAuthenticationException | 
 This exception indicates that SSL handshake has failed. 
 | 
| SslClientAuth | 
 Describes whether the server should require or request client authentication. 
 | 
| SslConfigs | 
  | 
| SslEngineFactory | 
 Plugin interface for allowing creation of SSLEngine object in a custom way. 
 | 
| StaleBrokerEpochException | 
  | 
| StickyAssignor | 
 This class is not supported. 
 | 
| StreamsPartitioner | 
 Partitioner Interface 
 | 
| StringDeserializer | 
 String encoding defaults to UTF8 and can be customized by setting the property key.deserializer.encoding,
  value.deserializer.encoding or deserializer.encoding. 
 | 
| StringSerializer | 
 String encoding defaults to UTF8 and can be customized by setting the property key.serializer.encoding,
  value.serializer.encoding or serializer.encoding. 
 | 
| TimeoutException | 
 Indicates that a request timed out. 
 | 
| TokenInformation | 
 A class representing a delegation token details. 
 | 
| TopicAuthorizationException | 
  | 
| TopicConfig | 
 Keys that can be used to configure a topic. 
 | 
| TopicDeletionDisabledException | 
  | 
| TopicDescription | 
 A detailed description of a single topic in the cluster. 
 | 
| TopicExistsException | 
  | 
| TopicListing | 
 A listing of a topic in the cluster. 
 | 
| TopicPartition | 
 A topic name and partition number 
 | 
| TopicPartitionInfo | 
 A class containing leadership, replicas and ISR information for a topic partition. 
 | 
| TopicPartitionReplica | 
 The topic name, partition number and the brokerId of the replica 
 | 
| TransactionalIdAuthorizationException | 
  | 
| TransactionCoordinatorFencedException | 
  | 
| UniformStickyPartitioner | 
 The partitioning strategy:
 
 If a partition is specified in the record, use it
 Otherwise choose the sticky partition that changes when the batch is full. 
 | 
| UnknownLeaderEpochException | 
 The request contained a leader epoch which is larger than that on the broker that received the
 request. 
 | 
| UnknownMemberIdException | 
  | 
| UnknownProducerIdException | 
 This exception is raised by the broker if it could not locate the producer metadata associated with the producerId
 in question. 
 | 
| UnknownServerException | 
 An error occurred on the server for which the client doesn't have a corresponding error code. 
 | 
| UnknownTopicOrPartitionException | 
 This topic/partition doesn't exist. 
 | 
| UnstableOffsetCommitException | 
 Exception thrown when there are unstable offsets for the requested topic partitions. 
 | 
| UnsupportedByAuthenticationException | 
 Authentication mechanism does not support the requested function. 
 | 
| UnsupportedCompressionTypeException | 
 The requesting client does not support the compression type of given partition. 
 | 
| UnsupportedForMessageFormatException | 
 The message format version does not support the requested function. 
 | 
| UnsupportedSaslMechanismException | 
 This exception indicates that the SASL mechanism requested by the client
 is not enabled on the broker. 
 | 
| UnsupportedVersionException | 
 Indicates that a request API or version needed by the client is not supported by the broker. 
 | 
| UUIDDeserializer | 
 We are converting the byte array to String before deserializing to UUID. 
 | 
| UUIDSerializer | 
 We are converting UUID to String before serializing. 
 | 
| VoidDeserializer | 
  | 
| VoidSerializer | 
  | 
| WakeupException | 
 Exception used to indicate preemption of a blocking operation by an external thread. 
 |