A B C D E F G H I K L M N O P Q R S T U V W 
All Classes All Packages

A

abort() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
 
abort() - Method in class org.apache.kafka.common.security.plain.PlainLoginModule
 
abort() - Method in class org.apache.kafka.common.security.scram.ScramLoginModule
 
abortTransaction() - Method in class org.apache.kafka.clients.producer.KafkaProducer
This API is not supported.
abortTransaction() - Method in class org.apache.kafka.clients.producer.MockProducer
 
abortTransaction() - Method in interface org.apache.kafka.clients.producer.Producer
AbstractConfig - Class in org.apache.kafka.common.config
A convenient base class for configurations to extend.
AbstractConfig(ConfigDef, Map<?, ?>) - Constructor for class org.apache.kafka.common.config.AbstractConfig
 
AbstractConfig(ConfigDef, Map<?, ?>, boolean) - Constructor for class org.apache.kafka.common.config.AbstractConfig
 
AbstractOptions<T extends AbstractOptions> - Class in org.apache.kafka.clients.admin
 
AbstractOptions() - Constructor for class org.apache.kafka.clients.admin.AbstractOptions
 
accept(A, B) - Method in interface org.apache.kafka.common.KafkaFuture.BiConsumer
 
AccessControlEntry - Class in org.apache.kafka.common.acl
Represents an access control entry.
AccessControlEntry(String, String, AclOperation, AclPermissionType) - Constructor for class org.apache.kafka.common.acl.AccessControlEntry
Create an instance of an access control entry with the provided parameters.
AccessControlEntryFilter - Class in org.apache.kafka.common.acl
Represents a filter which matches access control entries.
AccessControlEntryFilter(String, String, AclOperation, AclPermissionType) - Constructor for class org.apache.kafka.common.acl.AccessControlEntryFilter
Create an instance of an access control entry filter with the provided parameters.
ACKS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
acks
AclBinding - Class in org.apache.kafka.common.acl
Represents a binding between a resource pattern and an access control entry.
AclBinding(ResourcePattern, AccessControlEntry) - Constructor for class org.apache.kafka.common.acl.AclBinding
Create an instance of this class with the provided parameters.
AclBinding(Resource, AccessControlEntry) - Constructor for class org.apache.kafka.common.acl.AclBinding
AclBindingFilter - Class in org.apache.kafka.common.acl
A filter which can match AclBinding objects.
AclBindingFilter(ResourceFilter, AccessControlEntryFilter) - Constructor for class org.apache.kafka.common.acl.AclBindingFilter
AclBindingFilter(ResourcePatternFilter, AccessControlEntryFilter) - Constructor for class org.apache.kafka.common.acl.AclBindingFilter
Create an instance of this filter with the provided parameters.
AclOperation - Enum in org.apache.kafka.common.acl
Represents an operation which an ACL grants or denies permission to perform.
AclPermissionType - Enum in org.apache.kafka.common.acl
Represents whether an ACL grants or denies permissions.
add(String, byte[]) - Method in interface org.apache.kafka.common.header.Headers
Creates and adds a header, to the end, returning if the operation succeeded.
add(Header) - Method in interface org.apache.kafka.common.header.Headers
Adds a header (key inside), to the end, returning if the operation succeeded.
addClientSaslSupport(ConfigDef) - Static method in class org.apache.kafka.common.config.SaslConfigs
 
addClientSslSupport(ConfigDef) - Static method in class org.apache.kafka.common.config.SslConfigs
 
addDeserializerToConfig(Map<String, Object>, Deserializer<?>, Deserializer<?>) - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
 
addDeserializerToConfig(Properties, Deserializer<?>, Deserializer<?>) - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
 
addEndOffsets(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
addErrorMessage(String) - Method in class org.apache.kafka.common.config.ConfigValue
 
addRecord(ConsumerRecord<K, V>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
addSerializerToConfig(Map<String, Object>, Serializer<?>, Serializer<?>) - Static method in class org.apache.kafka.clients.producer.ProducerConfig
 
addSerializerToConfig(Properties, Serializer<?>, Serializer<?>) - Static method in class org.apache.kafka.clients.producer.ProducerConfig
 
addWaiter(KafkaFuture.BiConsumer<? super T, ? super Throwable>) - Method in class org.apache.kafka.common.KafkaFuture
 
AdminClient - Class in org.apache.kafka.clients.admin
The administrative client for Kafka, which supports managing and inspecting topics, brokers, configurations and ACLs.
AdminClient() - Constructor for class org.apache.kafka.clients.admin.AdminClient
 
ADMINCLIENT_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
 
AdminClientConfig - Class in org.apache.kafka.clients.admin
The AdminClient configuration class, which also contains constants for configuration entry names.
AdminClientConfig(Map<?, ?>) - Constructor for class org.apache.kafka.clients.admin.AdminClientConfig
 
AdminClientConfig(Map<?, ?>, boolean) - Constructor for class org.apache.kafka.clients.admin.AdminClientConfig
 
all() - Method in class org.apache.kafka.clients.admin.AlterConfigsResult
Return a future which succeeds only if all the alter configs operations succeed.
all() - Method in class org.apache.kafka.clients.admin.AlterReplicaLogDirsResult
Return a future which succeeds if all the replica movement have succeeded
all() - Method in class org.apache.kafka.clients.admin.CreateAclsResult
Return a future which succeeds only if all the ACL creations succeed.
all() - Method in class org.apache.kafka.clients.admin.CreatePartitionsResult
Return a future which succeeds if all the partition creations succeed.
all() - Method in class org.apache.kafka.clients.admin.CreateTopicsResult
Return a future which succeeds if all the topic creations succeed.
all() - Method in class org.apache.kafka.clients.admin.DeleteAclsResult
Return a future which succeeds only if all the ACLs deletions succeed, and which contains all the deleted ACLs.
all() - Method in class org.apache.kafka.clients.admin.DeleteConsumerGroupsResult
Return a future which succeeds only if all the consumer group deletions succeed.
all() - Method in class org.apache.kafka.clients.admin.DeleteRecordsResult
Return a future which succeeds only if all the records deletions succeed.
all() - Method in class org.apache.kafka.clients.admin.DeleteTopicsResult
Return a future which succeeds only if all the topic deletions succeed.
all() - Method in class org.apache.kafka.clients.admin.DescribeConfigsResult
Return a future which succeeds only if all the config descriptions succeed.
all() - Method in class org.apache.kafka.clients.admin.DescribeConsumerGroupsResult
Return a future which yields all ConsumerGroupDescription objects, if all the describes succeed.
all() - Method in class org.apache.kafka.clients.admin.DescribeLogDirsResult
Return a future which succeeds only if all the brokers have responded without error
all() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult
Return a future which succeeds if log directory information of all replicas are available
all() - Method in class org.apache.kafka.clients.admin.DescribeTopicsResult
Return a future which succeeds only if all the topic descriptions succeed.
all() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsResult
Returns a future that yields either an exception, or the full set of consumer group listings.
ALL - org.apache.kafka.common.acl.AclOperation
ALL operation.
allOf(KafkaFuture<?>...) - Static method in class org.apache.kafka.common.KafkaFuture
Returns a new KafkaFuture that is completed when all the given futures have completed.
ALLOW - org.apache.kafka.common.acl.AclPermissionType
Grants access.
allPartitionsSorted(Map<String, Integer>, Map<String, PartitionAssignor.Subscription>) - Method in class org.apache.kafka.clients.consumer.RoundRobinAssignor
 
ALTER - org.apache.kafka.common.acl.AclOperation
ALTER operation.
ALTER_CONFIGS - org.apache.kafka.common.acl.AclOperation
ALTER_CONFIGS operation.
AlterConfigPolicy - Interface in org.apache.kafka.server.policy
An interface for enforcing a policy on alter configs requests.
AlterConfigPolicy.RequestMetadata - Class in org.apache.kafka.server.policy
Class containing the create request parameters.
alterConfigs(Map<ConfigResource, Config>) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
alterConfigs(Map<ConfigResource, Config>, AlterConfigsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
alterConfigs(Map<ConfigResource, Config>, AlterConfigsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
AlterConfigsOptions - Class in org.apache.kafka.clients.admin
AlterConfigsOptions() - Constructor for class org.apache.kafka.clients.admin.AlterConfigsOptions
 
AlterConfigsResult - Class in org.apache.kafka.clients.admin
The result of the AdminClient.alterConfigs(Map) call.
AlterConfigsResult(Map<ConfigResource, KafkaFuture<Void>>) - Constructor for class org.apache.kafka.clients.admin.AlterConfigsResult
 
alterReplicaLogDirs(Map<TopicPartitionReplica, String>) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
alterReplicaLogDirs(Map<TopicPartitionReplica, String>, AlterReplicaLogDirsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
alterReplicaLogDirs(Map<TopicPartitionReplica, String>, AlterReplicaLogDirsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
AlterReplicaLogDirsOptions - Class in org.apache.kafka.clients.admin
AlterReplicaLogDirsOptions() - Constructor for class org.apache.kafka.clients.admin.AlterReplicaLogDirsOptions
 
AlterReplicaLogDirsResult - Class in org.apache.kafka.clients.admin
AlterReplicaLogDirsResult(Map<TopicPartitionReplica, KafkaFuture<Void>>) - Constructor for class org.apache.kafka.clients.admin.AlterReplicaLogDirsResult
 
ANONYMOUS - Static variable in class org.apache.kafka.common.security.auth.KafkaPrincipal
 
ANY - org.apache.kafka.common.acl.AclOperation
In a filter, matches any AclOperation.
ANY - org.apache.kafka.common.acl.AclPermissionType
In a filter, matches any AclPermissionType.
ANY - org.apache.kafka.common.resource.PatternType
In a filter, matches any resource pattern type.
ANY - org.apache.kafka.common.resource.ResourceType
In a filter, matches any ResourceType.
ANY - Static variable in class org.apache.kafka.common.acl.AccessControlEntryFilter
Matches any access control entry.
ANY - Static variable in class org.apache.kafka.common.acl.AclBindingFilter
A filter which matches any ACL binding.
ANY - Static variable in class org.apache.kafka.common.resource.ResourceFilter
Matches any resource.
ANY - Static variable in class org.apache.kafka.common.resource.ResourcePatternFilter
Matches any resource pattern.
ApiException - Exception in org.apache.kafka.common.errors
Any API exception that is part of the public protocol and should be a subclass of this class and be part of this package.
ApiException() - Constructor for exception org.apache.kafka.common.errors.ApiException
 
ApiException(String) - Constructor for exception org.apache.kafka.common.errors.ApiException
 
ApiException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ApiException
 
ApiException(Throwable) - Constructor for exception org.apache.kafka.common.errors.ApiException
 
apply(A) - Method in interface org.apache.kafka.common.KafkaFuture.BaseFunction
 
assign(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
assign(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Manually assign a list of partitions to this consumer.
assign(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
assign(List<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
assign(List<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Retained for backward binary compatibility.
assign(List<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
assign(Map<String, Integer>, Map<String, PartitionAssignor.Subscription>) - Method in class org.apache.kafka.clients.consumer.RangeAssignor
 
assign(Map<String, Integer>, Map<String, PartitionAssignor.Subscription>) - Method in class org.apache.kafka.clients.consumer.RoundRobinAssignor
 
assign(Map<String, Integer>, Map<String, PartitionAssignor.Subscription>) - Method in class org.apache.kafka.clients.consumer.StickyAssignor
 
assignment() - Method in class org.apache.kafka.clients.admin.MemberDescription
The assignment of the group member.
assignment() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
assignment() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the set of partitions currently assigned to this consumer.
assignment() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
assignments() - Method in class org.apache.kafka.clients.admin.NewPartitions
The replica assignments for the new partitions, or null if the assignment will be done by the controller.
atLeast(Number) - Static method in class org.apache.kafka.common.config.ConfigDef.Range
A numeric range that checks only the lower bound
AuthenticateCallbackHandler - Interface in org.apache.kafka.common.security.auth
 
authenticated() - Method in class org.apache.kafka.common.security.plain.PlainAuthenticateCallback
Returns true if client password matches expected password, false otherwise.
authenticated(boolean) - Method in class org.apache.kafka.common.security.plain.PlainAuthenticateCallback
Sets the authenticated state.
AuthenticationContext - Interface in org.apache.kafka.common.security.auth
An object representing contextual information from the authentication session.
AuthenticationException - Exception in org.apache.kafka.common.errors
This exception indicates that SASL authentication has failed.
AuthenticationException(String) - Constructor for exception org.apache.kafka.common.errors.AuthenticationException
 
AuthenticationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.AuthenticationException
 
AuthenticationException(Throwable) - Constructor for exception org.apache.kafka.common.errors.AuthenticationException
 
AuthorizationException - Exception in org.apache.kafka.common.errors
 
AuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.AuthorizationException
 
AuthorizationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.AuthorizationException
 
AUTO_COMMIT_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
auto.commit.interval.ms
AUTO_OFFSET_RESET_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
auto.offset.reset
AUTO_OFFSET_RESET_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
 
availablePartitionsForTopic(String) - Method in class org.apache.kafka.common.Cluster
Get the list of available partitions for this topic

B

BATCH_SIZE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
batch.size
beforeOffset() - Method in class org.apache.kafka.clients.admin.RecordsToDelete
The offset before which all records will be deleted
beforeOffset(long) - Static method in class org.apache.kafka.clients.admin.RecordsToDelete
Delete all the records before the given offset
beginningOffsets(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
beginningOffsets(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the first offset for the given partitions.
beginningOffsets(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
beginningOffsets(Collection<TopicPartition>, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
beginningOffsets(Collection<TopicPartition>, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the first offset for the given partitions.
beginningOffsets(Collection<TopicPartition>, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
beginTransaction() - Method in class org.apache.kafka.clients.producer.KafkaProducer
This API is not supported.
beginTransaction() - Method in class org.apache.kafka.clients.producer.MockProducer
 
beginTransaction() - Method in interface org.apache.kafka.clients.producer.Producer
between(Number, Number) - Static method in class org.apache.kafka.common.config.ConfigDef.Range
A numeric range that checks both the upper (inclusive) and lower bound
binding() - Method in class org.apache.kafka.clients.admin.DeleteAclsResult.FilterResult
Return the deleted ACL binding or null if there was an error.
BOOLEAN - org.apache.kafka.common.config.ConfigDef.Type
 
bootstrap(List<InetSocketAddress>) - Static method in class org.apache.kafka.common.Cluster
Create a "bootstrap" cluster using the given list of host/ports
BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
bootstrap.servers
BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
bootstrap.servers
BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
bootstrap.servers
BROKER - org.apache.kafka.common.config.ConfigResource.Type
 
brokerId() - Method in class org.apache.kafka.common.TopicPartitionReplica
 
BrokerNotAvailableException - Exception in org.apache.kafka.common.errors
 
BrokerNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.BrokerNotAvailableException
 
BrokerNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.BrokerNotAvailableException
 
BUFFER_MEMORY_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
buffer.memory
BufferExhaustedException - Exception in org.apache.kafka.clients.producer
This exception is thrown if the producer is in non-blocking mode and the rate of data production exceeds the rate at which data can be sent for long enough for the allocated buffer to be exhausted.
BufferExhaustedException(String) - Constructor for exception org.apache.kafka.clients.producer.BufferExhaustedException
 
build(AuthenticationContext) - Method in interface org.apache.kafka.common.security.auth.KafkaPrincipalBuilder
Build a kafka principal from the authentication context.
buildPrincipal(TransportLayer, Authenticator) - Method in class org.apache.kafka.common.security.auth.DefaultPrincipalBuilder
Deprecated.
 
buildPrincipal(TransportLayer, Authenticator) - Method in interface org.apache.kafka.common.security.auth.PrincipalBuilder
Deprecated.
Returns Principal.
ByteArray() - Static method in class org.apache.kafka.common.serialization.Serdes
 
ByteArrayDeserializer - Class in org.apache.kafka.common.serialization
 
ByteArrayDeserializer() - Constructor for class org.apache.kafka.common.serialization.ByteArrayDeserializer
 
ByteArraySerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.ByteArraySerde
 
ByteArraySerializer - Class in org.apache.kafka.common.serialization
 
ByteArraySerializer() - Constructor for class org.apache.kafka.common.serialization.ByteArraySerializer
 
ByteBuffer() - Static method in class org.apache.kafka.common.serialization.Serdes
 
ByteBufferDeserializer - Class in org.apache.kafka.common.serialization
 
ByteBufferDeserializer() - Constructor for class org.apache.kafka.common.serialization.ByteBufferDeserializer
 
ByteBufferSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.ByteBufferSerde
 
ByteBufferSerializer - Class in org.apache.kafka.common.serialization
 
ByteBufferSerializer() - Constructor for class org.apache.kafka.common.serialization.ByteBufferSerializer
 
Bytes() - Static method in class org.apache.kafka.common.serialization.Serdes
 
BytesDeserializer - Class in org.apache.kafka.common.serialization
 
BytesDeserializer() - Constructor for class org.apache.kafka.common.serialization.BytesDeserializer
 
BytesSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.BytesSerde
 
BytesSerializer - Class in org.apache.kafka.common.serialization
 
BytesSerializer() - Constructor for class org.apache.kafka.common.serialization.BytesSerializer
 

C

Callback - Interface in org.apache.kafka.clients.producer
A callback interface that the user can implement to allow code to execute when the request is complete.
cancel(boolean) - Method in class org.apache.kafka.common.KafkaFuture
If not already completed, completes this future with a CancellationException.
CHECK_CRCS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
check.crcs
checksum() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
Deprecated.
As of Kafka 0.11.0. Because of the potential for message format conversion on the broker, the checksum returned by the broker may not match what was computed by the producer. It is therefore unsafe to depend on this checksum for end-to-end delivery guarantees. Additionally, message format v2 does not include a record-level checksum (for performance, the record checksum was replaced with a batch checksum). To maintain compatibility, a partial checksum computed from the record timestamp, serialized key size, and serialized value size is returned instead, but this should not be depended on for end-to-end reliability.
checksum() - Method in class org.apache.kafka.clients.producer.RecordMetadata
Deprecated.
As of Kafka 0.11.0. Because of the potential for message format conversion on the broker, the computed checksum may not match what was stored on the broker, or what will be returned to the consumer. It is therefore unsafe to depend on this checksum for end-to-end delivery guarantees. Additionally, message format v2 does not include a record-level checksum (for performance, the record checksum was replaced with a batch checksum). To maintain compatibility, a partial checksum computed from the record timestamp, serialized key size, and serialized value size is returned instead, but this should not be depended on for end-to-end reliability.
CLASS - org.apache.kafka.common.config.ConfigDef.Type
 
CLEANUP_POLICY_COMPACT - Static variable in class org.apache.kafka.common.config.TopicConfig
 
CLEANUP_POLICY_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
CLEANUP_POLICY_DELETE - Static variable in class org.apache.kafka.common.config.TopicConfig
 
CLEANUP_POLICY_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
clear() - Method in class org.apache.kafka.clients.producer.MockProducer
Clear the stored history of sent records, consumer group offsets, and transactional state
CLIENT_DNS_LOOKUP_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
client.dns.lookup
CLIENT_DNS_LOOKUP_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
client.dns.lookup
CLIENT_DNS_LOOKUP_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
client.dns.lookup
CLIENT_ID - org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
 
CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
 
CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
client.id
CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
client.id
clientAddress() - Method in interface org.apache.kafka.common.security.auth.AuthenticationContext
Address of the authenticated client
clientAddress() - Method in class org.apache.kafka.common.security.auth.PlaintextAuthenticationContext
 
clientAddress() - Method in class org.apache.kafka.common.security.auth.SaslAuthenticationContext
 
clientAddress() - Method in class org.apache.kafka.common.security.auth.SslAuthenticationContext
 
clientId() - Method in class org.apache.kafka.clients.admin.MemberDescription
The client id of the group member.
ClientQuotaCallback - Interface in org.apache.kafka.server.quota
Quota callback interface for brokers that enables customization of client quota computation.
ClientQuotaEntity - Interface in org.apache.kafka.server.quota
The metadata for an entity for which quota is configured.
ClientQuotaEntity.ConfigEntity - Interface in org.apache.kafka.server.quota
Interface representing a quota configuration entity.
ClientQuotaEntity.ConfigEntityType - Enum in org.apache.kafka.server.quota
ClientQuotaType - Enum in org.apache.kafka.server.quota
Types of quotas that may be configured on brokers for client requests.
close() - Method in class org.apache.kafka.clients.admin.AdminClient
Close the AdminClient and release all associated resources.
close() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
close() - Method in interface org.apache.kafka.clients.consumer.ConsumerInterceptor
This is called when interceptor is closed
close() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Close the consumer, waiting for up to the default timeout of 30 seconds for any needed cleanup.
close() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
close() - Method in class org.apache.kafka.clients.producer.DefaultStreamsPartitioner
This is called when partitioner is closed.
close() - Method in class org.apache.kafka.clients.producer.KafkaProducer
Close this producer.
close() - Method in class org.apache.kafka.clients.producer.MockProducer
 
close() - Method in interface org.apache.kafka.clients.producer.Partitioner
This is called when partitioner is closed.
close() - Method in interface org.apache.kafka.clients.producer.Producer
close() - Method in interface org.apache.kafka.clients.producer.ProducerInterceptor
This is called when interceptor is closed
close() - Method in interface org.apache.kafka.clients.producer.StreamsPartitioner
This is called when partitioner is closed.
close() - Method in class org.apache.kafka.common.config.provider.FileConfigProvider
 
close() - Method in interface org.apache.kafka.common.security.auth.AuthenticateCallbackHandler
Closes this instance.
close() - Method in class org.apache.kafka.common.security.auth.DefaultPrincipalBuilder
Deprecated.
 
close() - Method in interface org.apache.kafka.common.security.auth.Login
Closes this instance.
close() - Method in interface org.apache.kafka.common.security.auth.PrincipalBuilder
Deprecated.
Closes this instance.
close() - Method in class org.apache.kafka.common.serialization.ByteArrayDeserializer
 
close() - Method in class org.apache.kafka.common.serialization.ByteArraySerializer
 
close() - Method in class org.apache.kafka.common.serialization.ByteBufferDeserializer
 
close() - Method in class org.apache.kafka.common.serialization.ByteBufferSerializer
 
close() - Method in class org.apache.kafka.common.serialization.BytesDeserializer
 
close() - Method in class org.apache.kafka.common.serialization.BytesSerializer
 
close() - Method in interface org.apache.kafka.common.serialization.Deserializer
 
close() - Method in class org.apache.kafka.common.serialization.DoubleDeserializer
 
close() - Method in class org.apache.kafka.common.serialization.DoubleSerializer
 
close() - Method in class org.apache.kafka.common.serialization.ExtendedDeserializer.Wrapper
Deprecated.
 
close() - Method in class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
Deprecated.
 
close() - Method in class org.apache.kafka.common.serialization.FloatDeserializer
 
close() - Method in class org.apache.kafka.common.serialization.FloatSerializer
 
close() - Method in class org.apache.kafka.common.serialization.IntegerDeserializer
 
close() - Method in class org.apache.kafka.common.serialization.IntegerSerializer
 
close() - Method in class org.apache.kafka.common.serialization.LongDeserializer
 
close() - Method in class org.apache.kafka.common.serialization.LongSerializer
 
close() - Method in interface org.apache.kafka.common.serialization.Serde
Close this serde class, which will close the underlying serializer and deserializer.
close() - Method in class org.apache.kafka.common.serialization.Serdes.WrapperSerde
 
close() - Method in interface org.apache.kafka.common.serialization.Serializer
Close this serializer.
close() - Method in class org.apache.kafka.common.serialization.ShortDeserializer
 
close() - Method in class org.apache.kafka.common.serialization.ShortSerializer
 
close() - Method in class org.apache.kafka.common.serialization.StringDeserializer
 
close() - Method in class org.apache.kafka.common.serialization.StringSerializer
 
close() - Method in class org.apache.kafka.common.serialization.UUIDDeserializer
 
close() - Method in class org.apache.kafka.common.serialization.UUIDSerializer
 
close() - Method in interface org.apache.kafka.server.quota.ClientQuotaCallback
Closes this instance.
close(long, TimeUnit) - Method in class org.apache.kafka.clients.admin.AdminClient
Close the AdminClient and release all associated resources.
close(long, TimeUnit) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
close(long, TimeUnit) - Method in interface org.apache.kafka.clients.consumer.Consumer
Deprecated.
close(long, TimeUnit) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
close(long, TimeUnit) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
close(long, TimeUnit) - Method in class org.apache.kafka.clients.producer.KafkaProducer
This method waits up to timeout for the producer to complete the sending of all incomplete requests.
close(long, TimeUnit) - Method in class org.apache.kafka.clients.producer.MockProducer
 
close(long, TimeUnit) - Method in interface org.apache.kafka.clients.producer.Producer
close(Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
close(Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Tries to close the consumer cleanly within the specified timeout.
close(Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
closed() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
closed() - Method in class org.apache.kafka.clients.producer.MockProducer
 
Cluster - Class in org.apache.kafka.common
A representation of a subset of the nodes, topics, and partitions in the Kafka cluster.
Cluster(String, Collection<Node>, Collection<PartitionInfo>, Set<String>, Set<String>) - Constructor for class org.apache.kafka.common.Cluster
Create a new cluster with the given id, nodes and partitions
Cluster(String, Collection<Node>, Collection<PartitionInfo>, Set<String>, Set<String>, Set<String>, Node) - Constructor for class org.apache.kafka.common.Cluster
Create a new cluster with the given id, nodes and partitions
Cluster(String, Collection<Node>, Collection<PartitionInfo>, Set<String>, Set<String>, Node) - Constructor for class org.apache.kafka.common.Cluster
Create a new cluster with the given id, nodes and partitions
CLUSTER - org.apache.kafka.common.resource.ResourceType
The cluster as a whole.
CLUSTER - Static variable in class org.apache.kafka.common.resource.Resource
A resource representing the whole cluster.
CLUSTER_ACTION - org.apache.kafka.common.acl.AclOperation
CLUSTER_ACTION operation.
CLUSTER_NAME - Static variable in class org.apache.kafka.common.resource.Resource
The name of the CLUSTER resource.
ClusterAuthorizationException - Exception in org.apache.kafka.common.errors
 
ClusterAuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.ClusterAuthorizationException
 
ClusterAuthorizationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ClusterAuthorizationException
 
clusterId() - Method in class org.apache.kafka.clients.admin.DescribeClusterResult
Returns a future which yields the current cluster id.
clusterId() - Method in class org.apache.kafka.common.ClusterResource
Return the cluster id.
clusterResource() - Method in class org.apache.kafka.common.Cluster
 
ClusterResource - Class in org.apache.kafka.common
The ClusterResource class encapsulates metadata for a Kafka cluster.
ClusterResource(String) - Constructor for class org.apache.kafka.common.ClusterResource
Create ClusterResource with a cluster id.
ClusterResourceListener - Interface in org.apache.kafka.common
A callback interface that users can implement when they wish to get notified about changes in the Cluster metadata.
code() - Method in enum org.apache.kafka.common.acl.AclOperation
Return the code of this operation.
code() - Method in enum org.apache.kafka.common.acl.AclPermissionType
Return the code of this permission type.
code() - Method in enum org.apache.kafka.common.resource.PatternType
 
code() - Method in enum org.apache.kafka.common.resource.ResourceType
Return the code of this resource.
commit() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
 
commit() - Method in class org.apache.kafka.common.security.plain.PlainLoginModule
 
commit() - Method in class org.apache.kafka.common.security.scram.ScramLoginModule
 
commitAsync() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitAsync() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit offsets returned on the last KafkaConsumer.poll(Duration) for all the subscribed list of topics and partition.
commitAsync() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commitAsync(Map<TopicPartition, OffsetAndMetadata>, OffsetCommitCallback) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitAsync(Map<TopicPartition, OffsetAndMetadata>, OffsetCommitCallback) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit the specified offsets for the specified list of topics and partitions to Kafka.
commitAsync(Map<TopicPartition, OffsetAndMetadata>, OffsetCommitCallback) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commitAsync(OffsetCommitCallback) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitAsync(OffsetCommitCallback) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit offsets returned on the last poll() for the subscribed list of topics and partitions.
commitAsync(OffsetCommitCallback) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commitCount() - Method in class org.apache.kafka.clients.producer.MockProducer
 
CommitFailedException - Exception in org.apache.kafka.clients.consumer
This exception is raised when an offset commit with KafkaConsumer.commitSync() fails with an unrecoverable error.
CommitFailedException() - Constructor for exception org.apache.kafka.clients.consumer.CommitFailedException
 
commitSync() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitSync() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit offsets returned on the last poll() for all the subscribed list of topics and partitions.
commitSync() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commitSync(Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitSync(Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit offsets returned on the last poll() for all the subscribed list of topics and partitions.
commitSync(Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commitSync(Map<TopicPartition, OffsetAndMetadata>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitSync(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit the specified offsets for the specified list of topics and partitions.
commitSync(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commitSync(Map<TopicPartition, OffsetAndMetadata>, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitSync(Map<TopicPartition, OffsetAndMetadata>, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit the specified offsets for the specified list of topics and partitions.
commitSync(Map<TopicPartition, OffsetAndMetadata>, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
committed(TopicPartition) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
committed(TopicPartition) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the last committed offset for the given partition (whether the commit happened by this process or another).
committed(TopicPartition) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
committed(TopicPartition, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
committed(TopicPartition, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the last committed offset for the given partition (whether the commit happened by this process or another).
committed(TopicPartition, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commitTransaction() - Method in class org.apache.kafka.clients.producer.KafkaProducer
This API is not supported.
commitTransaction() - Method in class org.apache.kafka.clients.producer.MockProducer
 
commitTransaction() - Method in interface org.apache.kafka.clients.producer.Producer
complete(T) - Method in class org.apache.kafka.common.KafkaFuture
If not already completed, sets the value returned by get() and related methods to the given value.
completedFuture(U) - Static method in class org.apache.kafka.common.KafkaFuture
Returns a new KafkaFuture that is already completed with the given value.
completeExceptionally(Throwable) - Method in class org.apache.kafka.common.KafkaFuture
If not already completed, causes invocations of get() and related methods to throw the given exception.
completeNext() - Method in class org.apache.kafka.clients.producer.MockProducer
Complete the earliest uncompleted call successfully.
COMPLETING_REBALANCE - org.apache.kafka.common.ConsumerGroupState
 
COMPRESSION_TYPE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
compression.type
COMPRESSION_TYPE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
COMPRESSION_TYPE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
ConcurrentTransactionsException - Exception in org.apache.kafka.common.errors
 
ConcurrentTransactionsException(String) - Constructor for exception org.apache.kafka.common.errors.ConcurrentTransactionsException
 
Config - Class in org.apache.kafka.clients.admin
A configuration object containing the configuration entries for a resource.
Config - Class in org.apache.kafka.common.config
 
Config(Collection<ConfigEntry>) - Constructor for class org.apache.kafka.clients.admin.Config
Create a configuration instance with the provided entries.
Config(List<ConfigValue>) - Constructor for class org.apache.kafka.common.config.Config
 
ConfigChangeCallback - Interface in org.apache.kafka.common.config
A callback passed to ConfigProvider for subscribing to changes.
ConfigData - Class in org.apache.kafka.common.config
Configuration data from a ConfigProvider.
ConfigData(Map<String, String>) - Constructor for class org.apache.kafka.common.config.ConfigData
Creates a new ConfigData with the given data.
ConfigData(Map<String, String>, Long) - Constructor for class org.apache.kafka.common.config.ConfigData
Creates a new ConfigData with the given data and TTL (in milliseconds).
ConfigDef - Class in org.apache.kafka.common.config
This class is used for specifying the set of expected configurations.
ConfigDef() - Constructor for class org.apache.kafka.common.config.ConfigDef
 
ConfigDef(ConfigDef) - Constructor for class org.apache.kafka.common.config.ConfigDef
 
ConfigDef.CompositeValidator - Class in org.apache.kafka.common.config
 
ConfigDef.ConfigKey - Class in org.apache.kafka.common.config
 
ConfigDef.Importance - Enum in org.apache.kafka.common.config
The importance level for a configuration
ConfigDef.NonEmptyString - Class in org.apache.kafka.common.config
 
ConfigDef.NonEmptyStringWithoutControlChars - Class in org.apache.kafka.common.config
 
ConfigDef.NonNullValidator - Class in org.apache.kafka.common.config
 
ConfigDef.Range - Class in org.apache.kafka.common.config
Validation logic for numeric ranges
ConfigDef.Recommender - Interface in org.apache.kafka.common.config
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 - Enum in org.apache.kafka.common.config
The config types
ConfigDef.Validator - Interface in org.apache.kafka.common.config
Validation logic the user may provide to perform single configuration validation.
ConfigDef.ValidList - Class in org.apache.kafka.common.config
 
ConfigDef.ValidString - Class in org.apache.kafka.common.config
 
ConfigDef.Width - Enum in org.apache.kafka.common.config
The width of a configuration value
configEntities() - Method in interface org.apache.kafka.server.quota.ClientQuotaEntity
Returns the list of configuration entities that this quota entity is comprised of.
ConfigEntry - Class in org.apache.kafka.clients.admin
A class representing a configuration entry containing name, value and additional metadata.
ConfigEntry(String, String) - Constructor for class org.apache.kafka.clients.admin.ConfigEntry
Create a configuration entry with the provided values.
ConfigEntry(String, String, boolean, boolean, boolean) - Constructor for class org.apache.kafka.clients.admin.ConfigEntry
Deprecated.
since 1.1.0. This constructor will be removed in a future release.
ConfigEntry.ConfigSource - Enum in org.apache.kafka.clients.admin
Source of configuration entries.
ConfigEntry.ConfigSynonym - Class in org.apache.kafka.clients.admin
Class representing a configuration synonym of a ConfigEntry.
ConfigException - Exception in org.apache.kafka.common.config
Thrown if the user supplies an invalid configuration
ConfigException(String) - Constructor for exception org.apache.kafka.common.config.ConfigException
 
ConfigException(String, Object) - Constructor for exception org.apache.kafka.common.config.ConfigException
 
ConfigException(String, Object, String) - Constructor for exception org.apache.kafka.common.config.ConfigException
 
ConfigKey(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender, boolean) - Constructor for class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
configKeys() - Method in class org.apache.kafka.common.config.ConfigDef
Get the configuration keys
configNames() - Static method in class org.apache.kafka.clients.admin.AdminClientConfig
 
configNames() - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
 
configNames() - Static method in class org.apache.kafka.clients.producer.ProducerConfig
 
ConfigProvider - Interface in org.apache.kafka.common.config.provider
A provider of configuration data, which may optionally support subscriptions to configuration changes.
ConfigResource - Class in org.apache.kafka.common.config
A class representing resources that have configs.
ConfigResource(ConfigResource.Type, String) - Constructor for class org.apache.kafka.common.config.ConfigResource
Create an instance of this class with the provided parameters.
ConfigResource.Type - Enum in org.apache.kafka.common.config
Type of resource.
configs() - Method in class org.apache.kafka.clients.admin.NewTopic
The configuration for the new topic or null if no configs ever specified.
configs() - Method in class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
Return the configs in the request.
configs() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
Return topic configs in the request, not including broker defaults.
configs(Map<String, String>) - Method in class org.apache.kafka.clients.admin.NewTopic
Set the configuration to use on the new topic.
ConfigTransformer - Class in org.apache.kafka.common.config
This class wraps a set of ConfigProvider instances and uses them to perform transformations.
ConfigTransformer(Map<String, ConfigProvider>) - Constructor for class org.apache.kafka.common.config.ConfigTransformer
Creates a ConfigTransformer with the default pattern, of the form ${provider:[path:]key}.
ConfigTransformerResult - Class in org.apache.kafka.common.config
The result of a transformation from ConfigTransformer.
ConfigTransformerResult(Map<String, String>, Map<String, Long>) - Constructor for class org.apache.kafka.common.config.ConfigTransformerResult
Creates a new ConfigTransformerResult with the given data and TTL values for a set of paths.
Configurable - Interface in org.apache.kafka.common
A Mix-in style interface for classes that are instantiated by reflection and need to take configuration parameters
configure(Map<String, ?>) - Method in class org.apache.kafka.clients.producer.DefaultStreamsPartitioner
 
configure(Map<String, ?>) - Method in class org.apache.kafka.common.config.provider.FileConfigProvider
 
configure(Map<String, ?>) - Method in interface org.apache.kafka.common.Configurable
Configure this class with the given key-value pairs
configure(Map<String, ?>) - Method in class org.apache.kafka.common.security.auth.DefaultPrincipalBuilder
Deprecated.
 
configure(Map<String, ?>) - Method in interface org.apache.kafka.common.security.auth.PrincipalBuilder
Deprecated.
Configures this class with given key-value pairs.
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.ByteArrayDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.ByteArraySerializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.ByteBufferDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.ByteBufferSerializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.BytesDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.BytesSerializer
 
configure(Map<String, ?>, boolean) - Method in interface org.apache.kafka.common.serialization.Deserializer
Configure this class.
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.DoubleDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.DoubleSerializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.ExtendedDeserializer.Wrapper
Deprecated.
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
Deprecated.
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.FloatDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.FloatSerializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.IntegerDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.IntegerSerializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.LongDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.LongSerializer
 
configure(Map<String, ?>, boolean) - Method in interface org.apache.kafka.common.serialization.Serde
Configure this class, which will configure the underlying serializer and deserializer.
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.Serdes.WrapperSerde
 
configure(Map<String, ?>, boolean) - Method in interface org.apache.kafka.common.serialization.Serializer
Configure this class.
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.ShortDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.ShortSerializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.StringDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.StringSerializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.UUIDDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.UUIDSerializer
 
configure(Map<String, ?>, String, List<AppConfigurationEntry>) - Method in interface org.apache.kafka.common.security.auth.AuthenticateCallbackHandler
Configures this callback handler for the specified SASL mechanism.
configure(Map<String, ?>, String, Configuration, AuthenticateCallbackHandler) - Method in interface org.apache.kafka.common.security.auth.Login
Configures this login instance.
ConfigValue - Class in org.apache.kafka.common.config
 
ConfigValue(String) - Constructor for class org.apache.kafka.common.config.ConfigValue
 
ConfigValue(String, Object, List<Object>, List<String>) - Constructor for class org.apache.kafka.common.config.ConfigValue
 
configValues() - Method in class org.apache.kafka.common.config.Config
 
CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
connections.max.idle.ms
CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
connections.max.idle.ms
CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
connections.max.idle.ms
Consumer<K,​V> - Interface in org.apache.kafka.clients.consumer
 
ConsumerConfig - Class in org.apache.kafka.clients.consumer
The consumer configuration keys
ConsumerConfig(Map<?, ?>, boolean) - Constructor for class org.apache.kafka.clients.consumer.ConsumerConfig
 
ConsumerConfig(Map<String, Object>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerConfig
 
ConsumerConfig(Properties) - Constructor for class org.apache.kafka.clients.consumer.ConsumerConfig
 
ConsumerGroupDescription - Class in org.apache.kafka.clients.admin
A detailed description of a single consumer group in the cluster.
ConsumerGroupDescription(String, boolean, Collection<MemberDescription>, String, ConsumerGroupState, Node) - Constructor for class org.apache.kafka.clients.admin.ConsumerGroupDescription
 
ConsumerGroupListing - Class in org.apache.kafka.clients.admin
A listing of a consumer group in the cluster.
ConsumerGroupListing(String, boolean) - Constructor for class org.apache.kafka.clients.admin.ConsumerGroupListing
Create an instance with the specified parameters.
consumerGroupOffsetsHistory() - Method in class org.apache.kafka.clients.producer.MockProducer
Get the list of committed consumer group offsets since the last call to MockProducer.clear()
ConsumerGroupState - Enum in org.apache.kafka.common
The consumer group state.
consumerId() - Method in class org.apache.kafka.clients.admin.MemberDescription
The consumer id of the group member.
ConsumerInterceptor<K,​V> - Interface in org.apache.kafka.clients.consumer
A plugin interface that allows you to intercept (and possibly mutate) records received by the consumer.
ConsumerRebalanceListener - Interface in org.apache.kafka.clients.consumer
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> - Class in org.apache.kafka.clients.consumer
A key/value pair to be received from Kafka.
ConsumerRecord(String, int, long, long, TimestampType, long, int, int, K, V) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
Creates a record to be received from a specified topic and partition (provided for compatibility with Kafka 0.10 before the message format supported headers).
ConsumerRecord(String, int, long, long, TimestampType, Long, int, int, K, V, Headers) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
Creates a record to be received from a specified topic and partition
ConsumerRecord(String, int, long, long, TimestampType, Long, int, int, K, V, Headers, String) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
The constructor is added for backward compatibility
ConsumerRecord(String, int, long, long, TimestampType, Long, int, int, K, V, Headers, Optional<Integer>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
 
ConsumerRecord(String, int, long, long, TimestampType, Long, int, int, K, V, Headers, Optional<Integer>, String) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
Creates a record to be received from a specified topic and partition
ConsumerRecord(String, int, long, K, V) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
Creates a record to be received from a specified topic and partition (provided for compatibility with Kafka 0.9 before the message format supported timestamps and before serialized metadata were exposed).
ConsumerRecord(String, int, long, K, V, long, String) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
Creates a record to be received from a specified topic and partition
ConsumerRecords<K,​V> - Class in org.apache.kafka.clients.consumer
A container that holds the list ConsumerRecord per partition for a particular topic.
ConsumerRecords(Map<TopicPartition, List<ConsumerRecord<K, V>>>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecords
 
controller() - Method in class org.apache.kafka.clients.admin.DescribeClusterResult
Returns a future which yields the current controller id.
controller() - Method in class org.apache.kafka.common.Cluster
 
ControllerMovedException - Exception in org.apache.kafka.common.errors
 
ControllerMovedException(String) - Constructor for exception org.apache.kafka.common.errors.ControllerMovedException
 
ControllerMovedException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ControllerMovedException
 
convertToString(Object, ConfigDef.Type) - Static method in class org.apache.kafka.common.config.ConfigDef
 
convertToStringMapWithPasswordValues(Map<String, ?>) - Static method in class org.apache.kafka.common.config.ConfigDef
Converts a map of config (key, value) pairs to a map of strings where each value is converted to a string.
coordinator() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
The consumer group coordinator, or null if the coordinator is not known.
CoordinatorLoadInProgressException - Exception in org.apache.kafka.common.errors
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.
CoordinatorLoadInProgressException(String) - Constructor for exception org.apache.kafka.common.errors.CoordinatorLoadInProgressException
 
CoordinatorLoadInProgressException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.CoordinatorLoadInProgressException
 
CoordinatorNotAvailableException - Exception in org.apache.kafka.common.errors
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.
CoordinatorNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.CoordinatorNotAvailableException
 
CoordinatorNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.CoordinatorNotAvailableException
 
CorruptRecordException - Exception in org.apache.kafka.common.errors
This exception indicates a record has failed its internal CRC check, this generally indicates network or disk corruption.
CorruptRecordException() - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
 
CorruptRecordException(String) - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
 
CorruptRecordException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
 
CorruptRecordException(Throwable) - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
 
count() - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
The number of records for all topics
create(Map<String, Object>) - Static method in class org.apache.kafka.clients.admin.AdminClient
Create a new AdminClient with the given configuration.
create(Properties) - Static method in class org.apache.kafka.clients.admin.AdminClient
Create a new AdminClient with the given configuration.
CREATE - org.apache.kafka.common.acl.AclOperation
CREATE operation.
createAcls(Collection<AclBinding>) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
createAcls(Collection<AclBinding>, CreateAclsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
createAcls(Collection<AclBinding>, CreateAclsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
CreateAclsOptions - Class in org.apache.kafka.clients.admin
CreateAclsOptions() - Constructor for class org.apache.kafka.clients.admin.CreateAclsOptions
 
CreateAclsResult - Class in org.apache.kafka.clients.admin
The result of the AdminClient.createAcls(Collection) call.
CreateAclsResult(Map<AclBinding, KafkaFuture<Void>>) - Constructor for class org.apache.kafka.clients.admin.CreateAclsResult
 
createDelegationToken() - Method in class org.apache.kafka.clients.admin.AdminClient
Create a Delegation Token.
createDelegationToken(CreateDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
Create a Delegation Token.
createDelegationToken(CreateDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
CreateDelegationTokenOptions - Class in org.apache.kafka.clients.admin
CreateDelegationTokenOptions() - Constructor for class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
 
CreateDelegationTokenResult - Class in org.apache.kafka.clients.admin
createPartitions(Map<String, NewPartitions>) - Method in class org.apache.kafka.clients.admin.AdminClient
Increase the number of partitions of the topics given as the keys of newPartitions according to the corresponding values.
createPartitions(Map<String, NewPartitions>, CreatePartitionsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
Increase the number of partitions of the topics given as the keys of newPartitions according to the corresponding values.
createPartitions(Map<String, NewPartitions>, CreatePartitionsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
CreatePartitionsOptions - Class in org.apache.kafka.clients.admin
CreatePartitionsOptions() - Constructor for class org.apache.kafka.clients.admin.CreatePartitionsOptions
 
CreatePartitionsResult - Class in org.apache.kafka.clients.admin
The result of the AdminClient.createPartitions(Map) call.
CreatePartitionsResult(Map<String, KafkaFuture<Void>>) - Constructor for class org.apache.kafka.clients.admin.CreatePartitionsResult
 
CreateTopicPolicy - Interface in org.apache.kafka.server.policy
An interface for enforcing a policy on create topics requests.
CreateTopicPolicy.RequestMetadata - Class in org.apache.kafka.server.policy
Class containing the create request parameters.
createTopics(Collection<NewTopic>) - Method in class org.apache.kafka.clients.admin.AdminClient
Create a batch of new topics with the default options.
createTopics(Collection<NewTopic>, CreateTopicsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
Create a batch of new topics.
createTopics(Collection<NewTopic>, CreateTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
CreateTopicsOptions - Class in org.apache.kafka.clients.admin
CreateTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.CreateTopicsOptions
 
CreateTopicsResult - Class in org.apache.kafka.clients.admin
CreateTopicsResult(Map<String, KafkaFuture<Void>>) - Constructor for class org.apache.kafka.clients.admin.CreateTopicsResult
 

D

data() - Method in class org.apache.kafka.common.config.ConfigData
Returns the data.
data() - Method in class org.apache.kafka.common.config.ConfigTransformerResult
Returns the transformed data, with variables replaced with corresponding values from the ConfigProvider instances if found.
DEAD - org.apache.kafka.common.ConsumerGroupState
 
DEFAULT_API_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
default.api.timeout.ms
DEFAULT_API_TIMEOUT_MS_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
 
DEFAULT_CLIENT_ID - org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
 
DEFAULT_CONFIG - org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
 
DEFAULT_EXCLUDE_INTERNAL_TOPICS - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
 
DEFAULT_FETCH_MAX_BYTES - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
 
DEFAULT_ISOLATION_LEVEL - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
 
DEFAULT_KERBEROS_KINIT_CMD - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
DEFAULT_KERBEROS_MIN_TIME_BEFORE_RELOGIN - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
DEFAULT_KERBEROS_TICKET_RENEW_JITTER - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
DEFAULT_KERBEROS_TICKET_RENEW_WINDOW_FACTOR - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
DEFAULT_LOGIN_REFRESH_BUFFER_SECONDS - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
DEFAULT_LOGIN_REFRESH_MIN_PERIOD_SECONDS - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
DEFAULT_LOGIN_REFRESH_WINDOW_FACTOR - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
DEFAULT_LOGIN_REFRESH_WINDOW_JITTER - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
DEFAULT_MAX_PARTITION_FETCH_BYTES - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
 
DEFAULT_PATTERN - Static variable in class org.apache.kafka.common.config.ConfigTransformer
 
DEFAULT_PRINCIPAL_BUILDER_CLASS - Static variable in class org.apache.kafka.common.config.SslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release. In recent versions, the config is optional and there is no default.
DEFAULT_SASL_ENABLED_MECHANISMS - Static variable in class org.apache.kafka.common.config.SaslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
DEFAULT_SASL_KERBEROS_PRINCIPAL_TO_LOCAL_RULES - Static variable in class org.apache.kafka.common.config.SaslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
DEFAULT_SASL_MECHANISM - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
DEFAULT_SECURITY_PROTOCOL - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
 
DEFAULT_SSL_ENABLED_PROTOCOLS - Static variable in class org.apache.kafka.common.config.SslConfigs
 
DEFAULT_SSL_ENDPOINT_IDENTIFICATION_ALGORITHM - Static variable in class org.apache.kafka.common.config.SslConfigs
 
DEFAULT_SSL_KEYMANGER_ALGORITHM - Static variable in class org.apache.kafka.common.config.SslConfigs
 
DEFAULT_SSL_KEYSTORE_TYPE - Static variable in class org.apache.kafka.common.config.SslConfigs
 
DEFAULT_SSL_PROTOCOL - Static variable in class org.apache.kafka.common.config.SslConfigs
 
DEFAULT_SSL_TRUSTMANAGER_ALGORITHM - Static variable in class org.apache.kafka.common.config.SslConfigs
 
DEFAULT_SSL_TRUSTSTORE_TYPE - Static variable in class org.apache.kafka.common.config.SslConfigs
 
DEFAULT_STREAMS_CLIENTSIDE_PARTITION_ASSIGNMENT - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
 
DEFAULT_USER - org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
 
DefaultPrincipalBuilder - Class in org.apache.kafka.common.security.auth
Deprecated.
As of Kafka 1.0.0. This will be removed in a future major release.
DefaultPrincipalBuilder() - Constructor for class org.apache.kafka.common.security.auth.DefaultPrincipalBuilder
Deprecated.
 
DefaultStreamsPartitioner - Class in org.apache.kafka.clients.producer
 
DefaultStreamsPartitioner() - Constructor for class org.apache.kafka.clients.producer.DefaultStreamsPartitioner
 
defaultValue - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
defaultValues() - Method in class org.apache.kafka.common.config.ConfigDef
 
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no special validation logic
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String, String, int, ConfigDef.Width, String) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no special validation logic, not dependents and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no special validation logic and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no special validation logic
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, ConfigDef.Recommender) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no special validation logic and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no group, no order in group, no width, no display name, no dependents and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no dependents and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, ConfigDef.Recommender) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no dependents
define(String, ConfigDef.Type, ConfigDef.Importance, String) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no default value and no special validation logic
define(String, ConfigDef.Type, ConfigDef.Importance, String, String, int, ConfigDef.Width, String) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no default value, no special validation logic, no dependents and no custom recommender
define(String, ConfigDef.Type, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no default value, no special validation logic and no custom recommender
define(String, ConfigDef.Type, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no default value and no special validation logic
define(String, ConfigDef.Type, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, ConfigDef.Recommender) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no default value, no special validation logic and no custom recommender
define(ConfigDef.ConfigKey) - Method in class org.apache.kafka.common.config.ConfigDef
 
defineInternal(String, ConfigDef.Type, Object, ConfigDef.Importance) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new internal configuration.
DELEGATION_TOKEN - org.apache.kafka.common.resource.ResourceType
A token ID.
delegationToken() - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenResult
Returns a future which yields a delegation token
DelegationToken - Class in org.apache.kafka.common.security.token.delegation
A class representing a delegation token.
DelegationToken(TokenInformation, byte[]) - Constructor for class org.apache.kafka.common.security.token.delegation.DelegationToken
 
DelegationTokenAuthorizationException - Exception in org.apache.kafka.common.errors
 
DelegationTokenAuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenAuthorizationException
 
DelegationTokenAuthorizationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenAuthorizationException
 
DelegationTokenDisabledException - Exception in org.apache.kafka.common.errors
 
DelegationTokenDisabledException(String) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenDisabledException
 
DelegationTokenDisabledException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenDisabledException
 
DelegationTokenExpiredException - Exception in org.apache.kafka.common.errors
 
DelegationTokenExpiredException(String) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenExpiredException
 
DelegationTokenExpiredException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenExpiredException
 
DelegationTokenNotFoundException - Exception in org.apache.kafka.common.errors
 
DelegationTokenNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenNotFoundException
 
DelegationTokenNotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenNotFoundException
 
DelegationTokenOwnerMismatchException - Exception in org.apache.kafka.common.errors
 
DelegationTokenOwnerMismatchException(String) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenOwnerMismatchException
 
DelegationTokenOwnerMismatchException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenOwnerMismatchException
 
delegationTokens() - Method in class org.apache.kafka.clients.admin.DescribeDelegationTokenResult
Returns a future which yields list of delegation tokens
DELETE - org.apache.kafka.common.acl.AclOperation
DELETE operation.
DELETE_RETENTION_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
DELETE_RETENTION_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
deleteAcls(Collection<AclBindingFilter>) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
deleteAcls(Collection<AclBindingFilter>, DeleteAclsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
deleteAcls(Collection<AclBindingFilter>, DeleteAclsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
DeleteAclsOptions - Class in org.apache.kafka.clients.admin
DeleteAclsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteAclsOptions
 
DeleteAclsResult - Class in org.apache.kafka.clients.admin
The result of the AdminClient.deleteAcls(Collection) call.
DeleteAclsResult(Map<AclBindingFilter, KafkaFuture<DeleteAclsResult.FilterResults>>) - Constructor for class org.apache.kafka.clients.admin.DeleteAclsResult
 
DeleteAclsResult.FilterResult - Class in org.apache.kafka.clients.admin
A class containing either the deleted ACL binding or an exception if the delete failed.
DeleteAclsResult.FilterResults - Class in org.apache.kafka.clients.admin
A class containing the results of the delete ACLs operation.
deleteConsumerGroups(Collection<String>) - Method in class org.apache.kafka.clients.admin.AdminClient
Delete consumer groups from the cluster with the default options.
deleteConsumerGroups(Collection<String>, DeleteConsumerGroupsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
Delete consumer groups from the cluster.
deleteConsumerGroups(Collection<String>, DeleteConsumerGroupsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
DeleteConsumerGroupsOptions - Class in org.apache.kafka.clients.admin
DeleteConsumerGroupsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteConsumerGroupsOptions
 
DeleteConsumerGroupsResult - Class in org.apache.kafka.clients.admin
deletedGroups() - Method in class org.apache.kafka.clients.admin.DeleteConsumerGroupsResult
Return a map from group id to futures which can be used to check the status of individual deletions.
DeletedRecords - Class in org.apache.kafka.clients.admin
Represents information about deleted records The API for this class is still evolving and we may break compatibility in minor releases, if necessary.
DeletedRecords(long) - Constructor for class org.apache.kafka.clients.admin.DeletedRecords
Create an instance of this class with the provided parameters.
deleteRecords(Map<TopicPartition, RecordsToDelete>) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
deleteRecords(Map<TopicPartition, RecordsToDelete>, DeleteRecordsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
deleteRecords(Map<TopicPartition, RecordsToDelete>, DeleteRecordsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
DeleteRecordsOptions - Class in org.apache.kafka.clients.admin
DeleteRecordsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteRecordsOptions
 
DeleteRecordsResult - Class in org.apache.kafka.clients.admin
The result of the AdminClient.deleteRecords(Map) call.
DeleteRecordsResult(Map<TopicPartition, KafkaFuture<DeletedRecords>>) - Constructor for class org.apache.kafka.clients.admin.DeleteRecordsResult
 
deleteTopics(Collection<String>) - Method in class org.apache.kafka.clients.admin.AdminClient
This is a convenience method for #AdminClient.deleteTopics(Collection, DeleteTopicsOptions) with default options.
deleteTopics(Collection<String>, DeleteTopicsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
Delete a batch of topics.
deleteTopics(Collection<String>, DeleteTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
DeleteTopicsOptions - Class in org.apache.kafka.clients.admin
DeleteTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteTopicsOptions
 
DeleteTopicsResult - Class in org.apache.kafka.clients.admin
The result of the AdminClient.deleteTopics(Collection) call.
DeleteTopicsResult(Map<String, KafkaFuture<Void>>) - Constructor for class org.apache.kafka.clients.admin.DeleteTopicsResult
 
DELIVERY_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
delivery.timeout.ms
DENY - org.apache.kafka.common.acl.AclPermissionType
Disallows access.
dependents - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
DESCRIBE - org.apache.kafka.common.acl.AclOperation
DESCRIBE operation.
DESCRIBE_CONFIGS - org.apache.kafka.common.acl.AclOperation
DESCRIBE_CONFIGS operation.
describeAcls(AclBindingFilter) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
describeAcls(AclBindingFilter, DescribeAclsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
describeAcls(AclBindingFilter, DescribeAclsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
DescribeAclsOptions - Class in org.apache.kafka.clients.admin
DescribeAclsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeAclsOptions
 
DescribeAclsResult - Class in org.apache.kafka.clients.admin
DescribeAclsResult(KafkaFuture<Collection<AclBinding>>) - Constructor for class org.apache.kafka.clients.admin.DescribeAclsResult
 
describeCluster() - Method in class org.apache.kafka.clients.admin.AdminClient
Get information about the nodes in the cluster, using the default options.
describeCluster(DescribeClusterOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
Get information about the nodes in the cluster.
describeCluster(DescribeClusterOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
DescribeClusterOptions - Class in org.apache.kafka.clients.admin
DescribeClusterOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeClusterOptions
 
DescribeClusterResult - Class in org.apache.kafka.clients.admin
The result of the AdminClient.describeCluster() call.
DescribeClusterResult(KafkaFuture<Collection<Node>>, KafkaFuture<Node>, KafkaFuture<String>) - Constructor for class org.apache.kafka.clients.admin.DescribeClusterResult
 
describeConfigs(Collection<ConfigResource>) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
describeConfigs(Collection<ConfigResource>, DescribeConfigsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
describeConfigs(Collection<ConfigResource>, DescribeConfigsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
DescribeConfigsOptions - Class in org.apache.kafka.clients.admin
DescribeConfigsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeConfigsOptions
 
DescribeConfigsResult - Class in org.apache.kafka.clients.admin
DescribeConfigsResult(Map<ConfigResource, KafkaFuture<Config>>) - Constructor for class org.apache.kafka.clients.admin.DescribeConfigsResult
 
describeConsumerGroups(Collection<String>) - Method in class org.apache.kafka.clients.admin.AdminClient
Describe some group IDs in the cluster, with the default options.
describeConsumerGroups(Collection<String>, DescribeConsumerGroupsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
Describe some group IDs in the cluster.
describeConsumerGroups(Collection<String>, DescribeConsumerGroupsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
DescribeConsumerGroupsOptions - Class in org.apache.kafka.clients.admin
DescribeConsumerGroupsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeConsumerGroupsOptions
 
DescribeConsumerGroupsResult - Class in org.apache.kafka.clients.admin
DescribeConsumerGroupsResult(Map<String, KafkaFuture<ConsumerGroupDescription>>) - Constructor for class org.apache.kafka.clients.admin.DescribeConsumerGroupsResult
 
describeDelegationToken() - Method in class org.apache.kafka.clients.admin.AdminClient
Describe the Delegation Tokens.
describeDelegationToken(DescribeDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
Describe the Delegation Tokens.
describeDelegationToken(DescribeDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
DescribeDelegationTokenOptions - Class in org.apache.kafka.clients.admin
DescribeDelegationTokenOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeDelegationTokenOptions
 
DescribeDelegationTokenResult - Class in org.apache.kafka.clients.admin
describedGroups() - Method in class org.apache.kafka.clients.admin.DescribeConsumerGroupsResult
Return a map from group id to futures which yield group descriptions.
describeLogDirs(Collection<Integer>) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
describeLogDirs(Collection<Integer>, DescribeLogDirsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
describeLogDirs(Collection<Integer>, DescribeLogDirsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
DescribeLogDirsOptions - Class in org.apache.kafka.clients.admin
Options for AdminClient.describeLogDirs(Collection) The API of this class is evolving, see AdminClient for details.
DescribeLogDirsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeLogDirsOptions
 
DescribeLogDirsResult - Class in org.apache.kafka.clients.admin
DescribeLogDirsResult(Map<Integer, KafkaFuture<Map<String, DescribeLogDirsResponse.LogDirInfo>>>) - Constructor for class org.apache.kafka.clients.admin.DescribeLogDirsResult
 
describeReplicaLogDirs(Collection<TopicPartitionReplica>) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
describeReplicaLogDirs(Collection<TopicPartitionReplica>, DescribeReplicaLogDirsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
This API is not supported.
describeReplicaLogDirs(Collection<TopicPartitionReplica>, DescribeReplicaLogDirsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
DescribeReplicaLogDirsOptions - Class in org.apache.kafka.clients.admin
DescribeReplicaLogDirsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeReplicaLogDirsOptions
 
DescribeReplicaLogDirsResult - Class in org.apache.kafka.clients.admin
DescribeReplicaLogDirsResult(Map<TopicPartitionReplica, KafkaFuture<DescribeReplicaLogDirsResult.ReplicaLogDirInfo>>) - Constructor for class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult
 
DescribeReplicaLogDirsResult.ReplicaLogDirInfo - Class in org.apache.kafka.clients.admin
 
describeTopics(Collection<String>) - Method in class org.apache.kafka.clients.admin.AdminClient
Describe some topics in the cluster, with the default options.
describeTopics(Collection<String>, DescribeTopicsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
Describe some topics in the cluster.
describeTopics(Collection<String>, DescribeTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
DescribeTopicsOptions - Class in org.apache.kafka.clients.admin
DescribeTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeTopicsOptions
 
DescribeTopicsResult - Class in org.apache.kafka.clients.admin
DescribeTopicsResult(Map<String, KafkaFuture<TopicDescription>>) - Constructor for class org.apache.kafka.clients.admin.DescribeTopicsResult
 
description() - Method in class org.apache.kafka.common.MetricName
 
description() - Method in class org.apache.kafka.common.MetricNameTemplate
Get the description of the metric.
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ByteArrayDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ByteBufferDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.BytesDeserializer
 
deserialize(String, byte[]) - Method in interface org.apache.kafka.common.serialization.Deserializer
Deserialize a record value from a byte array into a value or object.
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.DoubleDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ExtendedDeserializer.Wrapper
Deprecated.
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.FloatDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.IntegerDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.LongDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ShortDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.StringDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.UUIDDeserializer
 
deserialize(String, Headers, byte[]) - Method in interface org.apache.kafka.common.serialization.Deserializer
Deserialize a record value from a byte array into a value or object.
deserialize(String, Headers, byte[]) - Method in interface org.apache.kafka.common.serialization.ExtendedDeserializer
Deprecated.
Deserialize a record value from a byte array into a value or object.
deserialize(String, Headers, byte[]) - Method in class org.apache.kafka.common.serialization.ExtendedDeserializer.Wrapper
Deprecated.
 
deserializer() - Method in interface org.apache.kafka.common.serialization.Serde
 
deserializer() - Method in class org.apache.kafka.common.serialization.Serdes.WrapperSerde
 
Deserializer<T> - Interface in org.apache.kafka.common.serialization
An interface for converting bytes to objects.
DisconnectException - Exception in org.apache.kafka.common.errors
Server disconnected before a request could be completed.
DisconnectException() - Constructor for exception org.apache.kafka.common.errors.DisconnectException
 
DisconnectException(String) - Constructor for exception org.apache.kafka.common.errors.DisconnectException
 
DisconnectException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.DisconnectException
 
DisconnectException(Throwable) - Constructor for exception org.apache.kafka.common.errors.DisconnectException
 
displayName - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
documentation - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
Double() - Static method in class org.apache.kafka.common.serialization.Serdes
 
DOUBLE - org.apache.kafka.common.config.ConfigDef.Type
 
DoubleDeserializer - Class in org.apache.kafka.common.serialization
 
DoubleDeserializer() - Constructor for class org.apache.kafka.common.serialization.DoubleDeserializer
 
DoubleSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.DoubleSerde
 
DoubleSerializer - Class in org.apache.kafka.common.serialization
 
DoubleSerializer() - Constructor for class org.apache.kafka.common.serialization.DoubleSerializer
 
DuplicateSequenceException - Exception in org.apache.kafka.common.errors
 
DuplicateSequenceException(String) - Constructor for exception org.apache.kafka.common.errors.DuplicateSequenceException
 
DYNAMIC_BROKER_CONFIG - org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
 
DYNAMIC_DEFAULT_BROKER_CONFIG - org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
 
DYNAMIC_TOPIC_CONFIG - org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
 

E

EARLIEST - org.apache.kafka.clients.consumer.OffsetResetStrategy
 
embed(String, String, int, ConfigDef) - Method in class org.apache.kafka.common.config.ConfigDef
 
empty() - Static method in class org.apache.kafka.clients.consumer.ConsumerRecords
 
empty() - Static method in class org.apache.kafka.common.Cluster
Create an empty cluster instance with no nodes and no topic-partitions.
EMPTY - org.apache.kafka.common.ConsumerGroupState
 
EMPTY - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecords
 
ENABLE_AUTO_COMMIT_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
enable.auto.commit
ENABLE_IDEMPOTENCE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
enable.idempotence
ENABLE_IDEMPOTENCE_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
 
endOffsets(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
endOffsets(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the end offsets for the given partitions.
endOffsets(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
endOffsets(Collection<TopicPartition>, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
endOffsets(Collection<TopicPartition>, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the end offsets for the given partitions.
endOffsets(Collection<TopicPartition>, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
ensureActiveGroup() - Method in interface org.apache.kafka.common.GenericCoordinator
 
ensureCoordinatorReady() - Method in interface org.apache.kafka.common.GenericCoordinator
 
ensureExtended(Deserializer<T>) - Static method in class org.apache.kafka.common.serialization.ExtendedDeserializer.Wrapper
Deprecated.
 
ensureExtended(Serializer<T>) - Static method in class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
Deprecated.
 
ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.CompositeValidator
 
ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.NonEmptyString
 
ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.NonEmptyStringWithoutControlChars
 
ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.NonNullValidator
 
ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.Range
 
ensureValid(String, Object) - Method in interface org.apache.kafka.common.config.ConfigDef.Validator
Perform single configuration validation.
ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.ValidList
 
ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.ValidString
 
entityType() - Method in interface org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntity
Returns the type of this entity.
entries() - Method in class org.apache.kafka.clients.admin.Config
Configuration entries for a resource.
entry() - Method in class org.apache.kafka.common.acl.AclBinding
 
entryFilter() - Method in class org.apache.kafka.common.acl.AclBindingFilter
 
equals(Object) - Method in class org.apache.kafka.clients.admin.Config
 
equals(Object) - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
 
equals(Object) - Method in class org.apache.kafka.clients.admin.ConfigEntry
 
equals(Object) - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
 
equals(Object) - Method in class org.apache.kafka.clients.admin.MemberAssignment
 
equals(Object) - Method in class org.apache.kafka.clients.admin.MemberDescription
 
equals(Object) - Method in class org.apache.kafka.clients.admin.RecordsToDelete
 
equals(Object) - Method in class org.apache.kafka.clients.admin.TopicDescription
 
equals(Object) - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
 
equals(Object) - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
 
equals(Object) - Method in class org.apache.kafka.clients.producer.ProducerRecord
 
equals(Object) - Method in class org.apache.kafka.common.acl.AccessControlEntry
 
equals(Object) - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
 
equals(Object) - Method in class org.apache.kafka.common.acl.AclBinding
 
equals(Object) - Method in class org.apache.kafka.common.acl.AclBindingFilter
 
equals(Object) - Method in class org.apache.kafka.common.config.AbstractConfig
 
equals(Object) - Method in class org.apache.kafka.common.config.ConfigResource
 
equals(Object) - Method in class org.apache.kafka.common.config.ConfigValue
 
equals(Object) - Method in class org.apache.kafka.common.MetricName
 
equals(Object) - Method in class org.apache.kafka.common.MetricNameTemplate
 
equals(Object) - Method in class org.apache.kafka.common.Node
 
equals(Object) - Method in class org.apache.kafka.common.resource.Resource
 
equals(Object) - Method in class org.apache.kafka.common.resource.ResourceFilter
 
equals(Object) - Method in class org.apache.kafka.common.resource.ResourcePattern
 
equals(Object) - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
equals(Object) - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
 
equals(Object) - Method in class org.apache.kafka.common.security.auth.SaslExtensions
 
equals(Object) - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
 
equals(Object) - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
equals(Object) - Method in class org.apache.kafka.common.TopicPartition
 
equals(Object) - Method in class org.apache.kafka.common.TopicPartitionInfo
 
equals(Object) - Method in class org.apache.kafka.common.TopicPartitionReplica
 
error(String, String) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
Set the error value for a specific extension key-value pair if validation has failed
error(String, String, String) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback
error(String, String, String) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
errorCode() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback
Return the optional (but always non-empty if not null) error code as per RFC 6749: The OAuth 2.0 Authorization Framework.
errorDescription() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback
Return the (potentially null) error description as per RFC 6749: The OAuth 2.0 Authorization Framework.
errorMessages() - Method in class org.apache.kafka.common.config.ConfigValue
 
errorNext(RuntimeException) - Method in class org.apache.kafka.clients.producer.MockProducer
Complete the earliest uncompleted call with the given error.
errorOpenIDConfiguration() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
Return the (potentially null) error openid-configuration value as per RFC 7628: A Set of Simple Authentication and Security Layer (SASL) Mechanisms for OAuth.
errors() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsResult
Returns a future which yields just the errors which occurred.
errorScope() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
errorStatus() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
errorUri() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback
Return the (potentially null) error URI as per RFC 6749: The OAuth 2.0 Authorization Framework.
exception() - Method in class org.apache.kafka.clients.admin.DeleteAclsResult.FilterResult
Return an exception if the ACL delete was not successful or null if it was.
EXCLUDE_INTERNAL_TOPICS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
exclude.internal.topics
expireDelegationToken(byte[]) - Method in class org.apache.kafka.clients.admin.AdminClient
Expire a Delegation Token.
expireDelegationToken(byte[], ExpireDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
Expire a Delegation Token.
expireDelegationToken(byte[], ExpireDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
ExpireDelegationTokenOptions - Class in org.apache.kafka.clients.admin
ExpireDelegationTokenOptions() - Constructor for class org.apache.kafka.clients.admin.ExpireDelegationTokenOptions
 
ExpireDelegationTokenResult - Class in org.apache.kafka.clients.admin
expiryTimePeriodMs() - Method in class org.apache.kafka.clients.admin.ExpireDelegationTokenOptions
 
expiryTimePeriodMs(long) - Method in class org.apache.kafka.clients.admin.ExpireDelegationTokenOptions
 
expiryTimestamp() - Method in class org.apache.kafka.clients.admin.ExpireDelegationTokenResult
Returns a future which yields expiry timestamp
expiryTimestamp() - Method in class org.apache.kafka.clients.admin.RenewDelegationTokenResult
Returns a future which yields expiry timestamp
expiryTimestamp() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
ExtendedDeserializer<T> - Interface in org.apache.kafka.common.serialization
Deprecated.
This class has been deprecated and will be removed in a future release. Please use Deserializer instead.
ExtendedDeserializer.Wrapper<T> - Class in org.apache.kafka.common.serialization
Deprecated.
 
ExtendedSerializer<T> - Interface in org.apache.kafka.common.serialization
Deprecated.
This class has been deprecated and will be removed in a future release. Please use Serializer instead.
ExtendedSerializer.Wrapper<T> - Class in org.apache.kafka.common.serialization
Deprecated.
 
extensions() - Method in class org.apache.kafka.common.security.auth.SaslExtensionsCallback
Returns always non-null SaslExtensions consisting of the extension names and values that are sent by the client to the server in the initial client SASL authentication message.
extensions() - Method in class org.apache.kafka.common.security.scram.ScramExtensionsCallback
Returns map of the extension names and values that are sent by the client to the server in the initial client SCRAM authentication message.
extensions(Map<String, String>) - Method in class org.apache.kafka.common.security.scram.ScramExtensionsCallback
Sets the SCRAM extensions on this callback.
extensions(SaslExtensions) - Method in class org.apache.kafka.common.security.auth.SaslExtensionsCallback
Sets the SASL extensions on this callback.

F

FencedLeaderEpochException - Exception in org.apache.kafka.common.errors
The request contained a leader epoch which is smaller than that on the broker that received the request.
FencedLeaderEpochException(String) - Constructor for exception org.apache.kafka.common.errors.FencedLeaderEpochException
 
FencedLeaderEpochException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.FencedLeaderEpochException
 
fenceProducer() - Method in class org.apache.kafka.clients.producer.MockProducer
 
fenceProducerOnClose() - Method in class org.apache.kafka.clients.producer.MockProducer
 
FETCH - org.apache.kafka.server.quota.ClientQuotaType
 
FETCH_MAX_BYTES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
fetch.max.bytes
FETCH_MAX_WAIT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
fetch.max.wait.ms
FETCH_MIN_BYTES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
fetch.min.bytes
FetchSessionIdNotFoundException - Exception in org.apache.kafka.common.errors
 
FetchSessionIdNotFoundException() - Constructor for exception org.apache.kafka.common.errors.FetchSessionIdNotFoundException
 
FetchSessionIdNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.FetchSessionIdNotFoundException
 
FILE_DELETE_DELAY_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
FILE_DELETE_DELAY_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
FileConfigProvider - Class in org.apache.kafka.common.config.provider
An implementation of ConfigProvider that represents a Properties file.
FileConfigProvider() - Constructor for class org.apache.kafka.common.config.provider.FileConfigProvider
 
fillInStackTrace() - Method in exception org.apache.kafka.common.errors.ApiException
 
fillInStackTrace() - Method in exception org.apache.kafka.common.errors.SerializationException
 
findIndefiniteField() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
Returns a string describing an ANY or UNKNOWN field, or null if there is no such field.
findIndefiniteField() - Method in class org.apache.kafka.common.acl.AclBindingFilter
Return a string describing an ANY or UNKNOWN field, or null if there is no such field.
findIndefiniteField() - Method in class org.apache.kafka.common.resource.ResourceFilter
Return a string describing an ANY or UNKNOWN field, or null if there is no such field.
findIndefiniteField() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
Float() - Static method in class org.apache.kafka.common.serialization.Serdes
 
FloatDeserializer - Class in org.apache.kafka.common.serialization
 
FloatDeserializer() - Constructor for class org.apache.kafka.common.serialization.FloatDeserializer
 
FloatSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.FloatSerde
 
FloatSerializer - Class in org.apache.kafka.common.serialization
 
FloatSerializer() - Constructor for class org.apache.kafka.common.serialization.FloatSerializer
 
flush() - Method in class org.apache.kafka.clients.producer.KafkaProducer
Invoking this method makes all buffered records immediately available to send (even if linger.ms is greater than 0) and blocks on the completion of the requests associated with these records.
flush() - Method in class org.apache.kafka.clients.producer.MockProducer
 
flush() - Method in interface org.apache.kafka.clients.producer.Producer
FLUSH_MESSAGES_INTERVAL_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
FLUSH_MESSAGES_INTERVAL_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
FLUSH_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
FLUSH_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
flushed() - Method in class org.apache.kafka.clients.producer.MockProducer
 
forId(byte) - Static method in enum org.apache.kafka.common.config.ConfigResource.Type
 
forId(short) - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
 
forName(String) - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
Case insensitive lookup by protocol name
fromCode(byte) - Static method in enum org.apache.kafka.common.acl.AclOperation
Return the AclOperation with the provided code or `AclOperation.UNKNOWN` if one cannot be found.
fromCode(byte) - Static method in enum org.apache.kafka.common.acl.AclPermissionType
Return the AclPermissionType with the provided code or `AclPermissionType.UNKNOWN` if one cannot be found.
fromCode(byte) - Static method in enum org.apache.kafka.common.resource.PatternType
Return the PatternType with the provided code or PatternType.UNKNOWN if one cannot be found.
fromCode(byte) - Static method in enum org.apache.kafka.common.resource.ResourceType
Return the ResourceType with the provided code or `ResourceType.UNKNOWN` if one cannot be found.
fromString(String) - Static method in enum org.apache.kafka.common.acl.AclOperation
Parse the given string as an ACL operation.
fromString(String) - Static method in enum org.apache.kafka.common.acl.AclPermissionType
Parse the given string as an ACL permission.
fromString(String) - Static method in enum org.apache.kafka.common.resource.PatternType
Return the PatternType with the provided name or PatternType.UNKNOWN if one cannot be found.
fromString(String) - Static method in enum org.apache.kafka.common.resource.ResourceType
Parse the given string as an ACL resource type.
fromString(String) - Static method in class org.apache.kafka.common.security.auth.KafkaPrincipal
Deprecated.
As of 1.0.0. This method will be removed in a future major release.
Function() - Constructor for class org.apache.kafka.common.KafkaFuture.Function
 

G

GenericCoordinator - Interface in org.apache.kafka.common
 
get() - Method in class org.apache.kafka.common.KafkaFuture
Waits if necessary for this future to complete, and then returns its result.
get(long, TimeUnit) - Method in class org.apache.kafka.common.KafkaFuture
Waits if necessary for at most the given time for this future to complete, and then returns its result, if available.
get(String) - Method in class org.apache.kafka.clients.admin.Config
Get the configuration entry with the provided name or null if there isn't one.
get(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
get(String) - Method in interface org.apache.kafka.common.config.provider.ConfigProvider
Retrieves the data at the given path.
get(String) - Method in class org.apache.kafka.common.config.provider.FileConfigProvider
Retrieves the data at the given Properties file.
get(String, Set<String>) - Method in interface org.apache.kafka.common.config.provider.ConfigProvider
Retrieves the data with the given keys at the given path.
get(String, Set<String>) - Method in class org.apache.kafka.common.config.provider.FileConfigProvider
Retrieves the data with the given keys at the given Properties file.
getBoolean(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getClass(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getConfiguredInstance(String, Class<T>) - Method in class org.apache.kafka.common.config.AbstractConfig
Get a configured instance of the give class specified by the given configuration key.
getConfiguredInstances(String, Class<T>) - Method in class org.apache.kafka.common.config.AbstractConfig
Get a list of configured instances of the given class specified by the given configuration key.
getConfiguredInstances(String, Class<T>, Map<String, Object>) - Method in class org.apache.kafka.common.config.AbstractConfig
Get a list of configured instances of the given class specified by the given configuration key.
getConfiguredInstances(List<String>, Class<T>, Map<String, Object>) - Method in class org.apache.kafka.common.config.AbstractConfig
Get a list of configured instances of the given class specified by the given configuration key.
getConfigValue(ConfigDef.ConfigKey, String) - Method in class org.apache.kafka.common.config.ConfigDef
 
getCurrentReplicaLogDir() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
 
getCurrentReplicaOffsetLag() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
 
getDouble(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getFutureReplicaLogDir() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
 
getFutureReplicaOffsetLag() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
 
getInt(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getList(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getLong(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getName() - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
 
getNow(T) - Method in class org.apache.kafka.common.KafkaFuture
Returns the result value (or throws any encountered exception) if completed, else returns the given valueIfAbsent.
getPassword(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getPrincipalType() - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
 
getShort(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getString(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
group - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
group() - Method in class org.apache.kafka.common.MetricName
 
group() - Method in class org.apache.kafka.common.MetricNameTemplate
Get the name of the group.
GROUP - org.apache.kafka.common.resource.ResourceType
A consumer group.
GROUP_ID_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
group.id
GroupAuthorizationException - Exception in org.apache.kafka.common.errors
 
GroupAuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.GroupAuthorizationException
 
groupId() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
The id of the consumer group.
groupId() - Method in class org.apache.kafka.clients.admin.ConsumerGroupListing
Consumer Group Id
groupId() - Method in exception org.apache.kafka.common.errors.GroupAuthorizationException
 
GroupIdNotFoundException - Exception in org.apache.kafka.common.errors
 
GroupIdNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.GroupIdNotFoundException
 
GroupNotEmptyException - Exception in org.apache.kafka.common.errors
 
GroupNotEmptyException(String) - Constructor for exception org.apache.kafka.common.errors.GroupNotEmptyException
 
groups() - Method in class org.apache.kafka.common.config.ConfigDef
Get the groups for the configuration
GSSAPI_MECHANISM - Static variable in class org.apache.kafka.common.config.SaslConfigs
 

H

hasDefault() - Method in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
hashCode() - Method in class org.apache.kafka.clients.admin.Config
 
hashCode() - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
 
hashCode() - Method in class org.apache.kafka.clients.admin.ConfigEntry
 
hashCode() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
 
hashCode() - Method in class org.apache.kafka.clients.admin.MemberAssignment
 
hashCode() - Method in class org.apache.kafka.clients.admin.MemberDescription
 
hashCode() - Method in class org.apache.kafka.clients.admin.RecordsToDelete
 
hashCode() - Method in class org.apache.kafka.clients.admin.TopicDescription
 
hashCode() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
 
hashCode() - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
 
hashCode() - Method in class org.apache.kafka.clients.producer.ProducerRecord
 
hashCode() - Method in class org.apache.kafka.common.acl.AccessControlEntry
 
hashCode() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
 
hashCode() - Method in class org.apache.kafka.common.acl.AclBinding
 
hashCode() - Method in class org.apache.kafka.common.acl.AclBindingFilter
 
hashCode() - Method in class org.apache.kafka.common.config.AbstractConfig
 
hashCode() - Method in class org.apache.kafka.common.config.ConfigResource
 
hashCode() - Method in class org.apache.kafka.common.config.ConfigValue
 
hashCode() - Method in class org.apache.kafka.common.MetricName
 
hashCode() - Method in class org.apache.kafka.common.MetricNameTemplate
 
hashCode() - Method in class org.apache.kafka.common.Node
 
hashCode() - Method in class org.apache.kafka.common.resource.Resource
 
hashCode() - Method in class org.apache.kafka.common.resource.ResourceFilter
 
hashCode() - Method in class org.apache.kafka.common.resource.ResourcePattern
 
hashCode() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
hashCode() - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
 
hashCode() - Method in class org.apache.kafka.common.security.auth.SaslExtensions
 
hashCode() - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
 
hashCode() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
hashCode() - Method in class org.apache.kafka.common.TopicPartition
 
hashCode() - Method in class org.apache.kafka.common.TopicPartitionInfo
 
hashCode() - Method in class org.apache.kafka.common.TopicPartitionReplica
 
hasOffset() - Method in class org.apache.kafka.clients.producer.RecordMetadata
Indicates whether the record metadata includes the offset.
hasRack() - Method in class org.apache.kafka.common.Node
True if this node has a defined rack
hasTimestamp() - Method in class org.apache.kafka.clients.producer.RecordMetadata
Indicates whether the record metadata includes the timestamp.
Header - Interface in org.apache.kafka.common.header
 
headers() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The headers
headers() - Method in class org.apache.kafka.clients.producer.ProducerRecord
 
headers() - Method in class org.apache.kafka.common.config.ConfigDef
 
headers(String) - Method in interface org.apache.kafka.common.header.Headers
Returns all headers for the given key, in the order they were added in, if present.
Headers - Interface in org.apache.kafka.common.header
 
HEARTBEAT_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
heartbeat.interval.ms
HIGH - org.apache.kafka.common.config.ConfigDef.Importance
 
history() - Method in class org.apache.kafka.clients.producer.MockProducer
Get the list of sent records since the last call to MockProducer.clear()
hmac() - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
 
hmacAsBase64String() - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
 
host() - Method in class org.apache.kafka.clients.admin.MemberDescription
The host where the group member is running.
host() - Method in class org.apache.kafka.common.acl.AccessControlEntry
Return the host or `*` for all hosts.
host() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
Return the host or null.
host() - Method in class org.apache.kafka.common.Node
The host name for this node

I

id - Variable in enum org.apache.kafka.common.security.auth.SecurityProtocol
The permanent and immutable id of a security protocol -- this can't change, and must match kafka.cluster.SecurityProtocol
id() - Method in enum org.apache.kafka.common.config.ConfigResource.Type
 
id() - Method in class org.apache.kafka.common.Node
The node id of this node
IDEMPOTENT_WRITE - org.apache.kafka.common.acl.AclOperation
IDEMPOTENT_WRITE operation.
idString() - Method in class org.apache.kafka.common.Node
String representation of the node id.
ignore(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
ignoredExtensions() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
 
IllegalGenerationException - Exception in org.apache.kafka.common.errors
 
IllegalGenerationException() - Constructor for exception org.apache.kafka.common.errors.IllegalGenerationException
 
IllegalGenerationException(String) - Constructor for exception org.apache.kafka.common.errors.IllegalGenerationException
 
IllegalGenerationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.IllegalGenerationException
 
IllegalGenerationException(Throwable) - Constructor for exception org.apache.kafka.common.errors.IllegalGenerationException
 
IllegalSaslStateException - Exception in org.apache.kafka.common.errors
This exception indicates unexpected requests prior to SASL authentication.
IllegalSaslStateException(String) - Constructor for exception org.apache.kafka.common.errors.IllegalSaslStateException
 
IllegalSaslStateException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.IllegalSaslStateException
 
importance - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
in(String...) - Static method in class org.apache.kafka.common.config.ConfigDef.ValidList
 
in(String...) - Static method in class org.apache.kafka.common.config.ConfigDef.ValidString
 
includeSynonyms() - Method in class org.apache.kafka.clients.admin.DescribeConfigsOptions
Return true if synonym configs should be returned in the response.
includeSynonyms(boolean) - Method in class org.apache.kafka.clients.admin.DescribeConfigsOptions
Set to true if synonym configs should be returned in the response.
InconsistentGroupProtocolException - Exception in org.apache.kafka.common.errors
 
InconsistentGroupProtocolException(String) - Constructor for exception org.apache.kafka.common.errors.InconsistentGroupProtocolException
 
InconsistentGroupProtocolException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InconsistentGroupProtocolException
 
increaseTo(int) - Static method in class org.apache.kafka.clients.admin.NewPartitions
Increase the partition count for a topic to the given totalCount.
increaseTo(int, List<List<Integer>>) - Static method in class org.apache.kafka.clients.admin.NewPartitions
Increase the partition count for a topic to the given totalCount assigning the new partitions according to the given newAssignments.
INDEX_INTERVAL_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
INDEX_INTERVAL_BYTES_DOCS - Static variable in class org.apache.kafka.common.config.TopicConfig
 
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
 
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.apache.kafka.common.security.plain.PlainLoginModule
 
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.apache.kafka.common.security.scram.ScramLoginModule
 
initTransactions() - Method in class org.apache.kafka.clients.producer.KafkaProducer
This API is not supported.
initTransactions() - Method in class org.apache.kafka.clients.producer.MockProducer
 
initTransactions() - Method in interface org.apache.kafka.clients.producer.Producer
inputExtensions() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
 
INSTANCE - Static variable in exception org.apache.kafka.common.errors.CoordinatorNotAvailableException
 
INSTANCE - Static variable in exception org.apache.kafka.common.errors.DisconnectException
 
inSyncReplicas() - Method in class org.apache.kafka.common.PartitionInfo
The subset of the replicas that are in sync, that is caught-up to the leader and ready to take over as leader if the leader should fail
INT - org.apache.kafka.common.config.ConfigDef.Type
 
Integer() - Static method in class org.apache.kafka.common.serialization.Serdes
 
IntegerDeserializer - Class in org.apache.kafka.common.serialization
 
IntegerDeserializer() - Constructor for class org.apache.kafka.common.serialization.IntegerDeserializer
 
IntegerSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.IntegerSerde
 
IntegerSerializer - Class in org.apache.kafka.common.serialization
 
IntegerSerializer() - Constructor for class org.apache.kafka.common.serialization.IntegerSerializer
 
INTERCEPTOR_CLASSES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
interceptor.classes
INTERCEPTOR_CLASSES_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
interceptor.classes
INTERCEPTOR_CLASSES_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
 
INTERCEPTOR_CLASSES_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
 
InterfaceStability - Class in org.apache.kafka.common.annotation
Annotation to inform users of how much to rely on a particular package, class or method not changing over time.
InterfaceStability() - Constructor for class org.apache.kafka.common.annotation.InterfaceStability
 
InterfaceStability.Evolving - Annotation Type in org.apache.kafka.common.annotation
Compatibility may be broken at minor release (i.e.
InterfaceStability.Stable - Annotation Type in org.apache.kafka.common.annotation
Compatibility is maintained in major, minor and patch releases with one exception: compatibility may be broken in a major release (i.e.
InterfaceStability.Unstable - Annotation Type in org.apache.kafka.common.annotation
No guarantee is provided as to reliability or stability across any level of release granularity.
internalConfig - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
internalTopics() - Method in class org.apache.kafka.common.Cluster
 
InterruptException - Exception in org.apache.kafka.common.errors
An unchecked wrapper for InterruptedException
InterruptException(InterruptedException) - Constructor for exception org.apache.kafka.common.errors.InterruptException
 
InterruptException(String) - Constructor for exception org.apache.kafka.common.errors.InterruptException
 
InterruptException(String, InterruptedException) - Constructor for exception org.apache.kafka.common.errors.InterruptException
 
InvalidCommitOffsetSizeException - Exception in org.apache.kafka.common.errors
 
InvalidCommitOffsetSizeException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidCommitOffsetSizeException
 
InvalidCommitOffsetSizeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidCommitOffsetSizeException
 
InvalidConfigurationException - Exception in org.apache.kafka.common.errors
 
InvalidConfigurationException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidConfigurationException
 
InvalidConfigurationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidConfigurationException
 
invalidExtensions() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
 
InvalidFetchSessionEpochException - Exception in org.apache.kafka.common.errors
 
InvalidFetchSessionEpochException() - Constructor for exception org.apache.kafka.common.errors.InvalidFetchSessionEpochException
 
InvalidFetchSessionEpochException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidFetchSessionEpochException
 
InvalidFetchSizeException - Exception in org.apache.kafka.common.errors
 
InvalidFetchSizeException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidFetchSizeException
 
InvalidFetchSizeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidFetchSizeException
 
InvalidGroupIdException - Exception in org.apache.kafka.common.errors
 
InvalidGroupIdException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidGroupIdException
 
InvalidGroupIdException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidGroupIdException
 
InvalidMetadataException - Exception in org.apache.kafka.common.errors
An exception that may indicate the client's metadata is out of date
InvalidMetadataException() - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
 
InvalidMetadataException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
 
InvalidMetadataException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
 
InvalidMetadataException(Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
 
InvalidOffsetException - Exception in org.apache.kafka.clients.consumer
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 - Exception in org.apache.kafka.common.errors
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(String) - Constructor for exception org.apache.kafka.clients.consumer.InvalidOffsetException
 
InvalidOffsetException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidOffsetException
 
InvalidOffsetException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidOffsetException
 
InvalidPartitionsException - Exception in org.apache.kafka.common.errors
 
InvalidPartitionsException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidPartitionsException
 
InvalidPartitionsException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidPartitionsException
 
InvalidPidMappingException - Exception in org.apache.kafka.common.errors
 
InvalidPidMappingException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidPidMappingException
 
InvalidPrincipalTypeException - Exception in org.apache.kafka.common.errors
 
InvalidPrincipalTypeException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidPrincipalTypeException
 
InvalidPrincipalTypeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidPrincipalTypeException
 
InvalidReplicaAssignmentException - Exception in org.apache.kafka.common.errors
 
InvalidReplicaAssignmentException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidReplicaAssignmentException
 
InvalidReplicaAssignmentException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidReplicaAssignmentException
 
InvalidReplicationFactorException - Exception in org.apache.kafka.common.errors
 
InvalidReplicationFactorException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidReplicationFactorException
 
InvalidReplicationFactorException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidReplicationFactorException
 
InvalidRequestException - Exception in org.apache.kafka.common.errors
Thrown when a request breaks basic wire protocol rules.
InvalidRequestException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidRequestException
 
InvalidRequestException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidRequestException
 
InvalidRequiredAcksException - Exception in org.apache.kafka.common.errors
 
InvalidRequiredAcksException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidRequiredAcksException
 
InvalidSessionTimeoutException - Exception in org.apache.kafka.common.errors
 
InvalidSessionTimeoutException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidSessionTimeoutException
 
InvalidSessionTimeoutException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidSessionTimeoutException
 
InvalidTimestampException - Exception in org.apache.kafka.common.errors
Indicate the timestamp of a record is invalid.
InvalidTimestampException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidTimestampException
 
InvalidTimestampException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidTimestampException
 
InvalidTopicException - Exception in org.apache.kafka.common.errors
The client has attempted to perform an operation on an invalid topic.
InvalidTopicException() - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
InvalidTopicException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
InvalidTopicException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
InvalidTopicException(Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
InvalidTopicException(Set<String>) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
invalidTopics() - Method in class org.apache.kafka.common.Cluster
 
invalidTopics() - Method in exception org.apache.kafka.common.errors.InvalidTopicException
 
InvalidTxnStateException - Exception in org.apache.kafka.common.errors
 
InvalidTxnStateException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidTxnStateException
 
InvalidTxnTimeoutException - Exception in org.apache.kafka.common.errors
The transaction coordinator returns this error code if the timeout received via the InitProducerIdRequest is larger than the `transaction.max.timeout.ms` config value.
InvalidTxnTimeoutException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidTxnTimeoutException
 
InvalidTxnTimeoutException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidTxnTimeoutException
 
isBootstrapConfigured() - Method in class org.apache.kafka.common.Cluster
 
isCancelled() - Method in class org.apache.kafka.common.KafkaFuture
Returns true if this CompletableFuture was cancelled before it completed normally.
isCompletedExceptionally() - Method in class org.apache.kafka.common.KafkaFuture
Returns true if this CompletableFuture completed exceptionally, in any way.
isDefault() - Method in class org.apache.kafka.clients.admin.ConfigEntry
Return whether the config value is the default or if it's been explicitly set.
isDefault() - Method in class org.apache.kafka.common.config.ConfigResource
Returns true if this is the default resource of a resource type.
isDone() - Method in class org.apache.kafka.common.KafkaFuture
Returns true if completed in any fashion: normally, exceptionally, or via cancellation.
isEmpty() - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
 
isEmpty() - Method in class org.apache.kafka.common.Node
Check whether this node is empty, which may be the case if noNode() is used as a placeholder in a response payload with an error.
isInternal() - Method in class org.apache.kafka.clients.admin.TopicDescription
Whether the topic is internal to Kafka.
isInternal() - Method in class org.apache.kafka.clients.admin.TopicListing
Whether the topic is internal to Kafka.
ISOLATION_LEVEL_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
isolation.level
ISOLATION_LEVEL_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
 
isr() - Method in class org.apache.kafka.common.TopicPartitionInfo
Return the in-sync replicas of the partition.
isReadOnly() - Method in class org.apache.kafka.clients.admin.ConfigEntry
Return whether the config is read-only and cannot be updated.
isSensitive() - Method in class org.apache.kafka.clients.admin.ConfigEntry
Return whether the config value is sensitive.
isSimpleConsumerGroup() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
If consumer group is simple or not.
isSimpleConsumerGroup() - Method in class org.apache.kafka.clients.admin.ConsumerGroupListing
If Consumer Group is simple or not.
isSpecific() - Method in enum org.apache.kafka.common.resource.PatternType
 
issueTimestamp() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
isUnknown() - Method in class org.apache.kafka.common.acl.AccessControlEntry
Return true if this AclResource has any UNKNOWN components.
isUnknown() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
Return true if there are any UNKNOWN components.
isUnknown() - Method in class org.apache.kafka.common.acl.AclBinding
 
isUnknown() - Method in class org.apache.kafka.common.acl.AclBindingFilter
 
isUnknown() - Method in enum org.apache.kafka.common.acl.AclOperation
Return true if this operation is UNKNOWN.
isUnknown() - Method in enum org.apache.kafka.common.acl.AclPermissionType
Return true if this permission type is UNKNOWN.
isUnknown() - Method in enum org.apache.kafka.common.resource.PatternType
 
isUnknown() - Method in class org.apache.kafka.common.resource.Resource
Return true if this Resource has any UNKNOWN components.
isUnknown() - Method in class org.apache.kafka.common.resource.ResourceFilter
Return true if this ResourceFilter has any UNKNOWN components.
isUnknown() - Method in class org.apache.kafka.common.resource.ResourcePattern
 
isUnknown() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
isUnknown() - Method in enum org.apache.kafka.common.resource.ResourceType
Return whether this resource type is UNKNOWN.
iterations() - Method in class org.apache.kafka.common.security.scram.ScramCredential
Number of iterations used to process this credential using the SCRAM algorithm.
iterator() - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
 

K

KafkaAdminClient - Class in org.apache.kafka.clients.admin
The default implementation of AdminClient.
KafkaConsumer<K,​V> - Class in org.apache.kafka.clients.consumer
A client that consumes records from a Kafka cluster.
KafkaConsumer(Map<String, Object>) - Constructor for class org.apache.kafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a set of key-value pairs as configuration.
KafkaConsumer(Map<String, Object>, Deserializer<K>, Deserializer<V>) - Constructor for class org.apache.kafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a set of key-value pairs as configuration, and a key and a value Deserializer.
KafkaConsumer(Properties) - Constructor for class org.apache.kafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a Properties object as configuration.
KafkaConsumer(Properties, Deserializer<K>, Deserializer<V>) - Constructor for class org.apache.kafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a Properties object as configuration, and a key and a value Deserializer.
KafkaException - Exception in org.apache.kafka.common
The base class of all other Kafka exceptions
KafkaException() - Constructor for exception org.apache.kafka.common.KafkaException
 
KafkaException(String) - Constructor for exception org.apache.kafka.common.KafkaException
 
KafkaException(String, Throwable) - Constructor for exception org.apache.kafka.common.KafkaException
 
KafkaException(Throwable) - Constructor for exception org.apache.kafka.common.KafkaException
 
KafkaFuture<T> - Class in org.apache.kafka.common
A flexible future which supports call chaining and other asynchronous programming patterns.
KafkaFuture() - Constructor for class org.apache.kafka.common.KafkaFuture
 
KafkaFuture.BaseFunction<A,​B> - Interface in org.apache.kafka.common
A function which takes objects of type A and returns objects of type B.
KafkaFuture.BiConsumer<A,​B> - Interface in org.apache.kafka.common
A consumer of two different types of object.
KafkaFuture.Function<A,​B> - Class in org.apache.kafka.common
A function which takes objects of type A and returns objects of type B.
KafkaPrincipal - Class in org.apache.kafka.common.security.auth
Principals in Kafka are defined by a type and a name.
KafkaPrincipal(String, String) - Constructor for class org.apache.kafka.common.security.auth.KafkaPrincipal
 
KafkaPrincipalBuilder - Interface in org.apache.kafka.common.security.auth
Pluggable principal builder interface which supports both SSL authentication through SslAuthenticationContext and SASL through SaslAuthenticationContext.
KafkaProducer<K,​V> - Class in org.apache.kafka.clients.producer
A Kafka client that publishes records to the Kafka cluster.
KafkaProducer(Map<String, Object>) - Constructor for class org.apache.kafka.clients.producer.KafkaProducer
A producer is instantiated by providing a set of key-value pairs as configuration.
KafkaProducer(Map<String, Object>, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.KafkaProducer
A producer is instantiated by providing a set of key-value pairs as configuration, a key and a value Serializer.
KafkaProducer(Properties) - Constructor for class org.apache.kafka.clients.producer.KafkaProducer
A producer is instantiated by providing a set of key-value pairs as configuration.
KafkaProducer(Properties, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.KafkaProducer
A producer is instantiated by providing a set of key-value pairs as configuration, a key and a value Serializer.
KafkaStorageException - Exception in org.apache.kafka.common.errors
Miscellaneous disk-related IOException occurred when handling a request.
KafkaStorageException() - Constructor for exception org.apache.kafka.common.errors.KafkaStorageException
 
KafkaStorageException(String) - Constructor for exception org.apache.kafka.common.errors.KafkaStorageException
 
KafkaStorageException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.KafkaStorageException
 
KafkaStorageException(Throwable) - Constructor for exception org.apache.kafka.common.errors.KafkaStorageException
 
key() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The key (or null if no key is specified)
key() - Method in class org.apache.kafka.clients.producer.ProducerRecord
 
key() - Method in interface org.apache.kafka.common.header.Header
 
KEY_DESERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
key.deserializer
KEY_DESERIALIZER_CLASS_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
 
KEY_SERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
key.serializer
KEY_SERIALIZER_CLASS_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
 

L

lastHeader(String) - Method in interface org.apache.kafka.common.header.Headers
Returns just one (the very last) header for the given key, if present.
LATEST - org.apache.kafka.clients.consumer.OffsetResetStrategy
 
leader() - Method in class org.apache.kafka.common.PartitionInfo
The node id of the node currently acting as a leader for this partition or null if there is no leader
leader() - Method in class org.apache.kafka.common.TopicPartitionInfo
Return the leader of the partition or null if there is none.
leaderEpoch() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
Get the leader epoch for the record if available
leaderEpoch() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
Get the leader epoch of the previously consumed record (if one is known).
leaderEpoch() - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
Get the leader epoch corresponding to the offset that was found (if one exists).
leaderFor(TopicPartition) - Method in class org.apache.kafka.common.Cluster
Get the current leader for the given topic-partition
LeaderNotAvailableException - Exception in org.apache.kafka.common.errors
There is no currently available leader for the given partition (either because a leadership election is in progress or because all replicas are down).
LeaderNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.LeaderNotAvailableException
 
LeaderNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.LeaderNotAvailableException
 
lifetimeMs() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
The token's lifetime, expressed as the number of milliseconds since the epoch, as per RFC 6749 Section 1.4
LINGER_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
linger.ms
LIST - org.apache.kafka.common.config.ConfigDef.Type
 
listConsumerGroupOffsets(String) - Method in class org.apache.kafka.clients.admin.AdminClient
List the consumer group offsets available in the cluster with the default options.
listConsumerGroupOffsets(String, ListConsumerGroupOffsetsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
List the consumer group offsets available in the cluster.
listConsumerGroupOffsets(String, ListConsumerGroupOffsetsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
ListConsumerGroupOffsetsOptions - Class in org.apache.kafka.clients.admin
ListConsumerGroupOffsetsOptions() - Constructor for class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsOptions
 
ListConsumerGroupOffsetsResult - Class in org.apache.kafka.clients.admin
listConsumerGroups() - Method in class org.apache.kafka.clients.admin.AdminClient
List the consumer groups available in the cluster with the default options.
listConsumerGroups(ListConsumerGroupsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
List the consumer groups available in the cluster.
listConsumerGroups(ListConsumerGroupsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
ListConsumerGroupsOptions - Class in org.apache.kafka.clients.admin
ListConsumerGroupsOptions() - Constructor for class org.apache.kafka.clients.admin.ListConsumerGroupsOptions
 
ListConsumerGroupsResult - Class in org.apache.kafka.clients.admin
The result of the AdminClient.listConsumerGroups() call.
listenerName() - Method in interface org.apache.kafka.common.security.auth.AuthenticationContext
Name of the listener used for the connection
listenerName() - Method in class org.apache.kafka.common.security.auth.PlaintextAuthenticationContext
 
listenerName() - Method in class org.apache.kafka.common.security.auth.SaslAuthenticationContext
 
listenerName() - Method in class org.apache.kafka.common.security.auth.SslAuthenticationContext
 
ListenerNotFoundException - Exception in org.apache.kafka.common.errors
The leader does not have an endpoint corresponding to the listener on which metadata was requested.
ListenerNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.ListenerNotFoundException
 
ListenerNotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ListenerNotFoundException
 
listings() - Method in class org.apache.kafka.clients.admin.ListTopicsResult
Return a future which yields a collection of TopicListing objects.
listInternal(boolean) - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
Set whether we should list internal topics.
listTopics() - Method in class org.apache.kafka.clients.admin.AdminClient
List the topics available in the default stream with the default options.
listTopics() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
listTopics() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get metadata about partitions for all topics that the user is authorized to view.
listTopics() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
listTopics(String) - Method in class org.apache.kafka.clients.admin.AdminClient
List the topics available in the specified stream with the default options.
listTopics(String) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
listTopics(String) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get metadata about partitions for all topics of the stream.
listTopics(String) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
listTopics(String, ListTopicsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
List the topics available in the specified stream.
listTopics(String, ListTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
listTopics(Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
listTopics(Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get metadata about partitions for all topics that the user is authorized to view.
listTopics(Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
listTopics(Pattern) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
listTopics(Pattern) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get metadata about partitions for all topics of the stream that matches the pattern.
listTopics(Pattern) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
listTopics(ListTopicsOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
List the topics available in the default stream.
listTopics(ListTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
ListTopicsOptions - Class in org.apache.kafka.clients.admin
ListTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.ListTopicsOptions
 
ListTopicsResult - Class in org.apache.kafka.clients.admin
The result of the AdminClient.listTopics() call.
ListTopicsResult(KafkaFuture<Map<String, TopicListing>>) - Constructor for class org.apache.kafka.clients.admin.ListTopicsResult
 
LITERAL - org.apache.kafka.common.resource.PatternType
A literal resource name.
LogDirNotFoundException - Exception in org.apache.kafka.common.errors
Thrown when a request is made for a log directory that is not present on the broker
LogDirNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.LogDirNotFoundException
 
LogDirNotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.LogDirNotFoundException
 
LogDirNotFoundException(Throwable) - Constructor for exception org.apache.kafka.common.errors.LogDirNotFoundException
 
login() - Method in interface org.apache.kafka.common.security.auth.Login
Performs login for each login module specified for the login context of this instance.
login() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
 
login() - Method in class org.apache.kafka.common.security.plain.PlainLoginModule
 
login() - Method in class org.apache.kafka.common.security.scram.ScramLoginModule
 
Login - Interface in org.apache.kafka.common.security.auth
Login interface for authentication.
logout() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
 
logout() - Method in class org.apache.kafka.common.security.plain.PlainLoginModule
 
logout() - Method in class org.apache.kafka.common.security.scram.ScramLoginModule
 
logUnused() - Method in class org.apache.kafka.common.config.AbstractConfig
Log warnings for any unused configurations
Long() - Static method in class org.apache.kafka.common.serialization.Serdes
 
LONG - org.apache.kafka.common.config.ConfigDef.Type
 
LONG - org.apache.kafka.common.config.ConfigDef.Width
 
LongDeserializer - Class in org.apache.kafka.common.serialization
 
LongDeserializer() - Constructor for class org.apache.kafka.common.serialization.LongDeserializer
 
LongSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.LongSerde
 
LongSerializer - Class in org.apache.kafka.common.serialization
 
LongSerializer() - Constructor for class org.apache.kafka.common.serialization.LongSerializer
 
LOW - org.apache.kafka.common.config.ConfigDef.Importance
 
lowWatermark() - Method in class org.apache.kafka.clients.admin.DeletedRecords
Return the "low watermark" for the topic partition on which the deletion was executed
lowWatermarks() - Method in class org.apache.kafka.clients.admin.DeleteRecordsResult
Return a map from topic partition to futures which can be used to check the status of individual deletions.

M

main(String[]) - Static method in class org.apache.kafka.clients.admin.AdminClientConfig
 
main(String[]) - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
 
main(String[]) - Static method in class org.apache.kafka.clients.producer.ProducerConfig
 
map() - Method in class org.apache.kafka.common.security.auth.SaslExtensions
Returns an immutable map of the extension names and their values
MATCH - org.apache.kafka.common.resource.PatternType
In a filter, will perform pattern matching.
matches(AccessControlEntry) - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
Returns true if this filter matches the given AccessControlEntry.
matches(AclBinding) - Method in class org.apache.kafka.common.acl.AclBindingFilter
Return true if the resource filter matches the binding's resource and the entry filter matches binding's entry.
matches(Resource) - Method in class org.apache.kafka.common.resource.ResourceFilter
Return true if this filter matches the given Resource.
matches(ResourcePattern) - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
matchesAtMostOne() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
Returns true if this filter could only match one ACE -- in other words, if there are no ANY or UNKNOWN fields.
matchesAtMostOne() - Method in class org.apache.kafka.common.acl.AclBindingFilter
Return true if the resource and entry filters can only match one ACE.
matchesAtMostOne() - Method in class org.apache.kafka.common.resource.ResourceFilter
Return true if this filter could only match one ACE.
matchesAtMostOne() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
MAX_BLOCK_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
max.block.ms
MAX_IN_FLIGHT_REQUESTS_PER_CONNECTION - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
max.in.flight.requests.per.connection
MAX_MESSAGE_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MAX_MESSAGE_BYTES_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MAX_PARTITION_FETCH_BYTES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
max.partition.fetch.bytes
MAX_POLL_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
max.poll.interval.ms
MAX_POLL_RECORDS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
max.poll.records
MAX_REQUEST_SIZE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
max.request.size
maxlifeTimeMs() - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
 
maxlifeTimeMs(long) - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
 
maxTimestamp() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
maybeLeaveGroup() - Method in interface org.apache.kafka.common.GenericCoordinator
 
MEDIUM - org.apache.kafka.common.config.ConfigDef.Importance
 
MEDIUM - org.apache.kafka.common.config.ConfigDef.Width
 
MemberAssignment - Class in org.apache.kafka.clients.admin
A description of the assignments of a specific group member.
MemberAssignment(Set<TopicPartition>) - Constructor for class org.apache.kafka.clients.admin.MemberAssignment
Creates an instance with the specified parameters.
MemberDescription - Class in org.apache.kafka.clients.admin
A detailed description of a single group instance in the cluster.
MemberDescription(String, String, String, MemberAssignment) - Constructor for class org.apache.kafka.clients.admin.MemberDescription
 
memberId() - Method in interface org.apache.kafka.common.GenericCoordinator
 
members() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
A list of the members of the consumer group.
MESSAGE_DOWNCONVERSION_ENABLE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MESSAGE_DOWNCONVERSION_ENABLE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MESSAGE_FORMAT_VERSION_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MESSAGE_FORMAT_VERSION_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MESSAGE_TIMESTAMP_DIFFERENCE_MAX_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MESSAGE_TIMESTAMP_DIFFERENCE_MAX_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MESSAGE_TIMESTAMP_TYPE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MESSAGE_TIMESTAMP_TYPE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
metadata() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
 
METADATA_MAX_AGE_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
 
METADATA_MAX_AGE_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
metadata.max.age.ms
METADATA_MAX_AGE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
metadata.max.age.ms
Metric - Interface in org.apache.kafka.common
A metric tracked for monitoring purposes.
METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
 
METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
metric.reporters
METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
metric.reporters
metricName() - Method in interface org.apache.kafka.common.Metric
A name for this metric
MetricName - Class in org.apache.kafka.common
The MetricName class encapsulates a metric's name, logical group and its related attributes.
MetricName(String, String, String, Map<String, String>) - Constructor for class org.apache.kafka.common.MetricName
Please create MetricName by method Metrics.metricName(String, String, String, Map)
MetricNameTemplate - Class in org.apache.kafka.common
A template for a MetricName.
MetricNameTemplate(String, String, String, String...) - Constructor for class org.apache.kafka.common.MetricNameTemplate
Create a new template.
MetricNameTemplate(String, String, String, Set<String>) - Constructor for class org.apache.kafka.common.MetricNameTemplate
Create a new template.
metrics() - Method in class org.apache.kafka.clients.admin.AdminClient
Get the metrics kept by the adminClient
metrics() - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
metrics() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
metrics() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
This API is not supported.
metrics() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
metrics() - Method in class org.apache.kafka.clients.producer.KafkaProducer
This API is not supported.
metrics() - Method in class org.apache.kafka.clients.producer.MockProducer
 
metrics() - Method in interface org.apache.kafka.clients.producer.Producer
METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
 
METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
metrics.num.samples
METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
metrics.num.samples
METRICS_RECORDING_LEVEL_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
 
METRICS_RECORDING_LEVEL_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
metrics.log.level
METRICS_RECORDING_LEVEL_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
metrics.recording.level
METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
 
METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
metrics.sample.window.ms
METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
metrics.sample.window.ms
metricValue() - Method in interface org.apache.kafka.common.Metric
The value of the metric, which may be measurable or a non-measurable gauge
MIN_CLEANABLE_DIRTY_RATIO_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MIN_CLEANABLE_DIRTY_RATIO_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MIN_COMPACTION_LAG_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MIN_COMPACTION_LAG_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MIN_IN_SYNC_REPLICAS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MIN_IN_SYNC_REPLICAS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MockConsumer<K,​V> - Class in org.apache.kafka.clients.consumer
This class is not supported.
MockConsumer(OffsetResetStrategy) - Constructor for class org.apache.kafka.clients.consumer.MockConsumer
 
MockProducer<K,​V> - Class in org.apache.kafka.clients.producer
This class is not supported.
MockProducer() - Constructor for class org.apache.kafka.clients.producer.MockProducer
Create a new mock producer with invented metadata.
MockProducer(boolean, Partitioner, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.MockProducer
Create a new mock producer with invented metadata the given autoComplete setting, partitioner and key\value serializers.
MockProducer(boolean, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.MockProducer
Create a new mock producer with invented metadata the given autoComplete setting and key\value serializers.
MockProducer(Cluster, boolean, Partitioner, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.MockProducer
Create a mock producer

N

name - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
name - Variable in enum org.apache.kafka.common.security.auth.SecurityProtocol
Name of the security protocol.
name() - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
Returns the name of this configuration.
name() - Method in class org.apache.kafka.clients.admin.ConfigEntry
Return the config name.
name() - Method in class org.apache.kafka.clients.admin.NewTopic
The name of the topic to be created.
name() - Method in class org.apache.kafka.clients.admin.TopicDescription
The name of the topic.
name() - Method in class org.apache.kafka.clients.admin.TopicListing
The name of the topic.
name() - Method in class org.apache.kafka.clients.consumer.RangeAssignor
 
name() - Method in class org.apache.kafka.clients.consumer.RoundRobinAssignor
 
name() - Method in class org.apache.kafka.clients.consumer.StickyAssignor
 
name() - Method in class org.apache.kafka.common.config.ConfigResource
Return the resource name.
name() - Method in class org.apache.kafka.common.config.ConfigValue
 
name() - Method in class org.apache.kafka.common.MetricName
 
name() - Method in class org.apache.kafka.common.MetricNameTemplate
Get the name of the metric.
name() - Method in class org.apache.kafka.common.resource.Resource
Return the resource name.
name() - Method in class org.apache.kafka.common.resource.ResourceFilter
Return the resource name or null.
name() - Method in class org.apache.kafka.common.resource.ResourcePattern
 
name() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
name() - Method in interface org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntity
Returns the name of this entity.
names() - Method in class org.apache.kafka.clients.admin.ListTopicsResult
Return a future which yields a collection of topic names.
names() - Method in class org.apache.kafka.common.config.ConfigDef
Returns unmodifiable set of properties names defined in this ConfigDef
names() - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
 
namesToListings() - Method in class org.apache.kafka.clients.admin.ListTopicsResult
Return a future which yields a map of topic names to TopicListing objects.
NETWORK_THREAD_PREFIX - Static variable in class org.apache.kafka.clients.producer.KafkaProducer
 
NetworkException - Exception in org.apache.kafka.common.errors
A misc.
NetworkException() - Constructor for exception org.apache.kafka.common.errors.NetworkException
 
NetworkException(String) - Constructor for exception org.apache.kafka.common.errors.NetworkException
 
NetworkException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NetworkException
 
NetworkException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NetworkException
 
NewPartitions - Class in org.apache.kafka.clients.admin
Describes new partitions for a particular topic in a call to AdminClient.createPartitions(Map).
NewTopic - Class in org.apache.kafka.clients.admin
A new topic to be created via AdminClient.createTopics(Collection).
NewTopic(String, int, short) - Constructor for class org.apache.kafka.clients.admin.NewTopic
A new topic with the specified replication factor and number of partitions.
NewTopic(String, Map<Integer, List<Integer>>) - Constructor for class org.apache.kafka.clients.admin.NewTopic
A new topic with the specified replica assignment configuration.
NO_DEFAULT_VALUE - Static variable in class org.apache.kafka.common.config.ConfigDef
A unique Java object which represents the lack of a default value.
NO_SASL_EXTENSIONS - Static variable in class org.apache.kafka.common.security.auth.SaslExtensions
An "empty" instance indicating no SASL extensions
NO_TIMESTAMP - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecord
 
Node - Class in org.apache.kafka.common
Information about a Kafka node
Node(int, String, int) - Constructor for class org.apache.kafka.common.Node
 
Node(int, String, int, String) - Constructor for class org.apache.kafka.common.Node
 
nodeById(int) - Method in class org.apache.kafka.common.Cluster
Get the node by the node id (or null if no such node exists)
nodes() - Method in class org.apache.kafka.clients.admin.DescribeClusterResult
Returns a future which yields a collection of nodes.
nodes() - Method in class org.apache.kafka.common.Cluster
 
NONE - org.apache.kafka.clients.consumer.OffsetResetStrategy
 
NONE - org.apache.kafka.common.config.ConfigDef.Width
 
NonEmptyString() - Constructor for class org.apache.kafka.common.config.ConfigDef.NonEmptyString
 
nonEmptyStringWithoutControlChars() - Static method in class org.apache.kafka.common.config.ConfigDef.NonEmptyStringWithoutControlChars
 
NonEmptyStringWithoutControlChars() - Constructor for class org.apache.kafka.common.config.ConfigDef.NonEmptyStringWithoutControlChars
 
NonNullValidator() - Constructor for class org.apache.kafka.common.config.ConfigDef.NonNullValidator
 
noNode() - Static method in class org.apache.kafka.common.Node
 
NoOffsetForPartitionException - Exception in org.apache.kafka.clients.consumer
Indicates that there is no stored offset for a partition and no defined offset reset policy.
NoOffsetForPartitionException(Collection<TopicPartition>) - Constructor for exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
 
NoOffsetForPartitionException(TopicPartition) - Constructor for exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
 
NotControllerException - Exception in org.apache.kafka.common.errors
 
NotControllerException(String) - Constructor for exception org.apache.kafka.common.errors.NotControllerException
 
NotControllerException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotControllerException
 
NotCoordinatorException - Exception in org.apache.kafka.common.errors
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.
NotCoordinatorException(String) - Constructor for exception org.apache.kafka.common.errors.NotCoordinatorException
 
NotCoordinatorException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotCoordinatorException
 
NotEnoughReplicasAfterAppendException - Exception in org.apache.kafka.common.errors
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.
NotEnoughReplicasAfterAppendException(String) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasAfterAppendException
 
NotEnoughReplicasException - Exception in org.apache.kafka.common.errors
Number of insync replicas for the partition is lower than min.insync.replicas
NotEnoughReplicasException() - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
 
NotEnoughReplicasException(String) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
 
NotEnoughReplicasException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
 
NotEnoughReplicasException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
 
NotLeaderForPartitionException - Exception in org.apache.kafka.common.errors
This server is not the leader for the given partition
NotLeaderForPartitionException() - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
 
NotLeaderForPartitionException(String) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
 
NotLeaderForPartitionException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
 
NotLeaderForPartitionException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
 
NULL_CHECKSUM - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecord
 
NULL_SIZE - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecord
 
numPartitions() - Method in class org.apache.kafka.clients.admin.NewTopic
The number of partitions for the new topic or -1 if a replica assignment has been specified.
numPartitions() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
Return the number of partitions to create or null if replicaAssignments is not null.

O

OAUTHBEARER_MECHANISM - Static variable in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
The SASL Mechanism name for OAuth 2: OAUTHBEARER
OAuthBearerExtensionsValidatorCallback - Class in org.apache.kafka.common.security.oauthbearer
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.
OAuthBearerExtensionsValidatorCallback(OAuthBearerToken, SaslExtensions) - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
 
OAuthBearerLoginModule - Class in org.apache.kafka.common.security.oauthbearer
The LoginModule for the SASL/OAUTHBEARER mechanism.
OAuthBearerLoginModule() - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
 
OAuthBearerToken - Interface in org.apache.kafka.common.security.oauthbearer
The b64token value as defined in RFC 6750 Section 2.1 along with the token's specific scope and lifetime and principal name.
OAuthBearerTokenCallback - Class in org.apache.kafka.common.security.oauthbearer
A Callback for use by the SaslClient and Login implementations when they require an OAuth 2 bearer token.
OAuthBearerTokenCallback() - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback
 
OAuthBearerValidatorCallback - Class in org.apache.kafka.common.security.oauthbearer
A Callback for use by the SaslServer implementation when it needs to provide an OAuth 2 bearer token compact serialization for validation.
OAuthBearerValidatorCallback(String) - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
Constructor
of(ConfigDef.Validator...) - Static method in class org.apache.kafka.common.config.ConfigDef.CompositeValidator
 
offlineReplicas() - Method in class org.apache.kafka.common.PartitionInfo
The subset of the replicas that are offline
offset() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The position of this record in the corresponding Kafka partition.
offset() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
 
offset() - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
 
offset() - Method in class org.apache.kafka.clients.producer.RecordMetadata
The offset of the record in the topic/partition.
OffsetAndMetadata - Class in org.apache.kafka.clients.consumer
The Kafka offset commit API allows users to provide additional metadata (in the form of a string) when an offset is committed.
OffsetAndMetadata(long) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndMetadata
Construct a new OffsetAndMetadata object for committing through KafkaConsumer.
OffsetAndMetadata(long, String) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndMetadata
Construct a new OffsetAndMetadata object for committing through KafkaConsumer.
OffsetAndMetadata(long, Optional<Integer>, String) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndMetadata
Construct a new OffsetAndMetadata object for committing through KafkaConsumer.
OffsetAndTimestamp - Class in org.apache.kafka.clients.consumer
A container class for offset and timestamp.
OffsetAndTimestamp(long, long) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndTimestamp
 
OffsetAndTimestamp(long, long, Optional<Integer>) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndTimestamp
 
OffsetCommitCallback - Interface in org.apache.kafka.clients.consumer
A callback interface that the user can implement to trigger custom actions when a commit request completes.
OffsetMetadataTooLarge - Exception in org.apache.kafka.common.errors
The client has tried to save its offset with associated metadata larger than the maximum size allowed by the server.
OffsetMetadataTooLarge() - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
 
OffsetMetadataTooLarge(String) - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
 
OffsetMetadataTooLarge(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
 
OffsetMetadataTooLarge(Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
 
OffsetOutOfRangeException - Exception in org.apache.kafka.clients.consumer
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 - Exception in org.apache.kafka.common.errors
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(String) - Constructor for exception org.apache.kafka.common.errors.OffsetOutOfRangeException
 
OffsetOutOfRangeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetOutOfRangeException
 
OffsetOutOfRangeException(Map<TopicPartition, Long>) - Constructor for exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
 
offsetOutOfRangePartitions() - Method in exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
 
OffsetResetStrategy - Enum in org.apache.kafka.clients.consumer
 
offsetsForTimes(Map<TopicPartition, Long>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
offsetsForTimes(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Look up the offsets for the given partitions by timestamp.
offsetsForTimes(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
offsetsForTimes(Map<TopicPartition, Long>, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
offsetsForTimes(Map<TopicPartition, Long>, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Look up the offsets for the given partitions by timestamp.
offsetsForTimes(Map<TopicPartition, Long>, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
onAcknowledgement(RecordMetadata, Exception) - Method in interface org.apache.kafka.clients.producer.ProducerInterceptor
This method is called when the record sent to the server has been acknowledged, or when sending the record fails before it gets sent to the server.
onAssignment(PartitionAssignor.Assignment) - Method in class org.apache.kafka.clients.consumer.StickyAssignor
 
onChange(String, ConfigData) - Method in interface org.apache.kafka.common.config.ConfigChangeCallback
Performs an action when configuration data changes.
onCommit(Map<TopicPartition, OffsetAndMetadata>) - Method in interface org.apache.kafka.clients.consumer.ConsumerInterceptor
This is called when offsets get committed.
onComplete(Map<TopicPartition, OffsetAndMetadata>, Exception) - Method in interface org.apache.kafka.clients.consumer.OffsetCommitCallback
A callback method the user can implement to provide asynchronous handling of commit request completion.
onCompletion(RecordMetadata, Exception) - Method in interface org.apache.kafka.clients.producer.Callback
A callback method the user can implement to provide asynchronous handling of request completion.
onConsume(ConsumerRecords<K, V>) - Method in interface org.apache.kafka.clients.consumer.ConsumerInterceptor
This is called just before the records are returned by KafkaConsumer.poll(java.time.Duration)
onPartitionsAssigned(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.ConsumerRebalanceListener
A callback method the user can implement to provide handling of customized offsets on completion of a successful partition re-assignment.
onPartitionsRevoked(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.ConsumerRebalanceListener
A callback method the user can implement to provide handling of offset commits to a customized store on the start of a rebalance operation.
onSend(ProducerRecord<K, V>) - Method in interface org.apache.kafka.clients.producer.ProducerInterceptor
This is called from KafkaProducer.send(ProducerRecord) and KafkaProducer.send(ProducerRecord, Callback) methods, before key and value get serialized and partition is assigned (if partition is not specified in ProducerRecord).
onUpdate(ClusterResource) - Method in interface org.apache.kafka.common.ClusterResourceListener
A callback method that a user can implement to get updates for ClusterResource.
operation() - Method in class org.apache.kafka.common.acl.AccessControlEntry
Return the AclOperation.
operation() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
Return the AclOperation.
OperationNotAttemptedException - Exception in org.apache.kafka.common.errors
Indicates that the broker did not attempt to execute this operation.
OperationNotAttemptedException(String) - Constructor for exception org.apache.kafka.common.errors.OperationNotAttemptedException
 
orderInGroup - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
org.apache.kafka.clients.admin - package org.apache.kafka.clients.admin
 
org.apache.kafka.clients.consumer - package org.apache.kafka.clients.consumer
 
org.apache.kafka.clients.producer - package org.apache.kafka.clients.producer
 
org.apache.kafka.common - package org.apache.kafka.common
 
org.apache.kafka.common.acl - package org.apache.kafka.common.acl
 
org.apache.kafka.common.annotation - package org.apache.kafka.common.annotation
 
org.apache.kafka.common.config - package org.apache.kafka.common.config
 
org.apache.kafka.common.config.provider - package org.apache.kafka.common.config.provider
 
org.apache.kafka.common.errors - package org.apache.kafka.common.errors
 
org.apache.kafka.common.header - package org.apache.kafka.common.header
 
org.apache.kafka.common.resource - package org.apache.kafka.common.resource
 
org.apache.kafka.common.security.auth - package org.apache.kafka.common.security.auth
 
org.apache.kafka.common.security.oauthbearer - package org.apache.kafka.common.security.oauthbearer
 
org.apache.kafka.common.security.plain - package org.apache.kafka.common.security.plain
 
org.apache.kafka.common.security.scram - package org.apache.kafka.common.security.scram
 
org.apache.kafka.common.security.token.delegation - package org.apache.kafka.common.security.token.delegation
 
org.apache.kafka.common.serialization - package org.apache.kafka.common.serialization
 
org.apache.kafka.server.policy - package org.apache.kafka.server.policy
 
org.apache.kafka.server.quota - package org.apache.kafka.server.quota
 
originals() - Method in class org.apache.kafka.common.config.AbstractConfig
 
originalsStrings() - Method in class org.apache.kafka.common.config.AbstractConfig
Get all the original settings, ensuring that all values are of type String.
originalsWithPrefix(String) - Method in class org.apache.kafka.common.config.AbstractConfig
Gets all original settings with the given prefix, stripping the prefix before adding it to the output.
originalsWithPrefix(String, boolean) - Method in class org.apache.kafka.common.config.AbstractConfig
Gets all original settings with the given prefix.
OutOfOrderSequenceException - Exception in org.apache.kafka.common.errors
This exception indicates that the broker received an unexpected sequence number from the producer, which means that data may have been lost.
OutOfOrderSequenceException(String) - Constructor for exception org.apache.kafka.common.errors.OutOfOrderSequenceException
 
owner() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
ownerAsString() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
ownerOrRenewer(KafkaPrincipal) - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
owners() - Method in class org.apache.kafka.clients.admin.DescribeDelegationTokenOptions
 
owners(List<KafkaPrincipal>) - Method in class org.apache.kafka.clients.admin.DescribeDelegationTokenOptions
if owners is null, all the user owned tokens and tokens where user have Describe permission will be returned.

P

parse(String) - Static method in enum org.apache.kafka.common.ConsumerGroupState
Parse a string into a consumer group state.
parse(Map<?, ?>) - Method in class org.apache.kafka.common.config.ConfigDef
Parse and validate configs against this configuration definition.
parseType(String, Object, ConfigDef.Type) - Static method in class org.apache.kafka.common.config.ConfigDef
Parse a value according to its expected type.
partition() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The partition from which this record is received
partition() - Method in exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
partition() - Method in class org.apache.kafka.clients.producer.ProducerRecord
 
partition() - Method in class org.apache.kafka.clients.producer.RecordMetadata
The partition the record was sent to
partition() - Method in class org.apache.kafka.common.PartitionInfo
The partition id
partition() - Method in class org.apache.kafka.common.TopicPartition
 
partition() - Method in class org.apache.kafka.common.TopicPartitionInfo
Return the partition id.
partition() - Method in class org.apache.kafka.common.TopicPartitionReplica
 
partition(String, Object, byte[], Object, byte[], int) - Method in class org.apache.kafka.clients.producer.DefaultStreamsPartitioner
Compute the partition for the given record.
partition(String, Object, byte[], Object, byte[], int) - Method in interface org.apache.kafka.clients.producer.StreamsPartitioner
Compute the partition for the given record.
partition(String, Object, byte[], Object, byte[], Cluster) - Method in interface org.apache.kafka.clients.producer.Partitioner
Compute the partition for the given record.
partition(TopicPartition) - Method in class org.apache.kafka.common.Cluster
Get the metadata for the specified partition
PARTITION_ASSIGNMENT_STRATEGY_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
partition.assignment.strategy
partitionAssignor() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
The consumer group partition assignor.
partitionCountForTopic(String) - Method in class org.apache.kafka.common.Cluster
Get the number of partitions for the given topic
Partitioner - Interface in org.apache.kafka.clients.producer
Partitioner Interface is not supported.
PARTITIONER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
partitioner.class
PartitionInfo - Class in org.apache.kafka.common
This is used to describe per-partition state in the MetadataResponse.
PartitionInfo(String, int, Node, Node[], Node[]) - Constructor for class org.apache.kafka.common.PartitionInfo
 
PartitionInfo(String, int, Node, Node[], Node[], Node[]) - Constructor for class org.apache.kafka.common.PartitionInfo
 
partitions() - Method in class org.apache.kafka.clients.admin.TopicDescription
A list of partitions where the index represents the partition id and the element contains leadership and replica information for that partition.
partitions() - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
Get the partitions which have records contained in this record set.
partitions() - Method in exception org.apache.kafka.clients.consumer.InvalidOffsetException
 
partitions() - Method in exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
returns all partitions for which no offests are defined.
partitions() - Method in exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
 
partitionsFor(String) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
partitionsFor(String) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get metadata about the partitions for a given topic.
partitionsFor(String) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
partitionsFor(String) - Method in class org.apache.kafka.clients.producer.KafkaProducer
Get the partition metadata for the given topic.
partitionsFor(String) - Method in class org.apache.kafka.clients.producer.MockProducer
 
partitionsFor(String) - Method in interface org.apache.kafka.clients.producer.Producer
partitionsFor(String, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
partitionsFor(String, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get metadata about the partitions for a given topic.
partitionsFor(String, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
partitionsForNode(int) - Method in class org.apache.kafka.common.Cluster
Get the list of partitions whose leader is this node
partitionsForTopic(String) - Method in class org.apache.kafka.common.Cluster
Get the list of partitions for this topic
partitionsToOffsetAndMetadata() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsResult
Return a future which yields a map of topic partitions to OffsetAndMetadata objects.
password() - Method in class org.apache.kafka.common.security.plain.PlainAuthenticateCallback
Returns the password provided by the client during SASL/PLAIN authentication
PASSWORD - org.apache.kafka.common.config.ConfigDef.Type
 
pattern() - Method in class org.apache.kafka.common.acl.AclBinding
 
patternFilter() - Method in class org.apache.kafka.common.acl.AclBindingFilter
 
patternType() - Method in class org.apache.kafka.common.resource.ResourcePattern
 
patternType() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
PatternType - Enum in org.apache.kafka.common.resource
Resource pattern type.
pause(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
pause(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Suspend fetching from the requested partitions.
pause(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
pause(TopicPartition...) - Method in interface org.apache.kafka.clients.consumer.Consumer
Deprecated.
pause(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Deprecated.
pause(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.MockConsumer
Deprecated.
paused() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
paused() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the set of partitions that were previously paused by a call to KafkaConsumer.pause(Collection).
paused() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
permissionType() - Method in class org.apache.kafka.common.acl.AccessControlEntry
Return the AclPermissionType.
permissionType() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
Return the AclPermissionType.
PlainAuthenticateCallback - Class in org.apache.kafka.common.security.plain
 
PlainAuthenticateCallback(char[]) - Constructor for class org.apache.kafka.common.security.plain.PlainAuthenticateCallback
Creates a callback with the password provided by the client
PlainLoginModule - Class in org.apache.kafka.common.security.plain
 
PlainLoginModule() - Constructor for class org.apache.kafka.common.security.plain.PlainLoginModule
 
PLAINTEXT - org.apache.kafka.common.security.auth.SecurityProtocol
Un-authenticated, non-encrypted channel
PlaintextAuthenticationContext - Class in org.apache.kafka.common.security.auth
 
PlaintextAuthenticationContext(InetAddress, String) - Constructor for class org.apache.kafka.common.security.auth.PlaintextAuthenticationContext
 
PolicyViolationException - Exception in org.apache.kafka.common.errors
Exception thrown if a create topics request does not satisfy the configured policy for a topic.
PolicyViolationException(String) - Constructor for exception org.apache.kafka.common.errors.PolicyViolationException
 
PolicyViolationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.PolicyViolationException
 
poll(long) - Method in interface org.apache.kafka.clients.consumer.Consumer
Deprecated.
poll(long) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Deprecated.
Since 2.0. Use KafkaConsumer.poll(Duration), which does not block beyond the timeout awaiting partition assignment. See KIP-266 for more information.
poll(long) - Method in class org.apache.kafka.clients.consumer.MockConsumer
Deprecated.
poll(long) - Method in interface org.apache.kafka.common.GenericCoordinator
 
poll(Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
poll(Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Fetch data for the topics or partitions specified using one of the subscribe/assign APIs.
poll(Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
port() - Method in class org.apache.kafka.common.Node
The port for this node
position(TopicPartition) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
position(TopicPartition) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the offset of the next record that will be fetched (if a record with that offset exists).
position(TopicPartition) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
position(TopicPartition, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
position(TopicPartition, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the offset of the next record that will be fetched (if a record with that offset exists).
position(TopicPartition, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.clients.admin.AdminClientConfig
 
postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.clients.consumer.ConsumerConfig
 
postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.clients.producer.ProducerConfig
 
postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.common.config.AbstractConfig
Called directly after user configs got parsed (and thus default values got set).
PREALLOCATE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
PREALLOCATE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
PREFIXED - org.apache.kafka.common.resource.PatternType
A prefixed resource name.
PREPARING_REBALANCE - org.apache.kafka.common.ConsumerGroupState
 
principal() - Method in class org.apache.kafka.common.acl.AccessControlEntry
Return the principal for this entry.
principal() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
Return the principal or null.
PRINCIPAL_BUILDER_CLASS_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
PRINCIPAL_BUILDER_CLASS_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
PrincipalBuilder - Interface in org.apache.kafka.common.security.auth
Deprecated.
As of Kafka 1.0.0, use KafkaPrincipalBuilder instead. This will be removed in a future major release.
principalName() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
The name of the principal to which this credential applies
PRODUCE - org.apache.kafka.server.quota.ClientQuotaType
 
producer() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The producer for this record.
Producer<K,​V> - Interface in org.apache.kafka.clients.producer
The interface for the KafkaProducer
PRODUCER_METRIC_GROUP_NAME - Static variable in class org.apache.kafka.clients.producer.KafkaProducer
 
ProducerConfig - Class in org.apache.kafka.clients.producer
Configuration for the Kafka Producer.
ProducerConfig(Map<String, Object>) - Constructor for class org.apache.kafka.clients.producer.ProducerConfig
 
ProducerConfig(Properties) - Constructor for class org.apache.kafka.clients.producer.ProducerConfig
 
ProducerFencedException - Exception in org.apache.kafka.common.errors
This fatal exception indicates that another producer with the same transactional.id has been started.
ProducerFencedException(String) - Constructor for exception org.apache.kafka.common.errors.ProducerFencedException
 
ProducerInterceptor<K,​V> - Interface in org.apache.kafka.clients.producer
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> - Class in org.apache.kafka.clients.producer
A key/value pair to be sent to Kafka.
ProducerRecord(String, Integer, Long, K, V) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
Creates a record with a specified timestamp to be sent to a specified topic and partition
ProducerRecord(String, Integer, Long, K, V, Iterable<Header>) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
Creates a record with a specified timestamp to be sent to a specified topic and partition
ProducerRecord(String, Integer, K, V) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
Creates a record to be sent to a specified topic and partition
ProducerRecord(String, Integer, K, V, Iterable<Header>) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
Creates a record to be sent to a specified topic and partition
ProducerRecord(String, K, V) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
Create a record to be sent to Kafka
ProducerRecord(String, V) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
Create a record with no key

Q

quotaLimit(ClientQuotaType, Map<String, String>) - Method in interface org.apache.kafka.server.quota.ClientQuotaCallback
Returns the quota limit associated with the provided metric tags.
quotaMetricTags(ClientQuotaType, KafkaPrincipal, String) - Method in interface org.apache.kafka.server.quota.ClientQuotaCallback
Quota callback invoked to determine the quota metric tags to be applied for a request.
quotaResetRequired(ClientQuotaType) - Method in interface org.apache.kafka.server.quota.ClientQuotaCallback
Returns true if any of the existing quota configs may have been updated since the last call to this method for the provided quota type.

R

rack() - Method in class org.apache.kafka.common.Node
The rack for this node
RangeAssignor - Class in org.apache.kafka.clients.consumer
This class is not supported.
RangeAssignor() - Constructor for class org.apache.kafka.clients.consumer.RangeAssignor
 
READ - org.apache.kafka.common.acl.AclOperation
READ operation.
reader(String) - Method in class org.apache.kafka.common.config.provider.FileConfigProvider
 
ReassignmentInProgressException - Exception in org.apache.kafka.common.errors
Thrown if a request cannot be completed because a partition reassignment is in progress.
ReassignmentInProgressException(String) - Constructor for exception org.apache.kafka.common.errors.ReassignmentInProgressException
 
ReassignmentInProgressException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ReassignmentInProgressException
 
rebalance(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
Simulate a rebalance event.
RebalanceInProgressException - Exception in org.apache.kafka.common.errors
 
RebalanceInProgressException() - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
 
RebalanceInProgressException(String) - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
 
RebalanceInProgressException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
 
RebalanceInProgressException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
 
RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
 
RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
receive.buffer.bytes
RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
receive.buffer.bytes
recommendedValues() - Method in class org.apache.kafka.common.config.ConfigValue
 
recommendedValues(List<Object>) - Method in class org.apache.kafka.common.config.ConfigValue
 
recommender - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
Reconfigurable - Interface in org.apache.kafka.common
Interface for reconfigurable classes that support dynamic configuration.
RECONFIGURABLE_CONFIGS - Static variable in class org.apache.kafka.common.config.SslConfigs
 
reconfigurableConfigs() - Method in interface org.apache.kafka.common.Reconfigurable
Returns the names of configs that may be reconfigured.
reconfigure(Map<String, ?>) - Method in interface org.apache.kafka.common.Reconfigurable
Reconfigures this instance with the given key-value pairs.
RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
reconnect.backoff.max.ms
RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
reconnect.backoff.max.ms
RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
reconnect.backoff.max.ms
RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
reconnect.backoff.ms
RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
reconnect.backoff.ms
RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
reconnect.backoff.ms
RecordBatchTooLargeException - Exception in org.apache.kafka.common.errors
This record batch is larger than the maximum allowable size
RecordBatchTooLargeException() - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
 
RecordBatchTooLargeException(String) - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
 
RecordBatchTooLargeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
 
RecordBatchTooLargeException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
 
RecordMetadata - Class in org.apache.kafka.clients.producer
The metadata for a record that has been acknowledged by the server
RecordMetadata(TopicPartition, long, long) - Constructor for class org.apache.kafka.clients.producer.RecordMetadata
For kafka-0.9.0 backward compatibility
RecordMetadata(TopicPartition, long, long, long, long, int, int) - Constructor for class org.apache.kafka.clients.producer.RecordMetadata
RecordMetadata(TopicPartition, long, long, long, Long, int, int) - Constructor for class org.apache.kafka.clients.producer.RecordMetadata
 
records(String) - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
Get just the records for the given topic
records(TopicPartition) - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
Get just the records for the given partition
RecordsToDelete - Class in org.apache.kafka.clients.admin
Describe records to delete in a call to AdminClient.deleteRecords(Map) The API of this class is evolving, see AdminClient for details.
RecordTooLargeException - Exception in org.apache.kafka.common.errors
This record is larger than the maximum allowable size
RecordTooLargeException() - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
 
RecordTooLargeException(String) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
 
RecordTooLargeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
 
RecordTooLargeException(String, Map<TopicPartition, Long>) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
 
RecordTooLargeException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
 
recordTooLargePartitions() - Method in exception org.apache.kafka.common.errors.RecordTooLargeException
 
remove(String) - Method in interface org.apache.kafka.common.header.Headers
Removes all headers for the given key returning if the operation succeeded.
removeQuota(ClientQuotaType, ClientQuotaEntity) - Method in interface org.apache.kafka.server.quota.ClientQuotaCallback
Quota configuration removal callback that is invoked when quota configuration for an entity is removed in ZooKeeper.
renewDelegationToken(byte[]) - Method in class org.apache.kafka.clients.admin.AdminClient
Renew a Delegation Token.
renewDelegationToken(byte[], RenewDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.AdminClient
Renew a Delegation Token.
renewDelegationToken(byte[], RenewDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
RenewDelegationTokenOptions - Class in org.apache.kafka.clients.admin
RenewDelegationTokenOptions() - Constructor for class org.apache.kafka.clients.admin.RenewDelegationTokenOptions
 
RenewDelegationTokenResult - Class in org.apache.kafka.clients.admin
renewers() - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
 
renewers() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
renewers(List<KafkaPrincipal>) - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
 
renewersAsString() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
renewTimePeriodMs() - Method in class org.apache.kafka.clients.admin.RenewDelegationTokenOptions
 
renewTimePeriodMs(long) - Method in class org.apache.kafka.clients.admin.RenewDelegationTokenOptions
 
ReplicaNotAvailableException - Exception in org.apache.kafka.common.errors
 
ReplicaNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.ReplicaNotAvailableException
 
ReplicaNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ReplicaNotAvailableException
 
ReplicaNotAvailableException(Throwable) - Constructor for exception org.apache.kafka.common.errors.ReplicaNotAvailableException
 
replicas() - Method in class org.apache.kafka.common.PartitionInfo
The complete set of replicas for this partition regardless of whether they are alive or up-to-date
replicas() - Method in class org.apache.kafka.common.TopicPartitionInfo
Return the replicas of the partition in the same order as the replica assignment.
replicasAssignments() - Method in class org.apache.kafka.clients.admin.NewTopic
A map from partition id to replica ids (i.e.
replicasAssignments() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
Return a map from partition id to replica (broker) ids or null if numPartitions and replicationFactor are set instead.
replicationFactor() - Method in class org.apache.kafka.clients.admin.NewTopic
The replication factor for the new topic or -1 if a replica assignment has been specified.
replicationFactor() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
Return the number of replicas to create or null if replicaAssignments is not null.
REQUEST - org.apache.kafka.server.quota.ClientQuotaType
 
REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
request.timeout.ms
REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
request.timeout.ms
REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
request.timeout.ms
RequestMetadata(String, Integer, Short, Map<Integer, List<Integer>>, Map<String, String>) - Constructor for class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
Create an instance of this class with the provided parameters.
RequestMetadata(ConfigResource, Map<String, String>) - Constructor for class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
Create an instance of this class with the provided parameters.
requestRejoin() - Method in interface org.apache.kafka.common.GenericCoordinator
 
resource() - Method in class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
 
Resource - Class in org.apache.kafka.common.resource
Represents a cluster resource with a tuple of (type, name).
Resource(ResourceType, String) - Constructor for class org.apache.kafka.common.resource.Resource
Create an instance of this class with the provided parameters.
ResourceFilter - Class in org.apache.kafka.common.resource
A filter which matches Resource objects.
ResourceFilter(ResourceType, String) - Constructor for class org.apache.kafka.common.resource.ResourceFilter
Create an instance of this class with the provided parameters.
ResourcePattern - Class in org.apache.kafka.common.resource
Represents a pattern that is used by ACLs to match zero or more Resources.
ResourcePattern(ResourceType, String, PatternType) - Constructor for class org.apache.kafka.common.resource.ResourcePattern
Create a pattern using the supplied parameters.
ResourcePatternFilter - Class in org.apache.kafka.common.resource
Represents a filter that can match ResourcePattern.
ResourcePatternFilter(ResourceType, String, PatternType) - Constructor for class org.apache.kafka.common.resource.ResourcePatternFilter
Create a filter using the supplied parameters.
resourceType() - Method in class org.apache.kafka.common.resource.Resource
Return the resource type.
resourceType() - Method in class org.apache.kafka.common.resource.ResourceFilter
Return the resource type.
resourceType() - Method in class org.apache.kafka.common.resource.ResourcePattern
 
resourceType() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
ResourceType - Enum in org.apache.kafka.common.resource
Represents a type of resource which an ACL can be applied to.
resume(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
resume(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Resume specified partitions which have been paused with KafkaConsumer.pause(Collection).
resume(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
resume(TopicPartition...) - Method in interface org.apache.kafka.clients.consumer.Consumer
Deprecated.
resume(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Deprecated.
resume(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.MockConsumer
Deprecated.
RETENTION_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
RETENTION_BYTES_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
RETENTION_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
RETENTION_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
RetriableCommitFailedException - Exception in org.apache.kafka.clients.consumer
 
RetriableCommitFailedException(String) - Constructor for exception org.apache.kafka.clients.consumer.RetriableCommitFailedException
 
RetriableCommitFailedException(String, Throwable) - Constructor for exception org.apache.kafka.clients.consumer.RetriableCommitFailedException
 
RetriableCommitFailedException(Throwable) - Constructor for exception org.apache.kafka.clients.consumer.RetriableCommitFailedException
 
RetriableException - Exception in org.apache.kafka.common.errors
A retryable exception is a transient exception that if retried may succeed.
RetriableException() - Constructor for exception org.apache.kafka.common.errors.RetriableException
 
RetriableException(String) - Constructor for exception org.apache.kafka.common.errors.RetriableException
 
RetriableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RetriableException
 
RetriableException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RetriableException
 
RETRIES_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
 
RETRIES_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
retries
RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
retry.backoff.ms
RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
retry.backoff.ms
RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
retry.backoff.ms
RoundRobinAssignor - Class in org.apache.kafka.clients.consumer
This class is not supported.
RoundRobinAssignor() - Constructor for class org.apache.kafka.clients.consumer.RoundRobinAssignor
 

S

salt() - Method in class org.apache.kafka.common.security.scram.ScramCredential
Returns the salt used to process this credential using the SCRAM algorithm.
SASL_CLIENT_CALLBACK_HANDLER_CLASS - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_CLIENT_CALLBACK_HANDLER_CLASS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_ENABLED_MECHANISMS - Static variable in class org.apache.kafka.common.config.SaslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
SASL_ENABLED_MECHANISMS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
SASL_JAAS_CONFIG - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_JAAS_CONFIG_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_KINIT_CMD - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_KINIT_CMD_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_MIN_TIME_BEFORE_RELOGIN - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_MIN_TIME_BEFORE_RELOGIN_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_PRINCIPAL_TO_LOCAL_RULES - Static variable in class org.apache.kafka.common.config.SaslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
SASL_KERBEROS_PRINCIPAL_TO_LOCAL_RULES_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
SASL_KERBEROS_SERVICE_NAME - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_SERVICE_NAME_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_TICKET_RENEW_JITTER - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_TICKET_RENEW_JITTER_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_TICKET_RENEW_WINDOW_FACTOR - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_TICKET_RENEW_WINDOW_FACTOR_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_CALLBACK_HANDLER_CLASS - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_CALLBACK_HANDLER_CLASS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_CLASS - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_CLASS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_REFRESH_BUFFER_SECONDS - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_REFRESH_BUFFER_SECONDS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_REFRESH_MIN_PERIOD_SECONDS - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_REFRESH_MIN_PERIOD_SECONDS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_REFRESH_WINDOW_FACTOR - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_REFRESH_WINDOW_FACTOR_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_REFRESH_WINDOW_JITTER - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_REFRESH_WINDOW_JITTER_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_MECHANISM - Static variable in class org.apache.kafka.common.config.SaslConfigs
SASL mechanism configuration - standard mechanism names are listed here.
SASL_MECHANISM_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_PLAINTEXT - org.apache.kafka.common.security.auth.SecurityProtocol
SASL authenticated, non-encrypted channel
SASL_SSL - org.apache.kafka.common.security.auth.SecurityProtocol
SASL authenticated, SSL channel
SaslAuthenticationContext - Class in org.apache.kafka.common.security.auth
 
SaslAuthenticationContext(SaslServer, SecurityProtocol, InetAddress, String) - Constructor for class org.apache.kafka.common.security.auth.SaslAuthenticationContext
 
SaslAuthenticationException - Exception in org.apache.kafka.common.errors
This exception indicates that SASL authentication has failed.
SaslAuthenticationException(String) - Constructor for exception org.apache.kafka.common.errors.SaslAuthenticationException
 
SaslAuthenticationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SaslAuthenticationException
 
SaslConfigs - Class in org.apache.kafka.common.config
 
SaslConfigs() - Constructor for class org.apache.kafka.common.config.SaslConfigs
 
SaslExtensions - Class in org.apache.kafka.common.security.auth
A simple immutable value object class holding customizable SASL extensions
SaslExtensions(Map<String, String>) - Constructor for class org.apache.kafka.common.security.auth.SaslExtensions
 
SaslExtensionsCallback - Class in org.apache.kafka.common.security.auth
Optional callback used for SASL mechanisms if any extensions need to be set in the SASL exchange.
SaslExtensionsCallback() - Constructor for class org.apache.kafka.common.security.auth.SaslExtensionsCallback
 
scheduleNopPollTask() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
schedulePollTask(Runnable) - Method in class org.apache.kafka.clients.consumer.MockConsumer
Schedule a task to be executed during a poll().
scope() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
The token's scope of access, as per RFC 6749 Section 1.4
scramCredential() - Method in class org.apache.kafka.common.security.scram.ScramCredentialCallback
Returns the SCRAM credential if set on this instance.
scramCredential(ScramCredential) - Method in class org.apache.kafka.common.security.scram.ScramCredentialCallback
Sets the SCRAM credential for this instance.
ScramCredential - Class in org.apache.kafka.common.security.scram
SCRAM credential class that encapsulates the credential data persisted for each user that is accessible to the server.
ScramCredential(byte[], byte[], byte[], int) - Constructor for class org.apache.kafka.common.security.scram.ScramCredential
Constructs a new credential.
ScramCredentialCallback - Class in org.apache.kafka.common.security.scram
Callback used for SCRAM mechanisms.
ScramCredentialCallback() - Constructor for class org.apache.kafka.common.security.scram.ScramCredentialCallback
 
ScramExtensionsCallback - Class in org.apache.kafka.common.security.scram
Optional callback used for SCRAM mechanisms if any extensions need to be set in the SASL/SCRAM exchange.
ScramExtensionsCallback() - Constructor for class org.apache.kafka.common.security.scram.ScramExtensionsCallback
 
ScramLoginModule - Class in org.apache.kafka.common.security.scram
 
ScramLoginModule() - Constructor for class org.apache.kafka.common.security.scram.ScramLoginModule
 
SECURITY_PROTOCOL_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
 
SecurityDisabledException - Exception in org.apache.kafka.common.errors
An error indicating that security is disabled on the broker.
SecurityDisabledException(String) - Constructor for exception org.apache.kafka.common.errors.SecurityDisabledException
 
SecurityDisabledException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SecurityDisabledException
 
securityProtocol() - Method in interface org.apache.kafka.common.security.auth.AuthenticationContext
Underlying security protocol of the authentication session.
securityProtocol() - Method in class org.apache.kafka.common.security.auth.PlaintextAuthenticationContext
 
securityProtocol() - Method in class org.apache.kafka.common.security.auth.SaslAuthenticationContext
 
securityProtocol() - Method in class org.apache.kafka.common.security.auth.SslAuthenticationContext
 
SecurityProtocol - Enum in org.apache.kafka.common.security.auth
 
seek(TopicPartition, long) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
seek(TopicPartition, long) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Overrides the fetch offsets that the consumer will use on the next poll(timeout).
seek(TopicPartition, long) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
seekToBeginning(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
seekToBeginning(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Seek to the first offset for each of the given partitions.
seekToBeginning(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
seekToBeginning(TopicPartition...) - Method in interface org.apache.kafka.clients.consumer.Consumer
Deprecated.
seekToBeginning(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
seekToBeginning(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.MockConsumer
Deprecated.
seekToEnd(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
seekToEnd(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Seek to the last offset for each of the given partitions.
seekToEnd(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
seekToEnd(TopicPartition...) - Method in interface org.apache.kafka.clients.consumer.Consumer
Deprecated.
seekToEnd(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Deprecated.
seekToEnd(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.MockConsumer
Deprecated.
SEGMENT_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
SEGMENT_BYTES_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
SEGMENT_INDEX_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
SEGMENT_INDEX_BYTES_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
SEGMENT_JITTER_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
SEGMENT_JITTER_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
SEGMENT_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
SEGMENT_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
send(ProducerRecord<K, V>) - Method in class org.apache.kafka.clients.producer.KafkaProducer
Asynchronously send a record to a topic.
send(ProducerRecord<K, V>) - Method in class org.apache.kafka.clients.producer.MockProducer
Adds the record to the list of sent records.
send(ProducerRecord<K, V>) - Method in interface org.apache.kafka.clients.producer.Producer
send(ProducerRecord<K, V>, Callback) - Method in class org.apache.kafka.clients.producer.KafkaProducer
Asynchronously send a record to a topic and invoke the provided callback when the send has been acknowledged.
send(ProducerRecord<K, V>, Callback) - Method in class org.apache.kafka.clients.producer.MockProducer
Adds the record to the list of sent records.
send(ProducerRecord<K, V>, Callback) - Method in interface org.apache.kafka.clients.producer.Producer
SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
 
SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
send.buffer.bytes
SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
send.buffer.bytes
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class org.apache.kafka.clients.producer.KafkaProducer
This API is not supported.
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class org.apache.kafka.clients.producer.MockProducer
 
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in interface org.apache.kafka.clients.producer.Producer
sentOffsets() - Method in class org.apache.kafka.clients.producer.MockProducer
 
Serde<T> - Interface in org.apache.kafka.common.serialization
The interface for wrapping a serializer and deserializer for the given data type.
serdeFrom(Class<T>) - Static method in class org.apache.kafka.common.serialization.Serdes
 
serdeFrom(Serializer<T>, Deserializer<T>) - Static method in class org.apache.kafka.common.serialization.Serdes
Construct a serde object from separate serializer and deserializer
Serdes - Class in org.apache.kafka.common.serialization
Factory for creating serializers / deserializers.
Serdes() - Constructor for class org.apache.kafka.common.serialization.Serdes
 
Serdes.ByteArraySerde - Class in org.apache.kafka.common.serialization
 
Serdes.ByteBufferSerde - Class in org.apache.kafka.common.serialization
 
Serdes.BytesSerde - Class in org.apache.kafka.common.serialization
 
Serdes.DoubleSerde - Class in org.apache.kafka.common.serialization
 
Serdes.FloatSerde - Class in org.apache.kafka.common.serialization
 
Serdes.IntegerSerde - Class in org.apache.kafka.common.serialization
 
Serdes.LongSerde - Class in org.apache.kafka.common.serialization
 
Serdes.ShortSerde - Class in org.apache.kafka.common.serialization
 
Serdes.StringSerde - Class in org.apache.kafka.common.serialization
 
Serdes.UUIDSerde - Class in org.apache.kafka.common.serialization
 
Serdes.WrapperSerde<T> - Class in org.apache.kafka.common.serialization
 
SerializationException - Exception in org.apache.kafka.common.errors
Any exception during serialization in the producer
SerializationException() - Constructor for exception org.apache.kafka.common.errors.SerializationException
 
SerializationException(String) - Constructor for exception org.apache.kafka.common.errors.SerializationException
 
SerializationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SerializationException
 
SerializationException(Throwable) - Constructor for exception org.apache.kafka.common.errors.SerializationException
 
serialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ByteArraySerializer
 
serialize(String, Double) - Method in class org.apache.kafka.common.serialization.DoubleSerializer
 
serialize(String, Float) - Method in class org.apache.kafka.common.serialization.FloatSerializer
 
serialize(String, Integer) - Method in class org.apache.kafka.common.serialization.IntegerSerializer
 
serialize(String, Long) - Method in class org.apache.kafka.common.serialization.LongSerializer
 
serialize(String, Short) - Method in class org.apache.kafka.common.serialization.ShortSerializer
 
serialize(String, String) - Method in class org.apache.kafka.common.serialization.StringSerializer
 
serialize(String, ByteBuffer) - Method in class org.apache.kafka.common.serialization.ByteBufferSerializer
 
serialize(String, UUID) - Method in class org.apache.kafka.common.serialization.UUIDSerializer
 
serialize(String, Headers, T) - Method in interface org.apache.kafka.common.serialization.ExtendedSerializer
Deprecated.
Convert data into a byte array.
serialize(String, Headers, T) - Method in class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
Deprecated.
 
serialize(String, Headers, T) - Method in interface org.apache.kafka.common.serialization.Serializer
Convert data into a byte array.
serialize(String, Bytes) - Method in class org.apache.kafka.common.serialization.BytesSerializer
 
serialize(String, T) - Method in class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
Deprecated.
 
serialize(String, T) - Method in interface org.apache.kafka.common.serialization.Serializer
Convert data into a byte array.
serializedKeySize() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The size of the serialized, uncompressed key in bytes.
serializedKeySize() - Method in class org.apache.kafka.clients.producer.RecordMetadata
The size of the serialized, uncompressed key in bytes.
serializedValueSize() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The size of the serialized, uncompressed value in bytes.
serializedValueSize() - Method in class org.apache.kafka.clients.producer.RecordMetadata
The size of the serialized, uncompressed value in bytes.
serializer() - Method in interface org.apache.kafka.common.serialization.Serde
 
serializer() - Method in class org.apache.kafka.common.serialization.Serdes.WrapperSerde
 
Serializer<T> - Interface in org.apache.kafka.common.serialization
An interface for converting objects to bytes.
server() - Method in class org.apache.kafka.common.security.auth.SaslAuthenticationContext
 
serverKey() - Method in class org.apache.kafka.common.security.scram.ScramCredential
Server key computed from the client password using the SCRAM algorithm.
serviceName() - Method in interface org.apache.kafka.common.security.auth.Login
Returns the service name to be used for SASL.
session() - Method in class org.apache.kafka.common.security.auth.SslAuthenticationContext
 
SESSION_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
session.timeout.ms
setException(KafkaException) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
setExpiryTimestamp(long) - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
setMockMetrics(MetricName, Metric) - Method in class org.apache.kafka.clients.producer.MockProducer
Set a mock metric for testing purpose
Short() - Static method in class org.apache.kafka.common.serialization.Serdes
 
SHORT - org.apache.kafka.common.config.ConfigDef.Type
 
SHORT - org.apache.kafka.common.config.ConfigDef.Width
 
ShortDeserializer - Class in org.apache.kafka.common.serialization
 
ShortDeserializer() - Constructor for class org.apache.kafka.common.serialization.ShortDeserializer
 
ShortSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.ShortSerde
 
ShortSerializer - Class in org.apache.kafka.common.serialization
 
ShortSerializer() - Constructor for class org.apache.kafka.common.serialization.ShortSerializer
 
shouldListInternal() - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
Return true if we should list internal topics.
shouldValidateOnly() - Method in class org.apache.kafka.clients.admin.AlterConfigsOptions
Return true if the request should be validated without altering the configs.
shouldValidateOnly() - Method in class org.apache.kafka.clients.admin.CreateTopicsOptions
Return true if the request should be validated without creating the topic.
source() - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
Returns the source of this configuration.
source() - Method in class org.apache.kafka.clients.admin.ConfigEntry
Return the source of this configuration entry.
SSL - org.apache.kafka.common.security.auth.SecurityProtocol
SSL channel
SSL_CIPHER_SUITES_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_CIPHER_SUITES_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_CLIENT_AUTH_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
SSL_CLIENT_AUTH_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
SSL_DISABLED_CIPHER_SUITES_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_DISABLED_CIPHER_SUITES_DEFAULT - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_DISABLED_CIPHER_SUITES_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_DISABLED_PROTOCOLS_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_DISABLED_PROTOCOLS_DEFAULT - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_DISABLED_PROTOCOLS_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_ENABLED_PROTOCOLS_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_ENABLED_PROTOCOLS_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_ENDPOINT_IDENTIFICATION_ALGORITHM_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_ENDPOINT_IDENTIFICATION_ALGORITHM_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_KEY_PASSWORD_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_KEY_PASSWORD_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_KEYMANAGER_ALGORITHM_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_KEYMANAGER_ALGORITHM_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_KEYSTORE_LOCATION_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_KEYSTORE_LOCATION_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_KEYSTORE_PASSWORD_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_KEYSTORE_PASSWORD_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_KEYSTORE_TYPE_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_KEYSTORE_TYPE_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_PROTOCOL_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_PROTOCOL_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_PROVIDER_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_PROVIDER_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_SECURE_RANDOM_IMPLEMENTATION_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_SECURE_RANDOM_IMPLEMENTATION_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_TRUSTMANAGER_ALGORITHM_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_TRUSTMANAGER_ALGORITHM_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_TRUSTSTORE_LOCATION_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_TRUSTSTORE_LOCATION_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_TRUSTSTORE_PASSWORD_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_TRUSTSTORE_PASSWORD_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_TRUSTSTORE_TYPE_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_TRUSTSTORE_TYPE_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SslAuthenticationContext - Class in org.apache.kafka.common.security.auth
 
SslAuthenticationContext(SSLSession, InetAddress, String) - Constructor for class org.apache.kafka.common.security.auth.SslAuthenticationContext
 
SslAuthenticationException - Exception in org.apache.kafka.common.errors
This exception indicates that SSL handshake has failed.
SslAuthenticationException(String) - Constructor for exception org.apache.kafka.common.errors.SslAuthenticationException
 
SslAuthenticationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SslAuthenticationException
 
SslConfigs - Class in org.apache.kafka.common.config
 
SslConfigs() - Constructor for class org.apache.kafka.common.config.SslConfigs
 
STABLE - org.apache.kafka.common.ConsumerGroupState
 
startTimeMs() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
When the credential became valid, in terms of the number of milliseconds since the epoch, if known, otherwise null.
state() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
The consumer group state, or UNKNOWN if the state is too new for us to parse.
STATIC_BROKER_CONFIG - org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
 
StickyAssignor - Class in org.apache.kafka.clients.consumer
This class is not supported.
StickyAssignor() - Constructor for class org.apache.kafka.clients.consumer.StickyAssignor
 
storedKey() - Method in class org.apache.kafka.common.security.scram.ScramCredential
Stored key computed from the client password using the SCRAM algorithm.
STREAMS_ADMIN_DEFAULT_STREAM_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
streams.admin.default.stream
STREAMS_BUFFER_TIME_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
streams.buffer.max.time.ms
STREAMS_CLIENTSIDE_PARTITION_ASSIGNMENT_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
streams.clientside.partition.assignment
STREAMS_CLIENTSIDE_PARTITION_ASSIGNMENT_INTERNAL_STREAM - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
streams.clientside.partition.assignment
STREAMS_CONSUMER_BUFFER_MEMORY_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
streams.consumer.buffer.memory
STREAMS_CONSUMER_DEFAULT_STREAM_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
streams.consumer.default.stream
STREAMS_DEFAULT_INTERNAL_STREAM_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
streams.default.internal.stream
STREAMS_HARDMOUNT_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
fs.mapr.hardmount
STREAMS_HARDMOUNT_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
fs.mapr.hardmount
STREAMS_HARDMOUNT_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
fs.mapr.hardmount
STREAMS_NEGATIVEOFFSET_RECORD_ON_EOF_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
 
STREAMS_PARALLEL_FLUSHERS_PER_PARTITION_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
streams.parallel.flushers.per.partition
STREAMS_PARTITIONER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
streams.partitioner.class
STREAMS_PRODUCER_DEFAULT_STREAM_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
streams.producer.default.stream
STREAMS_RECORD_STRIP_STREAMPATH_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
streams.record.strip.streampath
STREAMS_RPC_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
streams.rpc.timeout.ms
STREAMS_RPC_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
streams.rpc.timeout.ms
STREAMS_RPC_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
streams.rpc.timeout.ms
STREAMS_ZEROOFFSET_RECORD_ON_EOF_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
 
StreamsPartitioner - Interface in org.apache.kafka.clients.producer
Partitioner Interface
String() - Static method in class org.apache.kafka.common.serialization.Serdes
 
STRING - org.apache.kafka.common.config.ConfigDef.Type
 
StringDeserializer - Class in org.apache.kafka.common.serialization
String encoding defaults to UTF8 and can be customized by setting the property key.deserializer.encoding, value.deserializer.encoding or deserializer.encoding.
StringDeserializer() - Constructor for class org.apache.kafka.common.serialization.StringDeserializer
 
StringSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.StringSerde
 
StringSerializer - Class in org.apache.kafka.common.serialization
String encoding defaults to UTF8 and can be customized by setting the property key.serializer.encoding, value.serializer.encoding or serializer.encoding.
StringSerializer() - Constructor for class org.apache.kafka.common.serialization.StringSerializer
 
subject() - Method in interface org.apache.kafka.common.security.auth.Login
Returns the authenticated subject of this login context.
subscribe(String, Set<String>, ConfigChangeCallback) - Method in interface org.apache.kafka.common.config.provider.ConfigProvider
Subscribes to changes for the given keys at the given path (optional operation).
subscribe(Collection<String>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
subscribe(Collection<String>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Subscribe to the given list of topics to get dynamically assigned partitions.
subscribe(Collection<String>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
subscribe(Collection<String>, ConsumerRebalanceListener) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
subscribe(Collection<String>, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Subscribe to the given list of topics to get dynamically assigned partitions.
subscribe(Collection<String>, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
subscribe(List<String>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
subscribe(List<String>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Retained for backward binary compatibility See KafkaConsumer.subscribe(Collection)
subscribe(List<String>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
subscribe(List<String>, ConsumerRebalanceListener) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
subscribe(List<String>, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Retained for backward binary compatibility.
subscribe(List<String>, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
subscribe(Pattern) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
subscribe(Pattern) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Subscribe to all topics matching specified pattern to get dynamically assigned partitions.
subscribe(Pattern) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
subscribe(Pattern, ConsumerRebalanceListener) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
subscribe(Pattern, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Subscribe to all topics matching specified pattern to get dynamically assigned partitions.
subscribe(Pattern, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
subscription() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
subscription() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the current subscription.
subscription() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
subscription(Set<String>) - Method in class org.apache.kafka.clients.consumer.StickyAssignor
 
synonyms() - Method in class org.apache.kafka.clients.admin.ConfigEntry
Returns all config values that may be used as the value of this config along with their source, in the order of precedence.

T

tags() - Method in class org.apache.kafka.common.MetricName
 
tags() - Method in class org.apache.kafka.common.MetricNameTemplate
Get the set of tag names for the metric.
thenApply(KafkaFuture.BaseFunction<T, R>) - Method in class org.apache.kafka.common.KafkaFuture
Returns a new KafkaFuture that, when this future completes normally, is executed with this futures's result as the argument to the supplied function.
thenApply(KafkaFuture.Function<T, R>) - Method in class org.apache.kafka.common.KafkaFuture
 
TimeoutException - Exception in org.apache.kafka.common.errors
Indicates that a request timed out.
TimeoutException() - Constructor for exception org.apache.kafka.common.errors.TimeoutException
 
TimeoutException(String) - Constructor for exception org.apache.kafka.common.errors.TimeoutException
 
TimeoutException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.TimeoutException
 
TimeoutException(Throwable) - Constructor for exception org.apache.kafka.common.errors.TimeoutException
 
timeoutMs - Variable in class org.apache.kafka.clients.admin.AbstractOptions
 
timeoutMs() - Method in class org.apache.kafka.clients.admin.AbstractOptions
The request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.AbstractOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.AlterConfigsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.CreateAclsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.CreateTopicsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DeleteAclsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DeleteTopicsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DescribeAclsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DescribeClusterOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DescribeConfigsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DescribeTopicsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timestamp() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The timestamp of this record
timestamp() - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
 
timestamp() - Method in class org.apache.kafka.clients.producer.ProducerRecord
 
timestamp() - Method in class org.apache.kafka.clients.producer.RecordMetadata
The timestamp of the record in the topic/partition.
timestampType() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The timestamp type of this record
toArray() - Method in interface org.apache.kafka.common.header.Headers
Returns all headers as an array, in the order they were added in.
toEnrichedRst() - Method in class org.apache.kafka.common.config.ConfigDef
Configs with new metadata (group, orderInGroup, dependents) formatted with reStructuredText, suitable for embedding in Sphinx documentation.
toFilter() - Method in class org.apache.kafka.common.acl.AccessControlEntry
Create a filter which matches only this AccessControlEntry.
toFilter() - Method in class org.apache.kafka.common.acl.AclBinding
Create a filter which matches only this AclBinding.
toFilter() - Method in class org.apache.kafka.common.resource.Resource
Create a filter which matches only this Resource.
toFilter() - Method in class org.apache.kafka.common.resource.ResourcePattern
 
toHtmlTable() - Method in class org.apache.kafka.common.config.ConfigDef
 
toHtmlTable(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
Converts this config into an HTML table that can be embedded into docs.
token() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
 
token() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback
Return the (potentially null) token
token() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
Return the (potentially null) token
token(OAuthBearerToken) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback
Set the token.
token(OAuthBearerToken) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
Set the token.
TOKEN_AUTH_CONFIG - Static variable in class org.apache.kafka.common.security.scram.ScramLoginModule
 
tokenAuthenticated() - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
 
tokenAuthenticated(boolean) - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
 
tokenId() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
tokenInfo() - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
 
TokenInformation - Class in org.apache.kafka.common.security.token.delegation
A class representing a delegation token details.
TokenInformation(String, KafkaPrincipal, Collection<KafkaPrincipal>, long, long, long) - Constructor for class org.apache.kafka.common.security.token.delegation.TokenInformation
 
tokenValue() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
Return the (always non-null) token value
topic() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The topic this record is received from
topic() - Method in class org.apache.kafka.clients.producer.ProducerRecord
 
topic() - Method in class org.apache.kafka.clients.producer.RecordMetadata
The topic the record was appended to
topic() - Method in class org.apache.kafka.common.PartitionInfo
The topic name
topic() - Method in class org.apache.kafka.common.TopicPartition
 
topic() - Method in class org.apache.kafka.common.TopicPartitionReplica
 
topic() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
Return the name of the topic to create.
TOPIC - org.apache.kafka.common.config.ConfigResource.Type
 
TOPIC - org.apache.kafka.common.resource.ResourceType
A Kafka topic.
TopicAuthorizationException - Exception in org.apache.kafka.common.errors
 
TopicAuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.TopicAuthorizationException
 
TopicAuthorizationException(Set<String>) - Constructor for exception org.apache.kafka.common.errors.TopicAuthorizationException
 
TopicConfig - Class in org.apache.kafka.common.config
Keys that can be used to configure a topic.
TopicConfig() - Constructor for class org.apache.kafka.common.config.TopicConfig
 
TopicDeletionDisabledException - Exception in org.apache.kafka.common.errors
 
TopicDeletionDisabledException() - Constructor for exception org.apache.kafka.common.errors.TopicDeletionDisabledException
 
TopicDeletionDisabledException(String) - Constructor for exception org.apache.kafka.common.errors.TopicDeletionDisabledException
 
TopicDescription - Class in org.apache.kafka.clients.admin
A detailed description of a single topic in the cluster.
TopicDescription(String, boolean, List<TopicPartitionInfo>) - Constructor for class org.apache.kafka.clients.admin.TopicDescription
Create an instance with the specified parameters.
TopicExistsException - Exception in org.apache.kafka.common.errors
 
TopicExistsException(String) - Constructor for exception org.apache.kafka.common.errors.TopicExistsException
 
TopicExistsException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.TopicExistsException
 
TopicListing - Class in org.apache.kafka.clients.admin
A listing of a topic in the cluster.
TopicListing(String, boolean) - Constructor for class org.apache.kafka.clients.admin.TopicListing
Create an instance with the specified parameters.
TopicPartition - Class in org.apache.kafka.common
A topic name and partition number
TopicPartition(String, int) - Constructor for class org.apache.kafka.common.TopicPartition
 
TopicPartitionInfo - Class in org.apache.kafka.common
A class containing leadership, replicas and ISR information for a topic partition.
TopicPartitionInfo(int, Node, List<Node>, List<Node>) - Constructor for class org.apache.kafka.common.TopicPartitionInfo
Create an instance of this class with the provided parameters.
TopicPartitionReplica - Class in org.apache.kafka.common
The topic name, partition number and the brokerId of the replica
TopicPartitionReplica(String, int, int) - Constructor for class org.apache.kafka.common.TopicPartitionReplica
 
topicPartitions() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsOptions
Returns a list of topic partitions to add as part of the result.
topicPartitions() - Method in class org.apache.kafka.clients.admin.MemberAssignment
The topic partitions assigned to a group member.
topicPartitions(List<TopicPartition>) - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsOptions
Set the topic partitions to list as part of the result.
topics() - Method in class org.apache.kafka.common.Cluster
Get all topics.
toRst() - Method in class org.apache.kafka.common.config.ConfigDef
Get the configs formatted with reStructuredText, suitable for embedding in Sphinx documentation.
toString() - Method in class org.apache.kafka.clients.admin.Config
 
toString() - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
 
toString() - Method in class org.apache.kafka.clients.admin.ConfigEntry
 
toString() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
 
toString() - Method in class org.apache.kafka.clients.admin.ConsumerGroupListing
 
toString() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
 
toString() - Method in class org.apache.kafka.clients.admin.MemberAssignment
 
toString() - Method in class org.apache.kafka.clients.admin.MemberDescription
 
toString() - Method in class org.apache.kafka.clients.admin.NewPartitions
 
toString() - Method in class org.apache.kafka.clients.admin.NewTopic
 
toString() - Method in class org.apache.kafka.clients.admin.RecordsToDelete
 
toString() - Method in class org.apache.kafka.clients.admin.TopicDescription
 
toString() - Method in class org.apache.kafka.clients.admin.TopicListing
 
toString() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
 
toString() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
 
toString() - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
 
toString() - Method in class org.apache.kafka.clients.producer.ProducerRecord
 
toString() - Method in class org.apache.kafka.clients.producer.RecordMetadata
 
toString() - Method in class org.apache.kafka.common.acl.AccessControlEntry
 
toString() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
 
toString() - Method in class org.apache.kafka.common.acl.AclBinding
 
toString() - Method in class org.apache.kafka.common.acl.AclBindingFilter
 
toString() - Method in class org.apache.kafka.common.Cluster
 
toString() - Method in class org.apache.kafka.common.ClusterResource
 
toString() - Method in class org.apache.kafka.common.config.ConfigDef.CompositeValidator
 
toString() - Method in class org.apache.kafka.common.config.ConfigDef.NonEmptyString
 
toString() - Method in class org.apache.kafka.common.config.ConfigDef.NonEmptyStringWithoutControlChars
 
toString() - Method in class org.apache.kafka.common.config.ConfigDef.NonNullValidator
 
toString() - Method in class org.apache.kafka.common.config.ConfigDef.Range
 
toString() - Method in class org.apache.kafka.common.config.ConfigDef.ValidList
 
toString() - Method in class org.apache.kafka.common.config.ConfigDef.ValidString
 
toString() - Method in class org.apache.kafka.common.config.ConfigResource
 
toString() - Method in class org.apache.kafka.common.config.ConfigValue
 
toString() - Method in enum org.apache.kafka.common.ConsumerGroupState
 
toString() - Method in class org.apache.kafka.common.MetricName
 
toString() - Method in class org.apache.kafka.common.MetricNameTemplate
 
toString() - Method in class org.apache.kafka.common.Node
 
toString() - Method in class org.apache.kafka.common.PartitionInfo
 
toString() - Method in class org.apache.kafka.common.resource.Resource
 
toString() - Method in class org.apache.kafka.common.resource.ResourceFilter
 
toString() - Method in class org.apache.kafka.common.resource.ResourcePattern
 
toString() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
toString() - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
 
toString() - Method in class org.apache.kafka.common.security.auth.SaslExtensions
 
toString() - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
 
toString() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
toString() - Method in class org.apache.kafka.common.TopicPartition
 
toString() - Method in class org.apache.kafka.common.TopicPartitionInfo
 
toString() - Method in class org.apache.kafka.common.TopicPartitionReplica
 
toString() - Method in class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
 
toString() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
 
totalCount() - Method in class org.apache.kafka.clients.admin.NewPartitions
The total number of partitions after the operation succeeds.
TRANSACTION_TIMEOUT_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
transaction.timeout.ms
TRANSACTION_TIMEOUT_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
 
transactionAborted() - Method in class org.apache.kafka.clients.producer.MockProducer
 
TRANSACTIONAL_ID - org.apache.kafka.common.resource.ResourceType
A transactional ID.
TRANSACTIONAL_ID_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
transactional.id
TRANSACTIONAL_ID_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
 
TransactionalIdAuthorizationException - Exception in org.apache.kafka.common.errors
 
TransactionalIdAuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.TransactionalIdAuthorizationException
 
transactionCommitted() - Method in class org.apache.kafka.clients.producer.MockProducer
 
TransactionCoordinatorFencedException - Exception in org.apache.kafka.common.errors
 
TransactionCoordinatorFencedException(String) - Constructor for exception org.apache.kafka.common.errors.TransactionCoordinatorFencedException
 
TransactionCoordinatorFencedException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.TransactionCoordinatorFencedException
 
transactionInFlight() - Method in class org.apache.kafka.clients.producer.MockProducer
 
transactionInitialized() - Method in class org.apache.kafka.clients.producer.MockProducer
 
transform(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigTransformer
Transforms the given configuration data by using the ConfigProvider instances to look up values to replace the variables in the pattern.
ttl() - Method in class org.apache.kafka.common.config.ConfigData
Returns the TTL (in milliseconds).
ttls() - Method in class org.apache.kafka.common.config.ConfigTransformerResult
Returns the TTL values (in milliseconds) returned from the ConfigProvider instances for a given set of paths.
type - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
type() - Method in class org.apache.kafka.common.config.ConfigResource
Return the resource type.
typeOf(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 

U

unauthorizedTopics() - Method in class org.apache.kafka.common.Cluster
 
unauthorizedTopics() - Method in exception org.apache.kafka.common.errors.TopicAuthorizationException
 
UNCLEAN_LEADER_ELECTION_ENABLE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
UNCLEAN_LEADER_ELECTION_ENABLE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
UNKNOWN - org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
 
UNKNOWN - org.apache.kafka.common.acl.AclOperation
Represents any AclOperation which this client cannot understand, perhaps because this client is too old.
UNKNOWN - org.apache.kafka.common.acl.AclPermissionType
Represents any AclPermissionType which this client cannot understand, perhaps because this client is too old.
UNKNOWN - org.apache.kafka.common.config.ConfigResource.Type
 
UNKNOWN - org.apache.kafka.common.ConsumerGroupState
 
UNKNOWN - org.apache.kafka.common.resource.PatternType
Represents any PatternType which this client cannot understand, perhaps because this client is too old.
UNKNOWN - org.apache.kafka.common.resource.ResourceType
Represents any ResourceType which this client cannot understand, perhaps because this client is too old.
UNKNOWN_PARTITION - Static variable in class org.apache.kafka.clients.producer.RecordMetadata
Partition value for record without partition assigned
UnknownLeaderEpochException - Exception in org.apache.kafka.common.errors
The request contained a leader epoch which is larger than that on the broker that received the request.
UnknownLeaderEpochException(String) - Constructor for exception org.apache.kafka.common.errors.UnknownLeaderEpochException
 
UnknownLeaderEpochException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownLeaderEpochException
 
UnknownMemberIdException - Exception in org.apache.kafka.common.errors
 
UnknownMemberIdException() - Constructor for exception org.apache.kafka.common.errors.UnknownMemberIdException
 
UnknownMemberIdException(String) - Constructor for exception org.apache.kafka.common.errors.UnknownMemberIdException
 
UnknownMemberIdException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownMemberIdException
 
UnknownMemberIdException(Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownMemberIdException
 
UnknownProducerIdException - Exception in org.apache.kafka.common.errors
This exception is raised by the broker if it could not locate the producer metadata associated with the producerId in question.
UnknownProducerIdException(String) - Constructor for exception org.apache.kafka.common.errors.UnknownProducerIdException
 
UnknownServerException - Exception in org.apache.kafka.common.errors
An error occurred on the server for which the client doesn't have a corresponding error code.
UnknownServerException() - Constructor for exception org.apache.kafka.common.errors.UnknownServerException
 
UnknownServerException(String) - Constructor for exception org.apache.kafka.common.errors.UnknownServerException
 
UnknownServerException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownServerException
 
UnknownServerException(Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownServerException
 
UnknownTopicOrPartitionException - Exception in org.apache.kafka.common.errors
This topic/partition doesn't exist.
UnknownTopicOrPartitionException() - Constructor for exception org.apache.kafka.common.errors.UnknownTopicOrPartitionException
 
UnknownTopicOrPartitionException(String) - Constructor for exception org.apache.kafka.common.errors.UnknownTopicOrPartitionException
 
UnknownTopicOrPartitionException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownTopicOrPartitionException
 
UnknownTopicOrPartitionException(Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownTopicOrPartitionException
 
unsubscribe() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
unsubscribe() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Unsubscribe from topics currently subscribed with KafkaConsumer.subscribe(Collection) or KafkaConsumer.subscribe(Pattern).
unsubscribe() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
unsubscribe(String, Set<String>, ConfigChangeCallback) - Method in interface org.apache.kafka.common.config.provider.ConfigProvider
Unsubscribes to changes for the given keys at the given path (optional operation).
unsubscribeAll() - Method in interface org.apache.kafka.common.config.provider.ConfigProvider
Clears all subscribers (optional operation).
UnsupportedByAuthenticationException - Exception in org.apache.kafka.common.errors
Authentication mechanism does not support the requested function.
UnsupportedByAuthenticationException(String) - Constructor for exception org.apache.kafka.common.errors.UnsupportedByAuthenticationException
 
UnsupportedByAuthenticationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnsupportedByAuthenticationException
 
UnsupportedCompressionTypeException - Exception in org.apache.kafka.common.errors
The requesting client does not support the compression type of given partition.
UnsupportedCompressionTypeException(String) - Constructor for exception org.apache.kafka.common.errors.UnsupportedCompressionTypeException
 
UnsupportedCompressionTypeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnsupportedCompressionTypeException
 
UnsupportedForMessageFormatException - Exception in org.apache.kafka.common.errors
The message format version does not support the requested function.
UnsupportedForMessageFormatException(String) - Constructor for exception org.apache.kafka.common.errors.UnsupportedForMessageFormatException
 
UnsupportedForMessageFormatException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnsupportedForMessageFormatException
 
UnsupportedSaslMechanismException - Exception in org.apache.kafka.common.errors
This exception indicates that the SASL mechanism requested by the client is not enabled on the broker.
UnsupportedSaslMechanismException(String) - Constructor for exception org.apache.kafka.common.errors.UnsupportedSaslMechanismException
 
UnsupportedSaslMechanismException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnsupportedSaslMechanismException
 
UnsupportedVersionException - Exception in org.apache.kafka.common.errors
Indicates that a request API or version needed by the client is not supported by the broker.
UnsupportedVersionException(String) - Constructor for exception org.apache.kafka.common.errors.UnsupportedVersionException
 
UnsupportedVersionException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnsupportedVersionException
 
unused() - Method in class org.apache.kafka.common.config.AbstractConfig
 
updateBeginningOffsets(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
updateClusterMetadata(Cluster) - Method in interface org.apache.kafka.server.quota.ClientQuotaCallback
Metadata update callback that is invoked whenever UpdateMetadata request is received from the controller.
updateEndOffsets(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
updatePartitions(String, List<PartitionInfo>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
updateQuota(ClientQuotaType, ClientQuotaEntity, double) - Method in interface org.apache.kafka.server.quota.ClientQuotaCallback
Quota configuration update callback that is invoked when quota configuration for an entity is updated in ZooKeeper.
USER - org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
 
USER_TYPE - Static variable in class org.apache.kafka.common.security.auth.KafkaPrincipal
 
UUID() - Static method in class org.apache.kafka.common.serialization.Serdes
 
UUIDDeserializer - Class in org.apache.kafka.common.serialization
We are converting the byte array to String before deserializing to UUID.
UUIDDeserializer() - Constructor for class org.apache.kafka.common.serialization.UUIDDeserializer
 
UUIDSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.UUIDSerde
 
UUIDSerializer - Class in org.apache.kafka.common.serialization
We are converting UUID to String before serializing.
UUIDSerializer() - Constructor for class org.apache.kafka.common.serialization.UUIDSerializer
 

V

valid() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsResult
Returns a future which yields just the valid listings.
valid(String) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
Validates a specific extension in the original inputExtensions map
validate(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
Validate the current configuration values with the configuration definition.
validate(AlterConfigPolicy.RequestMetadata) - Method in interface org.apache.kafka.server.policy.AlterConfigPolicy
Validate the request parameters and throw a PolicyViolationException with a suitable error message if the alter configs request parameters for the provided resource do not satisfy this policy.
validate(CreateTopicPolicy.RequestMetadata) - Method in interface org.apache.kafka.server.policy.CreateTopicPolicy
Validate the request parameters and throw a PolicyViolationException with a suitable error message if the create topics request parameters for the provided topic do not satisfy this policy.
validateAll(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
 
validatedExtensions() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
 
validateOnly() - Method in class org.apache.kafka.clients.admin.CreatePartitionsOptions
Return true if the request should be validated without creating new partitions.
validateOnly(boolean) - Method in class org.apache.kafka.clients.admin.AlterConfigsOptions
Set to true if the request should be validated without altering the configs.
validateOnly(boolean) - Method in class org.apache.kafka.clients.admin.CreatePartitionsOptions
Set to true if the request should be validated without creating new partitions.
validateOnly(boolean) - Method in class org.apache.kafka.clients.admin.CreateTopicsOptions
Set to true if the request should be validated without creating the topic.
validateReconfiguration(Map<String, ?>) - Method in interface org.apache.kafka.common.Reconfigurable
Validates the provided configuration.
validator - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
validValues(String, Map<String, Object>) - Method in interface org.apache.kafka.common.config.ConfigDef.Recommender
The valid values for the configuration given the current configuration values.
value() - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
Returns the value of this configuration, which may be null if the configuration is sensitive.
value() - Method in class org.apache.kafka.clients.admin.ConfigEntry
Return the value or null.
value() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The value
value() - Method in class org.apache.kafka.clients.producer.ProducerRecord
 
value() - Method in class org.apache.kafka.common.config.ConfigValue
 
value() - Method in interface org.apache.kafka.common.header.Header
 
value() - Method in interface org.apache.kafka.common.Metric
Deprecated.
As of 1.0.0, use Metric.metricValue() instead. This will be removed in a future major release.
value() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
The b64token value as defined in RFC 6750 Section 2.1
value(Object) - Method in class org.apache.kafka.common.config.ConfigValue
 
VALUE_DESERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
value.deserializer
VALUE_DESERIALIZER_CLASS_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
 
VALUE_SERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
value.serializer
VALUE_SERIALIZER_CLASS_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
 
valueOf(String) - Static method in enum org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.clients.consumer.OffsetResetStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.acl.AclOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.acl.AclPermissionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.config.ConfigDef.Importance
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.config.ConfigDef.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.config.ConfigDef.Width
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.config.ConfigResource.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.ConsumerGroupState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.resource.PatternType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.resource.ResourceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.server.quota.ClientQuotaType
Returns the enum constant of this type with the specified name.
values() - Method in class org.apache.kafka.clients.admin.AlterConfigsResult
Return a map from resources to futures which can be used to check the status of the operation on each resource.
values() - Method in class org.apache.kafka.clients.admin.AlterReplicaLogDirsResult
Return a map from replica to future which can be used to check the status of individual replica movement.
values() - Static method in enum org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.kafka.clients.admin.CreateAclsResult
Return a map from ACL bindings to futures which can be used to check the status of the creation of each ACL binding.
values() - Method in class org.apache.kafka.clients.admin.CreatePartitionsResult
Return a map from topic names to futures, which can be used to check the status of individual partition creations.
values() - Method in class org.apache.kafka.clients.admin.CreateTopicsResult
Return a map from topic names to futures, which can be used to check the status of individual topic creations.
values() - Method in class org.apache.kafka.clients.admin.DeleteAclsResult.FilterResults
Return a list of delete ACLs results for a given filter.
values() - Method in class org.apache.kafka.clients.admin.DeleteAclsResult
Return a map from acl filters to futures which can be used to check the status of the deletions by each filter.
values() - Method in class org.apache.kafka.clients.admin.DeleteTopicsResult
Return a map from topic names to futures which can be used to check the status of individual deletions.
values() - Method in class org.apache.kafka.clients.admin.DescribeAclsResult
Return a future containing the ACLs requested.
values() - Method in class org.apache.kafka.clients.admin.DescribeConfigsResult
Return a map from resources to futures which can be used to check the status of the configuration for each resource.
values() - Method in class org.apache.kafka.clients.admin.DescribeLogDirsResult
Return a map from brokerId to future which can be used to check the information of partitions on each individual broker
values() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult
Return a map from replica to future which can be used to check the log directory information of individual replicas
values() - Method in class org.apache.kafka.clients.admin.DescribeTopicsResult
Return a map from topic names to futures which can be used to check the status of individual topics.
values() - Static method in enum org.apache.kafka.clients.consumer.OffsetResetStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.acl.AclOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.acl.AclPermissionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.kafka.common.config.AbstractConfig
 
values() - Static method in enum org.apache.kafka.common.config.ConfigDef.Importance
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.config.ConfigDef.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.config.ConfigDef.Width
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.config.ConfigResource.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.ConsumerGroupState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.resource.PatternType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.resource.ResourceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.server.quota.ClientQuotaType
Returns an array containing the constants of this enum type, in the order they are declared.
valuesWithPrefixAllOrNothing(String) - Method in class org.apache.kafka.common.config.AbstractConfig
If at least one key with prefix exists, all prefixed values will be parsed and put into map.
valuesWithPrefixOverride(String) - Method in class org.apache.kafka.common.config.AbstractConfig
Put all keys that do not start with prefix and their parsed values in the result map and then put all the remaining keys with the prefix stripped and their parsed values in the result map.
visible() - Method in class org.apache.kafka.common.config.ConfigValue
 
visible(boolean) - Method in class org.apache.kafka.common.config.ConfigValue
 
visible(String, Map<String, Object>) - Method in interface org.apache.kafka.common.config.ConfigDef.Recommender
Set the visibility of the configuration given the current configuration values.

W

wakeup() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
wakeup() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Wakeup the consumer.
wakeup() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
wakeup() - Method in interface org.apache.kafka.common.GenericCoordinator
 
WakeupException - Exception in org.apache.kafka.common.errors
Exception used to indicate preemption of a blocking operation by an external thread.
WakeupException() - Constructor for exception org.apache.kafka.common.errors.WakeupException
 
whenComplete(KafkaFuture.BiConsumer<? super T, ? super Throwable>) - Method in class org.apache.kafka.common.KafkaFuture
Returns a new KafkaFuture with the same result or exception as this future, that executes the given action when this future completes.
width - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
WILDCARD_RESOURCE - Static variable in class org.apache.kafka.common.resource.ResourcePattern
A special literal resource name that corresponds to 'all resources of a certain type'.
withClientSaslSupport() - Method in class org.apache.kafka.common.config.ConfigDef
Add standard SASL client configuration options.
withClientSslSupport() - Method in class org.apache.kafka.common.config.ConfigDef
Add standard SSL client configuration options.
withPartitions(Map<TopicPartition, PartitionInfo>) - Method in class org.apache.kafka.common.Cluster
Return a copy of this cluster combined with `partitions`.
withUnderlyingMessage(String) - Static method in exception org.apache.kafka.clients.consumer.RetriableCommitFailedException
 
Wrapper(Deserializer<T>) - Constructor for class org.apache.kafka.common.serialization.ExtendedDeserializer.Wrapper
Deprecated.
 
Wrapper(Serializer<T>) - Constructor for class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
Deprecated.
 
WrapperSerde(Serializer<T>, Deserializer<T>) - Constructor for class org.apache.kafka.common.serialization.Serdes.WrapperSerde
 
WRITE - org.apache.kafka.common.acl.AclOperation
WRITE operation.
A B C D E F G H I K L M N O P Q R S T U V W 
All Classes All Packages