Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
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
- 
Aborts the ongoing transaction.
- abortTransaction() - Method in class org.apache.kafka.clients.producer.MockProducer
- abortTransaction() - Method in interface org.apache.kafka.clients.producer.Producer
- abortTransaction() - Method in interface org.apache.kafka.connect.source.TransactionContext
- 
Requests a transaction abort after the next batch of records fromSourceTask.poll().
- abortTransaction(AbortTransactionSpec) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Forcefully abort a transaction which is open on a topic partition.
- abortTransaction(AbortTransactionSpec, AbortTransactionOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Forcefully abort a transaction which is open on a topic partition.
- abortTransaction(AbortTransactionSpec, AbortTransactionOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- abortTransaction(AbortTransactionSpec, AbortTransactionOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- abortTransaction(SourceRecord) - Method in interface org.apache.kafka.connect.source.TransactionContext
- 
Requests a transaction abort after a source record is processed.
- abortTransactionException - Variable in class org.apache.kafka.clients.producer.MockProducer
- AbortTransactionOptions - Class in org.apache.kafka.clients.admin
- AbortTransactionOptions() - Constructor for class org.apache.kafka.clients.admin.AbortTransactionOptions
- AbortTransactionResult - Class in org.apache.kafka.clients.admin
- AbortTransactionSpec - Class in org.apache.kafka.clients.admin
- AbortTransactionSpec(TopicPartition, long, short, int) - Constructor for class org.apache.kafka.clients.admin.AbortTransactionSpec
- 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
- 
Construct a configuration with a ConfigDef and the configuration properties, which can include properties for zero or moreConfigProviderthat will be used to resolve variables in configuration property values.
- AbstractConfig(ConfigDef, Map<?, ?>, boolean) - Constructor for class org.apache.kafka.common.config.AbstractConfig
- 
Construct a configuration with a ConfigDef and the configuration properties, which can include properties for zero or moreConfigProviderthat will be used to resolve variables in configuration property values.
- AbstractConfig(ConfigDef, Map<?, ?>, Map<String, ?>, boolean) - Constructor for class org.apache.kafka.common.config.AbstractConfig
- 
Construct a configuration with a ConfigDef and the configuration properties, which can include properties for zero or moreConfigProviderthat will be used to resolve variables in configuration property values.
- AbstractOptions<T> - Class in org.apache.kafka.clients.admin
- AbstractOptions() - Constructor for class org.apache.kafka.clients.admin.AbstractOptions
- AbstractState - Class in org.apache.kafka.connect.health
- 
Provides the current status for a connector or a task, along with an identifier for its Connect worker
- AbstractState(String, String, String) - Constructor for class org.apache.kafka.connect.health.AbstractState
- 
Construct a state for a connector or task.
- accept(A, B) - Method in interface org.apache.kafka.common.KafkaFuture.BiConsumer
- ACCEPT - Enum constant in enum class org.apache.kafka.clients.consumer.AcknowledgeType
- 
The record was consumed successfully.
- acceptable(double) - Method in class org.apache.kafka.common.metrics.Quota
- ACCEPTABLE_RECOVERY_LAG_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
acceptable.recovery.lag
- acceptableRecoveryLag() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- 
The configured acceptable recovery lag according toStreamsConfig.ACCEPTABLE_RECOVERY_LAG_CONFIG
- accepts(StateStore) - Method in interface org.apache.kafka.streams.state.QueryableStoreType
- 
Called when searching forStateStores to see if they match the type expected by implementors of this interface.
- accepts(StateStore) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.KeyValueStoreType
- accepts(StateStore) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.SessionStoreType
- accepts(StateStore) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.WindowStoreType
- 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.
- acknowledge(ConsumerRecord<K, V>) - Method in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- 
Acknowledge successful delivery of a record returned on the lastKafkaShareConsumer.poll(Duration)call.
- acknowledge(ConsumerRecord<K, V>) - Method in class org.apache.kafka.clients.consumer.MockShareConsumer
- acknowledge(ConsumerRecord<K, V>) - Method in interface org.apache.kafka.clients.consumer.ShareConsumer
- acknowledge(ConsumerRecord<K, V>, AcknowledgeType) - Method in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- 
Acknowledge delivery of a record returned on the lastKafkaShareConsumer.poll(Duration)call indicating whether it was processed successfully.
- acknowledge(ConsumerRecord<K, V>, AcknowledgeType) - Method in class org.apache.kafka.clients.consumer.MockShareConsumer
- acknowledge(ConsumerRecord<K, V>, AcknowledgeType) - Method in interface org.apache.kafka.clients.consumer.ShareConsumer
- AcknowledgementCommitCallback - Interface in org.apache.kafka.clients.consumer
- 
A callback interface that the user can implement to trigger custom actions when an acknowledgement completes.
- AcknowledgeType - Enum Class in org.apache.kafka.clients.consumer
- Acknowledging a batch of records (implicit acknowledgement) - Search tag in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- Section
- ACKS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
acks
- aclBinding() - Method in class org.apache.kafka.server.authorizer.AclDeleteResult.AclBindingDeleteResult
- 
Returns ACL binding that matched the delete filter.
- 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.
- AclBindingDeleteResult(AclBinding) - Constructor for class org.apache.kafka.server.authorizer.AclDeleteResult.AclBindingDeleteResult
- AclBindingDeleteResult(AclBinding, ApiException) - Constructor for class org.apache.kafka.server.authorizer.AclDeleteResult.AclBindingDeleteResult
- aclBindingDeleteResults() - Method in class org.apache.kafka.server.authorizer.AclDeleteResult
- 
Returns delete result for each matching ACL binding.
- AclBindingFilter - Class in org.apache.kafka.common.acl
- 
A filter which can match AclBinding objects.
- AclBindingFilter(ResourcePatternFilter, AccessControlEntryFilter) - Constructor for class org.apache.kafka.common.acl.AclBindingFilter
- 
Create an instance of this filter with the provided parameters.
- aclCount() - Method in interface org.apache.kafka.server.authorizer.Authorizer
- 
Get the current number of ACLs, for the purpose of metrics.
- AclCreateResult - Class in org.apache.kafka.server.authorizer
- AclCreateResult(ApiException) - Constructor for class org.apache.kafka.server.authorizer.AclCreateResult
- AclDeleteResult - Class in org.apache.kafka.server.authorizer
- AclDeleteResult(Collection<AclDeleteResult.AclBindingDeleteResult>) - Constructor for class org.apache.kafka.server.authorizer.AclDeleteResult
- AclDeleteResult(ApiException) - Constructor for class org.apache.kafka.server.authorizer.AclDeleteResult
- AclDeleteResult.AclBindingDeleteResult - Class in org.apache.kafka.server.authorizer
- 
Delete result for each ACL binding that matched a delete filter.
- AclOperation - Enum Class in org.apache.kafka.common.acl
- 
Represents an operation which an ACL grants or denies permission to perform.
- AclPermissionType - Enum Class in org.apache.kafka.common.acl
- 
Represents whether an ACL grants or denies permissions.
- acls(AclBindingFilter) - Method in interface org.apache.kafka.server.authorizer.Authorizer
- 
Returns ACL bindings which match the provided filter.
- Action - Class in org.apache.kafka.server.authorizer
- Action(AclOperation, ResourcePattern, int, boolean, boolean) - Constructor for class org.apache.kafka.server.authorizer.Action
- ACTIVE - Enum constant in enum class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask.Type
- ACTIVE_TASK_ASSIGNED_MULTIPLE_TIMES - Enum constant in enum class org.apache.kafka.streams.processor.assignment.TaskAssignor.AssignmentError
- activeHost() - Method in class org.apache.kafka.streams.KeyQueryMetadata
- 
Get the active Kafka Streams instance for given key.
- activeProducers() - Method in class org.apache.kafka.clients.admin.DescribeProducersResult.PartitionProducerState
- activeTasks() - Method in interface org.apache.kafka.streams.ThreadMetadata
- 
Metadata of the active tasks assigned to the stream thread.
- 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(String, Object, Schema) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- add(String, Object, Schema) - Method in interface org.apache.kafka.connect.header.Headers
- 
Add to this collection aHeaderwith the given key and value.
- add(String, SchemaAndValue) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- add(String, SchemaAndValue) - Method in interface org.apache.kafka.connect.header.Headers
- 
Add to this collection aHeaderwith the given key and value.
- add(Header) - Method in interface org.apache.kafka.common.header.Headers
- 
Adds a header (key inside), to the end, returning if the operation succeeded.
- add(MetricName, MeasurableStat) - Method in class org.apache.kafka.common.metrics.Sensor
- 
Register a metric with this sensor
- add(MetricName, MeasurableStat, MetricConfig) - Method in class org.apache.kafka.common.metrics.Sensor
- 
Register a metric with this sensor
- add(CompoundStat) - Method in class org.apache.kafka.common.metrics.Sensor
- 
Register a compound statistic with this sensor with no config override
- add(CompoundStat, MetricConfig) - Method in class org.apache.kafka.common.metrics.Sensor
- 
Register a compound statistic with this sensor which yields multiple measurable quantities (like a histogram)
- add(Header) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- add(Header) - Method in interface org.apache.kafka.connect.header.Headers
- 
Add the givenHeaderto this collection.
- addBoolean(String, boolean) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addBoolean(String, boolean) - Method in interface org.apache.kafka.connect.header.Headers
- 
Add to this collection aHeaderwith the given key and value.
- addByte(String, byte) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addByte(String, byte) - Method in interface org.apache.kafka.connect.header.Headers
- 
Add to this collection aHeaderwith the given key and value.
- addBytes(String, byte[]) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addBytes(String, byte[]) - Method in interface org.apache.kafka.connect.header.Headers
- 
Add to this collection aHeaderwith the given key and value.
- addClientSaslSupport(ConfigDef) - Static method in class org.apache.kafka.common.config.SaslConfigs
- addClientSslSupport(ConfigDef) - Static method in class org.apache.kafka.common.config.SslConfigs
- addDate(String, Date) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addDate(String, Date) - Method in interface org.apache.kafka.connect.header.Headers
- addDecimal(String, BigDecimal) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addDecimal(String, BigDecimal) - Method in interface org.apache.kafka.connect.header.Headers
- addDouble(String, double) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addDouble(String, double) - Method in interface org.apache.kafka.connect.header.Headers
- 
Add to this collection aHeaderwith the given key and value.
- addedMetrics() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- addedMetrics() - Method in class org.apache.kafka.clients.producer.MockProducer
- addErrorMessage(String) - Method in class org.apache.kafka.common.config.ConfigValue
- addExecutionInfo(String) - Method in interface org.apache.kafka.streams.query.QueryResult
- 
Used by stores to add detailed execution information (if requested) during query execution.
- addFloat(String, float) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addFloat(String, float) - Method in interface org.apache.kafka.connect.header.Headers
- 
Add to this collection aHeaderwith the given key and value.
- addGlobalStore(StoreBuilder<?>, String, Deserializer<KIn>, Deserializer<VIn>, String, String, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class org.apache.kafka.streams.Topology
- 
Adds a globalstate storeto the topology.
- addGlobalStore(StoreBuilder<?>, String, Consumed<KIn, VIn>, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Adds a globalStateStoreto the topology.
- addGlobalStore(StoreBuilder<?>, String, TimestampExtractor, Deserializer<KIn>, Deserializer<VIn>, String, String, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class org.apache.kafka.streams.Topology
- addingReplicas() - Method in class org.apache.kafka.clients.admin.PartitionReassignment
- 
The brokers that we are adding this partition to as part of a reassignment.
- addInt(String, int) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addInt(String, int) - Method in interface org.apache.kafka.connect.header.Headers
- 
Add to this collection aHeaderwith the given key and value.
- addLatencyRateTotalSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
- 
Add a latency, rate and total sensor for a specific operation, which will include the following metrics: average latency max latency invocation rate (num.operations / seconds) total invocation count Whenever a user records this sensor viaSensor.record(double)etc., it will be counted as one invocation of the operation, and hence the rate / count metrics will be updated accordingly; and the recorded latency value will be used to update the average / max latency as well.
- addList(String, List<?>, Schema) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addList(String, List<?>, Schema) - Method in interface org.apache.kafka.connect.header.Headers
- 
Add to this collection aHeaderwith the given key and value.
- addLong(String, long) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addLong(String, long) - Method in interface org.apache.kafka.connect.header.Headers
- 
Add to this collection aHeaderwith the given key and value.
- addMap(String, Map<?, ?>, Schema) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addMap(String, Map<?, ?>, Schema) - Method in interface org.apache.kafka.connect.header.Headers
- 
Add to this collection aHeaderwith the given key and value.
- addMetric(MetricName, Measurable) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Add a metric to monitor an object that implements measurable.
- addMetric(MetricName, MetricConfig, Measurable) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Add a metric to monitor an object that implements Measurable.
- addMetric(MetricName, MetricConfig, MetricValueProvider<?>) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Add a metric to monitor an object that implements MetricValueProvider.
- addMetric(MetricName, MetricValueProvider<?>) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Add a metric to monitor an object that implements MetricValueProvider.
- addMetricIfAbsent(MetricName, MetricConfig, MetricValueProvider<?>) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Create or get an existing metric to monitor an object that implements MetricValueProvider.
- addProcessor(String, ProcessorSupplier<KIn, VIn, KOut, VOut>, String...) - Method in class org.apache.kafka.streams.Topology
- addRaftVoter(int, Uuid, Set<RaftVoterEndpoint>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Add a new voter node to the KRaft metadata quorum.
- addRaftVoter(int, Uuid, Set<RaftVoterEndpoint>, AddRaftVoterOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Add a new voter node to the KRaft metadata quorum.
- addRaftVoter(int, Uuid, Set<RaftVoterEndpoint>, AddRaftVoterOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- addRaftVoter(int, Uuid, Set<RaftVoterEndpoint>, AddRaftVoterOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- AddRaftVoterOptions - Class in org.apache.kafka.clients.admin
- AddRaftVoterOptions() - Constructor for class org.apache.kafka.clients.admin.AddRaftVoterOptions
- AddRaftVoterResult - Class in org.apache.kafka.clients.admin
- addRateTotalSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
- 
Add a rate and a total sensor for a specific operation, which will include the following metrics: invocation rate (num.operations / time unit) total invocation count Whenever a user records this sensor viaSensor.record(double)etc., it will be counted as one invocation of the operation, and hence the rate / count metrics will be updated accordingly.
- addReadOnlyStateStore(StoreBuilder<?>, String, Deserializer<KIn>, Deserializer<VIn>, String, String, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class org.apache.kafka.streams.Topology
- 
Adds a read-onlystate storeto the topology.
- addReadOnlyStateStore(StoreBuilder<?>, String, TimestampExtractor, Deserializer<KIn>, Deserializer<VIn>, String, String, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class org.apache.kafka.streams.Topology
- addRecord(ConsumerRecord<K, V>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- addRecord(ConsumerRecord<K, V>) - Method in class org.apache.kafka.clients.consumer.MockShareConsumer
- addRemoteLogSegmentMetadata(RemoteLogSegmentMetadata) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
- 
This method is used to addRemoteLogSegmentMetadataasynchronously with the containingRemoteLogSegmentIdintoRemoteLogMetadataManager.
- addReporter(MetricsReporter) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Add a MetricReporter
- addResult(int, QueryResult<R>) - Method in class org.apache.kafka.streams.query.StateQueryResult
- 
Set the result for a partitioned store query.
- addSensor(String, Sensor.RecordingLevel) - Method in interface org.apache.kafka.streams.StreamsMetrics
- 
Generic method to create a sensor.
- addSensor(String, Sensor.RecordingLevel, Sensor...) - Method in interface org.apache.kafka.streams.StreamsMetrics
- 
Generic method to create a sensor with parent sensors.
- addShort(String, short) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addShort(String, short) - Method in interface org.apache.kafka.connect.header.Headers
- 
Add to this collection aHeaderwith the given key and value.
- addSink(String, String, String...) - Method in class org.apache.kafka.streams.Topology
- 
Add a sink that sends records from upstreamprocessorsorsourcesto the named Kafka topic.
- addSink(String, String, Serializer<K>, Serializer<V>, String...) - Method in class org.apache.kafka.streams.Topology
- addSink(String, String, Serializer<K>, Serializer<V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
- addSink(String, String, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
- addSink(String, TopicNameExtractor<K, V>, String...) - Method in class org.apache.kafka.streams.Topology
- addSink(String, TopicNameExtractor<K, V>, Serializer<K>, Serializer<V>, String...) - Method in class org.apache.kafka.streams.Topology
- addSink(String, TopicNameExtractor<K, V>, Serializer<K>, Serializer<V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
- addSink(String, TopicNameExtractor<K, V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
- addSource(String, String...) - Method in class org.apache.kafka.streams.Topology
- 
Add a source that consumes the named topics and forwards the records to childprocessorsandsinks.
- addSource(String, Pattern) - Method in class org.apache.kafka.streams.Topology
- addSource(String, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
- addSource(String, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
- addSource(AutoOffsetReset, String, String...) - Method in class org.apache.kafka.streams.Topology
- addSource(AutoOffsetReset, String, Pattern) - Method in class org.apache.kafka.streams.Topology
- addSource(AutoOffsetReset, String, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
- addSource(AutoOffsetReset, String, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
- addSource(AutoOffsetReset, String, TimestampExtractor, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
- addSource(AutoOffsetReset, String, TimestampExtractor, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
- addSource(AutoOffsetReset, TimestampExtractor, String, String...) - Method in class org.apache.kafka.streams.Topology
- addSource(AutoOffsetReset, TimestampExtractor, String, Pattern) - Method in class org.apache.kafka.streams.Topology
- addSource(TimestampExtractor, String, String...) - Method in class org.apache.kafka.streams.Topology
- addSource(TimestampExtractor, String, Pattern) - Method in class org.apache.kafka.streams.Topology
- addSource(Topology.AutoOffsetReset, String, String...) - Method in class org.apache.kafka.streams.Topology
- 
Deprecated.
- addSource(Topology.AutoOffsetReset, String, Pattern) - Method in class org.apache.kafka.streams.Topology
- 
Deprecated.Since 4.0. UseTopology.addSource(org.apache.kafka.streams.AutoOffsetReset, String, Pattern)instead.
- addSource(Topology.AutoOffsetReset, String, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
- 
Deprecated.
- addSource(Topology.AutoOffsetReset, String, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
- 
Deprecated.
- addSource(Topology.AutoOffsetReset, String, TimestampExtractor, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
- 
Deprecated.
- addSource(Topology.AutoOffsetReset, String, TimestampExtractor, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
- 
Deprecated.
- addSource(Topology.AutoOffsetReset, TimestampExtractor, String, String...) - Method in class org.apache.kafka.streams.Topology
- 
Deprecated.
- addSource(Topology.AutoOffsetReset, TimestampExtractor, String, Pattern) - Method in class org.apache.kafka.streams.Topology
- 
Deprecated.
- addStateStore(StoreBuilder<?>) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Adds a state store to the underlyingTopology.
- addStateStore(StoreBuilder<?>, String...) - Method in class org.apache.kafka.streams.Topology
- 
Add astate storeto the topology, and optionally connect it to one or moreprocessors.
- addStateStore(S) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- addStreamThread() - Method in class org.apache.kafka.streams.KafkaStreams
- 
Adds and starts a stream thread in addition to the stream threads that are already running in this Kafka Streams client.
- addString(String, String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addString(String, String) - Method in interface org.apache.kafka.connect.header.Headers
- 
Add to this collection aHeaderwith the given key and value.
- addStruct(String, Struct) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addStruct(String, Struct) - Method in interface org.apache.kafka.connect.header.Headers
- 
Add to this collection aHeaderwith the given key and value.
- addTime(String, Date) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addTime(String, Date) - Method in interface org.apache.kafka.connect.header.Headers
- addTimestamp(String, Date) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addTimestamp(String, Date) - Method in interface org.apache.kafka.connect.header.Headers
- Admin - Interface in org.apache.kafka.clients.admin
- 
The administrative client for Kafka, which supports managing and inspecting topics, brokers, configurations and ACLs.
- ADMIN - Enum constant in enum class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
- ADMIN_CLIENT_PREFIX - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- ADMIN_CLIENT_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Prefix used to isolateadminconfigs from other client configs.
- AdminClient - Class in org.apache.kafka.clients.admin
- 
The base class for in-built admin clients.
- AdminClient() - Constructor for class org.apache.kafka.clients.admin.AdminClient
- 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
- adminClientId() - Method in interface org.apache.kafka.streams.ThreadMetadata
- 
Client ID of the admin client used by the stream thread.
- adminClientPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
- 
Prefix a property withStreamsConfig.ADMIN_CLIENT_PREFIX.
- adminConfig() - Method in class org.apache.kafka.connect.mirror.MirrorClientConfig
- 
Sub-config for Admin clients.
- adminInstanceId() - Method in interface org.apache.kafka.streams.ClientInstanceIds
- 
Returns theclient instance idof the admin client.
- advanceBy(Duration) - Method in class org.apache.kafka.streams.kstream.TimeWindows
- 
Return a window definition with the original size, but advance ("hop") the window by the given interval, which specifies by how much a window moves forward relative to the previous one.
- advanceMs - Variable in class org.apache.kafka.streams.kstream.TimeWindows
- 
The size of the window's advance interval in milliseconds, i.e., by how much a window moves forward relative to the previous one.
- advanceTime(Duration) - Method in class org.apache.kafka.streams.TestInputTopic
- 
Advances the internally tracked event time of this input topic.
- advanceWallClockTime(Duration) - Method in class org.apache.kafka.streams.TopologyTestDriver
- 
Advances the internally mocked wall-clock time.
- after(Duration) - Method in class org.apache.kafka.streams.kstream.JoinWindows
- 
Changes the end window boundary totimeDifferencebut keep the start window boundary as is.
- afterMs - Variable in class org.apache.kafka.streams.kstream.JoinWindows
- 
Maximum time difference for tuples that are after the join tuple.
- aggregate(Initializer<V>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedCogroupedKStream
- 
Aggregate the values of records in this stream by the grouped key and defined windows.
- aggregate(Initializer<V>, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedCogroupedKStream
- 
Aggregate the values of records in this stream by the grouped key and defined windows.
- aggregate(Initializer<V>, Merger<? super K, V>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedCogroupedKStream
- 
Aggregate the values of records in these streams by the grouped key and defined sessions.
- aggregate(Initializer<V>, Merger<? super K, V>, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedCogroupedKStream
- 
Aggregate the values of records in these streams by the grouped key and defined sessions.
- aggregate(Initializer<V>, Merger<? super K, V>, Named) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedCogroupedKStream
- 
Aggregate the values of records in these streams by the grouped key and defined sessions.
- aggregate(Initializer<V>, Merger<? super K, V>, Named, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedCogroupedKStream
- 
Aggregate the values of records in these streams by the grouped key and defined sessions.
- aggregate(Initializer<V>, Named) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedCogroupedKStream
- 
Aggregate the values of records in this stream by the grouped key and defined windows.
- aggregate(Initializer<V>, Named, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedCogroupedKStream
- 
Aggregate the values of records in this stream by the grouped key and defined windows.
- aggregate(Initializer<VAgg>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
- 
Aggregate the values of records in these streams by the grouped key.
- aggregate(Initializer<VAgg>, Materialized<K, VAgg, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
- 
Aggregate the values of records in these streams by the grouped key.
- aggregate(Initializer<VAgg>, Named) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
- 
Aggregate the values of records in these streams by the grouped key.
- aggregate(Initializer<VAgg>, Named, Materialized<K, VAgg, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
- 
Aggregate the values of records in these streams by the grouped key.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
- 
Aggregate the values of records in this stream by the grouped key.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
- 
Aggregate the values of records in this stream by the grouped key and defined windows.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
- 
Aggregate the values of records in this stream by the grouped key.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
- 
Aggregate the values of records in this stream by the grouped key and defined windows.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
- 
Aggregate the values of records in this stream by the grouped key and defined sessions.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Materialized<K, VR, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
- 
Aggregate the values of records in this stream by the grouped key and defined sessions.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
- 
Aggregate the values of records in this stream by the grouped key and defined sessions.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Named, Materialized<K, VR, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
- 
Aggregate the values of records in this stream by the grouped key and defined sessions.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
- 
Aggregate the values of records in this stream by the grouped key and defined windows.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
- 
Aggregate the values of records in this stream by the grouped key.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
- 
Aggregate the values of records in this stream by the grouped key and defined windows.
- Aggregator<K,V, - Interface in org.apache.kafka.streams.kstreamVAgg> 
- 
TheAggregatorinterface for aggregating values of the given key.
- all() - Method in class org.apache.kafka.clients.admin.AbortTransactionResult
- 
Get a future which completes when the transaction specified byAbortTransactionSpecin the respective call toAdmin.abortTransaction(AbortTransactionSpec, AbortTransactionOptions)returns successfully or fails due to an error or timeout.
- all() - Method in class org.apache.kafka.clients.admin.AddRaftVoterResult
- 
Returns a future that completes when the voter has been added.
- all() - Method in class org.apache.kafka.clients.admin.AlterClientQuotasResult
- 
Returns a future which succeeds only if all quota alterations succeed.
- 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.AlterConsumerGroupOffsetsResult
- 
Return a future which succeeds if all the alter offsets succeed.
- all() - Method in class org.apache.kafka.clients.admin.AlterPartitionReassignmentsResult
- 
Return a future which succeeds only if all the reassignments were successfully initiated.
- all() - Method in class org.apache.kafka.clients.admin.AlterReplicaLogDirsResult
- 
Return aKafkaFuturewhich succeeds onKafkaFuture.get()if all the replica movement have succeeded.
- all() - Method in class org.apache.kafka.clients.admin.AlterUserScramCredentialsResult
- 
Return a future which succeeds only if all the user SCRAM credential alterations succeed.
- 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.DeleteConsumerGroupOffsetsResult
- 
Return a future which succeeds only if all the deletions succeed.
- 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
- all() - Method in class org.apache.kafka.clients.admin.DescribeClassicGroupsResult
- 
Return a future which yields all ClassicGroupDescription objects, if all the describes 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.DescribeProducersResult
- 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.DescribeShareGroupsResult
- 
Return a future which yields all ShareGroupDescription objects, if all the describes succeed.
- all() - Method in class org.apache.kafka.clients.admin.DescribeTransactionsResult
- 
Get a future which returns a map of the transaction descriptions requested in the respective call toAdmin.describeTransactions(Collection, DescribeTransactionsOptions).
- all() - Method in class org.apache.kafka.clients.admin.DescribeUserScramCredentialsResult
- all() - Method in class org.apache.kafka.clients.admin.ElectLeadersResult
- 
Return a future which succeeds if all the topic elections succeed.
- all() - Method in class org.apache.kafka.clients.admin.FenceProducersResult
- 
Return a future which succeeds only if all the producer fencings succeed.
- all() - Method in class org.apache.kafka.clients.admin.ListClientMetricsResourcesResult
- 
Returns a future that yields either an exception, or the full set of client metrics listings.
- all() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsResult
- 
Return a future which yields allMap<String, Map<TopicPartition, OffsetAndMetadata>objects, if requests for all the groups 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() - Method in class org.apache.kafka.clients.admin.ListGroupsResult
- 
Returns a future that yields either an exception, or the full set of group listings.
- all() - Method in class org.apache.kafka.clients.admin.ListOffsetsResult
- 
Return a future which succeeds only if offsets for all specified partitions have been successfully retrieved.
- all() - Method in class org.apache.kafka.clients.admin.ListTransactionsResult
- 
Get all transaction listings.
- all() - Method in class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupResult
- 
Returns a future which indicates whether the request was 100% success, i.e.
- all() - Method in class org.apache.kafka.clients.admin.RemoveRaftVoterResult
- 
Returns a future that completes when the voter has been removed.
- all() - Method in class org.apache.kafka.clients.admin.UnregisterBrokerResult
- 
Return a future which succeeds if the operation is successful.
- all() - Method in class org.apache.kafka.clients.admin.UpdateFeaturesResult
- 
Return a future which succeeds if all the feature updates succeed.
- all() - Static method in class org.apache.kafka.common.quota.ClientQuotaFilter
- 
Constructs and returns a quota filter that matches all configured entities.
- all() - Static method in class org.apache.kafka.streams.processor.To
- 
Forward the key/value pair to all downstream processors
- all() - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
- 
Return an iterator over all keys in this store.
- all() - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
- 
Gets all the key-value pairs in the existing windows.
- ALL - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
- 
ALL operation.
- allByBrokerId() - Method in class org.apache.kafka.clients.admin.ListTransactionsResult
- 
Get all transaction listings in a map which is keyed by the ID of respective broker that is currently managing them.
- allDescriptions() - Method in class org.apache.kafka.clients.admin.DescribeLogDirsResult
- 
Return a future which succeeds only if all the brokers have responded without error.
- allLocalStorePartitionLags() - Method in class org.apache.kafka.streams.KafkaStreams
- 
ReturnsLagInfo, for all store partitions (active or standby) local to this Streams instance.
- allMetrics() - Static method in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- 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 - Enum constant in enum class org.apache.kafka.common.acl.AclPermissionType
- 
Grants access.
- ALLOW_AUTO_CREATE_TOPICS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- 
allow.auto.create.topics
- ALLOWED - Enum constant in enum class org.apache.kafka.server.authorizer.AuthorizationResult
- ALLOWED_PATHS_CONFIG - Static variable in class org.apache.kafka.common.config.provider.DirectoryConfigProvider
- ALLOWED_PATHS_CONFIG - Static variable in class org.apache.kafka.common.config.provider.FileConfigProvider
- ALLOWED_PATHS_DOC - Static variable in class org.apache.kafka.common.config.provider.DirectoryConfigProvider
- ALLOWED_PATHS_DOC - Static variable in class org.apache.kafka.common.config.provider.FileConfigProvider
- ALLOWLIST_PATTERN_CONFIG - Static variable in class org.apache.kafka.common.config.provider.EnvVarConfigProvider
- ALLOWLIST_PATTERN_CONFIG_DOC - Static variable in class org.apache.kafka.common.config.provider.EnvVarConfigProvider
- allTasks() - Method in interface org.apache.kafka.streams.processor.assignment.ApplicationState
- allTopicIds() - Method in class org.apache.kafka.clients.admin.DescribeTopicsResult
- allTopicNames() - Method in class org.apache.kafka.clients.admin.DescribeTopicsResult
- allWithName(String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- allWithName(String) - Method in interface org.apache.kafka.connect.header.Headers
- AlreadyExistsException - Exception Class in org.apache.kafka.connect.errors
- 
Indicates the operation tried to create an entity that already exists.
- AlreadyExistsException(String) - Constructor for exception class org.apache.kafka.connect.errors.AlreadyExistsException
- AlreadyExistsException(String, Throwable) - Constructor for exception class org.apache.kafka.connect.errors.AlreadyExistsException
- AlreadyExistsException(Throwable) - Constructor for exception class org.apache.kafka.connect.errors.AlreadyExistsException
- ALTER - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
- 
ALTER operation.
- ALTER_CONFIGS - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
- 
ALTER_CONFIGS operation.
- alterClientQuotas(Collection<ClientQuotaAlteration>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Alters client quota configurations with the specified alterations.
- alterClientQuotas(Collection<ClientQuotaAlteration>, AlterClientQuotasOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Alters client quota configurations with the specified alterations.
- alterClientQuotas(Collection<ClientQuotaAlteration>, AlterClientQuotasOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- alterClientQuotas(Collection<ClientQuotaAlteration>, AlterClientQuotasOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- AlterClientQuotasOptions - Class in org.apache.kafka.clients.admin
- AlterClientQuotasOptions() - Constructor for class org.apache.kafka.clients.admin.AlterClientQuotasOptions
- AlterClientQuotasResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.alterClientQuotas(Collection, AlterClientQuotasOptions)call.
- AlterClientQuotasResult(Map<ClientQuotaEntity, KafkaFuture<Void>>) - Constructor for class org.apache.kafka.clients.admin.AlterClientQuotasResult
- 
Maps an entity to its alteration result.
- AlterConfigOp - Class in org.apache.kafka.clients.admin
- 
A class representing an alter configuration entry containing name, value and operation type.
- AlterConfigOp(ConfigEntry, AlterConfigOp.OpType) - Constructor for class org.apache.kafka.clients.admin.AlterConfigOp
- AlterConfigOp.OpType - Enum Class in org.apache.kafka.clients.admin
- 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.
- AlterConfigsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.incrementalAlterConfigs(Map).
- AlterConfigsOptions() - Constructor for class org.apache.kafka.clients.admin.AlterConfigsOptions
- AlterConfigsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.incrementalAlterConfigs(Map, AlterConfigsOptions)call.
- alterConsumerGroupOffsets(String, Map<TopicPartition, OffsetAndMetadata>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Alters offsets for the specified group.
- alterConsumerGroupOffsets(String, Map<TopicPartition, OffsetAndMetadata>, AlterConsumerGroupOffsetsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Alters offsets for the specified group.
- alterConsumerGroupOffsets(String, Map<TopicPartition, OffsetAndMetadata>, AlterConsumerGroupOffsetsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- alterConsumerGroupOffsets(String, Map<TopicPartition, OffsetAndMetadata>, AlterConsumerGroupOffsetsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- AlterConsumerGroupOffsetsOptions - Class in org.apache.kafka.clients.admin
- 
Options for theAdmin.alterConsumerGroupOffsets(String, Map, AlterConsumerGroupOffsetsOptions)call.
- AlterConsumerGroupOffsetsOptions() - Constructor for class org.apache.kafka.clients.admin.AlterConsumerGroupOffsetsOptions
- AlterConsumerGroupOffsetsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.alterConsumerGroupOffsets(String, Map)call.
- alternativeString - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
- alterOffsets(Map<String, String>, Map<Map<String, ?>, Map<String, ?>>) - Method in class org.apache.kafka.connect.source.SourceConnector
- 
Invoked when users request to manually alter/reset the offsets for this connector via the Connect worker's REST API.
- alterOffsets(Map<String, String>, Map<TopicPartition, Long>) - Method in class org.apache.kafka.connect.sink.SinkConnector
- 
Invoked when users request to manually alter/reset the offsets for this connector via the Connect worker's REST API.
- alterPartitionReassignments(Map<TopicPartition, Optional<NewPartitionReassignment>>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Change the reassignments for one or more partitions.
- alterPartitionReassignments(Map<TopicPartition, Optional<NewPartitionReassignment>>, AlterPartitionReassignmentsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Change the reassignments for one or more partitions.
- alterPartitionReassignments(Map<TopicPartition, Optional<NewPartitionReassignment>>, AlterPartitionReassignmentsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- alterPartitionReassignments(Map<TopicPartition, Optional<NewPartitionReassignment>>, AlterPartitionReassignmentsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- AlterPartitionReassignmentsOptions - Class in org.apache.kafka.clients.admin
- AlterPartitionReassignmentsOptions() - Constructor for class org.apache.kafka.clients.admin.AlterPartitionReassignmentsOptions
- AlterPartitionReassignmentsResult - Class in org.apache.kafka.clients.admin
- alterReplicaLogDirs(Map<TopicPartitionReplica, String>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Change the log directory for the specified replicas.
- alterReplicaLogDirs(Map<TopicPartitionReplica, String>, AlterReplicaLogDirsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Change the log directory for the specified replicas.
- alterReplicaLogDirs(Map<TopicPartitionReplica, String>, AlterReplicaLogDirsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- 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
- 
The result ofAdmin.alterReplicaLogDirs(Map, AlterReplicaLogDirsOptions).
- alterUserScramCredentials(List<UserScramCredentialAlteration>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Alter SASL/SCRAM credentials for the given users.
- alterUserScramCredentials(List<UserScramCredentialAlteration>, AlterUserScramCredentialsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Alter SASL/SCRAM credentials.
- alterUserScramCredentials(List<UserScramCredentialAlteration>, AlterUserScramCredentialsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- alterUserScramCredentials(List<UserScramCredentialAlteration>, AlterUserScramCredentialsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- AlterUserScramCredentialsOptions - Class in org.apache.kafka.clients.admin
- AlterUserScramCredentialsOptions() - Constructor for class org.apache.kafka.clients.admin.AlterUserScramCredentialsOptions
- AlterUserScramCredentialsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.alterUserScramCredentials(List)call.
- AlterUserScramCredentialsResult(Map<String, KafkaFuture<Void>>) - Constructor for class org.apache.kafka.clients.admin.AlterUserScramCredentialsResult
- ANONYMOUS - Static variable in class org.apache.kafka.common.security.auth.KafkaPrincipal
- ANY - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
- 
In a filter, matches any AclOperation.
- ANY - Enum constant in enum class org.apache.kafka.common.acl.AclPermissionType
- 
In a filter, matches any AclPermissionType.
- ANY - Enum constant in enum class org.apache.kafka.common.resource.PatternType
- 
In a filter, matches any resource pattern type.
- ANY - Enum constant in enum class org.apache.kafka.common.resource.ResourceType
- 
In a filter, matches any ResourceType.
- ANY - Enum constant in enum class org.apache.kafka.streams.query.ResultOrder
- 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.ResourcePatternFilter
- 
Matches any resource pattern.
- ApiException - Exception Class 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 class org.apache.kafka.common.errors.ApiException
- ApiException(String) - Constructor for exception class org.apache.kafka.common.errors.ApiException
- ApiException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.ApiException
- ApiException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.ApiException
- appConfigs() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- appConfigs() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
- 
Returns all the application config properties as key/value pairs.
- appConfigs() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- appConfigs() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Return all the application config properties as key/value pairs.
- appConfigs() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
- 
Returns all the application config properties as key/value pairs.
- appConfigsWithPrefix(String) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- appConfigsWithPrefix(String) - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
- 
Return all the application config properties with the given key prefix, as key/value pairs stripping the prefix.
- appConfigsWithPrefix(String) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- appConfigsWithPrefix(String) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Return all the application config properties with the given key prefix, as key/value pairs stripping the prefix.
- appConfigsWithPrefix(String) - Method in interface org.apache.kafka.streams.processor.StateStoreContext
- 
Returns all the application config properties with the given key prefix, as key/value pairs stripping the prefix.
- APPEND - Enum constant in enum class org.apache.kafka.clients.admin.AlterConfigOp.OpType
- 
(For list-type configuration entries only.) Add the specified values to the current value of the configuration entry.
- appendDeserializerToConfig(Map<String, Object>, Deserializer<?>, Deserializer<?>) - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
- APPLICATION_ID_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
application.id
- APPLICATION_SERVER_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
application.server
- applicationConfigs - Variable in class org.apache.kafka.streams.TopologyConfig
- applicationId() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- applicationId() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
- 
Return the application id.
- applicationId() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- applicationId() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Return the application id.
- applicationId() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
- 
Returns the application id.
- ApplicationState - Interface in org.apache.kafka.streams.processor.assignment
- 
A read-only metadata class representing the state of the application and the current rebalance.
- apply() - Method in interface org.apache.kafka.streams.kstream.Initializer
- 
Return the initial value for an aggregation.
- apply(A) - Method in interface org.apache.kafka.common.KafkaFuture.BaseFunction
- apply(String, Headers.HeaderTransform) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- apply(String, Headers.HeaderTransform) - Method in interface org.apache.kafka.connect.header.Headers
- 
Get allHeaders with the given key, apply the transform to each and store the result in place of the original.
- apply(K1, V1, V2) - Method in interface org.apache.kafka.streams.kstream.ValueJoinerWithKey
- 
Return a joined value consisting ofreadOnlyKey,value1andvalue2.
- apply(K, V) - Method in interface org.apache.kafka.streams.kstream.ForeachAction
- 
Perform an action for each record of a stream.
- apply(K, V) - Method in interface org.apache.kafka.streams.kstream.KeyValueMapper
- 
Map a record with the given key and value to a new value.
- apply(K, V) - Method in interface org.apache.kafka.streams.kstream.ValueMapperWithKey
- 
Map the given [key and ]value to a new value.
- apply(K, V, V) - Method in interface org.apache.kafka.streams.kstream.Merger
- 
Compute a new aggregate from the key and two aggregates.
- apply(K, V, VAgg) - Method in interface org.apache.kafka.streams.kstream.Aggregator
- 
Compute a new aggregate from the key and value of a record and the current aggregate of the same key.
- apply(Header) - Method in interface org.apache.kafka.connect.header.Headers.HeaderTransform
- apply(Headers.HeaderTransform) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- apply(Headers.HeaderTransform) - Method in interface org.apache.kafka.connect.header.Headers
- 
Get allHeaders, apply the transform to each and store the result in place of the original.
- apply(R) - Method in interface org.apache.kafka.connect.transforms.Transformation
- 
Apply transformation to therecordand return another record object (which may berecorditself) ornull, corresponding to a map or filter operation respectively.
- apply(V) - Method in interface org.apache.kafka.streams.kstream.ValueMapper
- 
Map the given value to a new value.
- apply(V1, V2) - Method in interface org.apache.kafka.streams.kstream.ValueJoiner
- 
Return a joined value consisting ofvalue1andvalue2.
- apply(V, V) - Method in interface org.apache.kafka.streams.kstream.Reducer
- 
Aggregate the two given values into a single one.
- approximateNumEntries() - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
- 
Return an approximate count of key-value mappings in this store.
- array(Schema) - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- ARRAY - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
- 
An ordered sequence of elements, each of which shares the same type.
- as(String) - Static method in class org.apache.kafka.streams.kstream.Branched
- 
Create an instance ofBranchedwith provided branch name suffix.
- as(String) - Static method in class org.apache.kafka.streams.kstream.Consumed
- 
Create an instance ofConsumedwith provided processor name.
- as(String) - Static method in class org.apache.kafka.streams.kstream.Grouped
- 
Create aGroupedinstance with the provided name used as part of the repartition topic if required.
- as(String) - Static method in class org.apache.kafka.streams.kstream.Joined
- 
Create an instance ofJoinedwith base name for all components of the join, this may include any repartition topics created to complete the join.
- as(String) - Static method in class org.apache.kafka.streams.kstream.Materialized
- 
Materialize aStateStorewith the given name.
- as(String) - Static method in class org.apache.kafka.streams.kstream.Named
- 
Create a Named instance with provided name.
- as(String) - Static method in class org.apache.kafka.streams.kstream.Produced
- 
Create an instance ofProducedwith provided processor name.
- as(String) - Static method in class org.apache.kafka.streams.kstream.Repartitioned
- 
Create aRepartitionedinstance with the provided name used as part of the repartition topic.
- as(String) - Static method in class org.apache.kafka.streams.kstream.StreamJoined
- 
Creates aStreamJoinedinstance using the provided name for the state stores and hence the changelog topics for the join stores.
- as(String) - Static method in class org.apache.kafka.streams.kstream.TableJoined
- 
Create an instance ofTableJoinedwith base name for all components of the join, including internal topics created to complete the join.
- as(DslStoreSuppliers) - Static method in class org.apache.kafka.streams.kstream.Materialized
- 
Materialize aStateStorewith the givenDslStoreSuppliers.
- as(KeyValueBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
- 
Materialize aKeyValueStoreusing the providedKeyValueBytesStoreSupplier.
- as(SessionBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
- 
Materialize aSessionStoreusing the providedSessionBytesStoreSupplier.
- as(WindowBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
- 
Materialize aWindowStoreusing the providedWindowBytesStoreSupplier.
- ASCENDING - Enum constant in enum class org.apache.kafka.streams.query.ResultOrder
- asOf(Instant) - Method in class org.apache.kafka.streams.query.VersionedKeyQuery
- 
Specifies the timestamp for the key query.
- asOfTimestamp() - Method in class org.apache.kafka.streams.query.VersionedKeyQuery
- 
The timestamp of the query, if specified.
- 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(Map<String, Integer>, Map<String, ConsumerPartitionAssignor.Subscription>) - Method in class org.apache.kafka.clients.consumer.RangeAssignor
- assign(Map<String, Integer>, Map<String, ConsumerPartitionAssignor.Subscription>) - Method in class org.apache.kafka.clients.consumer.RoundRobinAssignor
- assign(Cluster, ConsumerPartitionAssignor.GroupSubscription) - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
- 
Perform the group assignment given the member subscriptions and current cluster metadata.
- assign(GroupSpec, SubscribedTopicDescriber) - Method in interface org.apache.kafka.coordinator.group.api.assignor.PartitionAssignor
- 
Assigns partitions to group members based on the given assignment specification and topic metadata.
- assign(ApplicationState) - Method in class org.apache.kafka.streams.processor.assignment.assignors.StickyTaskAssignor
- assign(ApplicationState) - Method in interface org.apache.kafka.streams.processor.assignment.TaskAssignor
- ASSIGN_FROM_SUBSCRIBED_ASSIGNORS - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- AssignedTask(TaskId, KafkaStreamsAssignment.AssignedTask.Type) - Constructor for class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask
- ASSIGNING - Enum constant in enum class org.apache.kafka.common.ConsumerGroupState
- 
Deprecated.
- ASSIGNING - Enum constant in enum class org.apache.kafka.common.GroupState
- assignment() - Method in class org.apache.kafka.clients.admin.MemberDescription
- 
The assignment of the group member.
- assignment() - Method in class org.apache.kafka.clients.admin.ShareMemberDescription
- 
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
- assignment() - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
- 
Get the current set of assigned TopicPartitions for this task.
- assignment() - Method in class org.apache.kafka.streams.processor.assignment.TaskAssignor.TaskAssignment
- Assignment(List<TopicPartition>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Assignment
- Assignment(List<TopicPartition>, ByteBuffer) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Assignment
- ASSIGNMENT_LISTENER - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- assignmentConfigs() - Method in interface org.apache.kafka.streams.processor.assignment.ApplicationState
- AssignmentConfigs - Class in org.apache.kafka.streams.processor.assignment
- 
Assignment related configs for the Kafka StreamsTaskAssignor.
- AssignmentConfigs(long, int, int, long, List<String>, int, int, String) - Constructor for class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- AssignmentConfigs(long, int, int, long, List<String>, OptionalInt, OptionalInt, String) - Constructor for class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- AssignmentConfigs(Long, Integer, Integer, Long, List<String>) - Constructor for class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- 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.
- assignPartitions(Map<String, List<PartitionInfo>>, Map<String, ConsumerPartitionAssignor.Subscription>) - Method in class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
- assignPartitions(Map<String, List<PartitionInfo>>, Map<String, ConsumerPartitionAssignor.Subscription>) - Method in class org.apache.kafka.clients.consumer.RangeAssignor
- 
Performs range assignment of the specified partitions for the consumers with the provided subscriptions.
- assignTask(KafkaStreamsAssignment.AssignedTask) - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment
- asWrapped(ProcessorSupplier<KIn, VIn, KOut, VOut>) - Static method in interface org.apache.kafka.streams.processor.api.ProcessorWrapper
- 
Use to convert aProcessorSupplierinstance into aWrappedProcessorSupplier
- asWrappedFixedKey(FixedKeyProcessorSupplier<KIn, VIn, VOut>) - Static method in interface org.apache.kafka.streams.processor.api.ProcessorWrapper
- 
Use to convert aFixedKeyProcessorSupplierinstance into aWrappedFixedKeyProcessorSupplier
- at(Position) - Static method in class org.apache.kafka.streams.query.PositionBound
- 
Creates a new PositionBound representing a specific position.
- AT_LEAST_ONCE - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"processing.guarantee"for at-least-once processing guarantees.
- atLeast(Number) - Static method in class org.apache.kafka.common.config.ConfigDef.Range
- 
A numeric range that checks only the lower bound
- atMostOfSize(int) - Static method in class org.apache.kafka.common.config.ConfigDef.ListSize
- 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 Class in org.apache.kafka.common.errors
- 
This exception indicates that SASL authentication has failed.
- AuthenticationException(String) - Constructor for exception class org.apache.kafka.common.errors.AuthenticationException
- AuthenticationException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.AuthenticationException
- AuthenticationException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.AuthenticationException
- AuthorizableRequestContext - Interface in org.apache.kafka.server.authorizer
- 
Request context interface that provides data from request header as well as connection and authentication information to plugins.
- AuthorizationException - Exception Class in org.apache.kafka.common.errors
- AuthorizationException(String) - Constructor for exception class org.apache.kafka.common.errors.AuthorizationException
- AuthorizationException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.AuthorizationException
- AuthorizationResult - Enum Class in org.apache.kafka.server.authorizer
- authorize(AuthorizableRequestContext, List<Action>) - Method in interface org.apache.kafka.server.authorizer.Authorizer
- 
Authorizes the specified action.
- authorizeByResourceType(AuthorizableRequestContext, AclOperation, ResourceType) - Method in interface org.apache.kafka.server.authorizer.Authorizer
- 
Check if the caller is authorized to perform the given ACL operation on at least one resource of the given type.
- authorizedOperations() - Method in class org.apache.kafka.clients.admin.ClassicGroupDescription
- 
authorizedOperations for this group, or null if that information is not known.
- authorizedOperations() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
- 
authorizedOperations for this group, or null if that information is not known.
- authorizedOperations() - Method in class org.apache.kafka.clients.admin.DescribeClusterResult
- 
Returns a future which yields authorized operations.
- authorizedOperations() - Method in class org.apache.kafka.clients.admin.ShareGroupDescription
- 
authorizedOperations for this group, or null if that information is not known.
- authorizedOperations() - Method in class org.apache.kafka.clients.admin.TopicDescription
- 
authorized operations for this topic, or null if this is not known.
- Authorizer - Interface in org.apache.kafka.server.authorizer
- 
Pluggable authorizer interface for Kafka brokers.
- AuthorizerNotReadyException - Exception Class in org.apache.kafka.common.errors
- 
An exception that indicates that the authorizer is not ready to receive the request yet.
- AuthorizerNotReadyException() - Constructor for exception class org.apache.kafka.common.errors.AuthorizerNotReadyException
- AuthorizerServerInfo - Interface in org.apache.kafka.server.authorizer
- 
Runtime broker configuration metadata provided to authorizers during start up.
- 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
- AUTOMATIC_CONFIG_PROVIDERS_PROPERTY - Static variable in class org.apache.kafka.common.config.AbstractConfig
- Automatic Offset Committing - Search tag in class org.apache.kafka.clients.consumer.KafkaConsumer
- Section
- AutoOffsetReset - Class in org.apache.kafka.streams
- 
Sets theauto.offset.resetconfiguration whenadding a source processoror when creatingKStreamorKTableviaStreamsBuilder.
- availablePartitionsForTopic(String) - Method in class org.apache.kafka.common.Cluster
- 
Get the list of available partitions for this topic
- Avg - Class in org.apache.kafka.common.metrics.stats
- 
ASampledStatthat maintains a simple average over its samples.
- Avg() - Constructor for class org.apache.kafka.common.metrics.stats.Avg
B
- backwardAll() - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
- 
Gets all the key-value pairs in the existing windows in backward order with respect to time (from end to beginning of time).
- backwardFetch(K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
- 
Retrieve all aggregated sessions for the provided key.
- backwardFetch(K, long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
- backwardFetch(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
- 
Get all the key-value pairs with the given key and the time range from all the existing windows in backward order with respect to time (from end to beginning of time).
- backwardFetch(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
- backwardFetch(K, K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
- 
Retrieve all aggregated sessions for the given range of keys.
- backwardFetch(K, K, long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
- backwardFetch(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
- 
Get all the key-value pairs in the given key range and time range from all the existing windows in backward order with respect to time (from end to beginning of time).
- backwardFetch(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
- backwardFetchAll(long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
- backwardFetchAll(Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
- 
Gets all the key-value pairs that belong to the windows within in the given time range in backward order with respect to time (from end to beginning of time).
- backwardFetchAll(Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
- backwardFindSessions(K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
- 
Fetch any sessions with the matching key and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from latest to earliest.
- backwardFindSessions(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
- 
Fetch any sessions with the matching key and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from latest to earliest.
- backwardFindSessions(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
- backwardFindSessions(K, K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
- 
Fetch any sessions in the given range of keys and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from latest to earliest.
- backwardFindSessions(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
- 
Fetch any sessions in the given range of keys and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from latest to earliest.
- backwardFindSessions(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
- BATCH_SIZE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
batch.size
- BatchingStateRestoreCallback - Interface in org.apache.kafka.streams.processor
- 
Interface for batching restoration of aStateStoreIt is expected that implementations of this class will not call theStateRestoreCallback.restore(byte[], byte[])method.
- before(Duration) - Method in class org.apache.kafka.streams.kstream.JoinWindows
- 
Changes the start window boundary totimeDifferencebut keep the end window boundary as is.
- beforeMs - Variable in class org.apache.kafka.streams.kstream.JoinWindows
- 
Maximum time difference for tuples that are before the join tuple.
- 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 givenoffset
- 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
- 
Should be called before the start of each new transaction.
- beginTransaction() - Method in class org.apache.kafka.clients.producer.MockProducer
- beginTransaction() - Method in interface org.apache.kafka.clients.producer.Producer
- beginTransactionException - Variable in class org.apache.kafka.clients.producer.MockProducer
- 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.
- bins() - Method in interface org.apache.kafka.common.metrics.stats.Histogram.BinScheme
- 
Get the number of bins.
- bins() - Method in class org.apache.kafka.common.metrics.stats.Histogram.ConstantBinScheme
- bins() - Method in class org.apache.kafka.common.metrics.stats.Histogram.LinearBinScheme
- bool() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- Boolean() - Static method in class org.apache.kafka.common.serialization.Serdes
- 
A serde for nullableBooleantype.
- BOOLEAN - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigType
- BOOLEAN - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Type
- 
Used for boolean values.
- BOOLEAN - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
- 
Boolean value (true or false)
- BOOLEAN_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- BOOLEAN_SIZE - Static variable in class org.apache.kafka.streams.state.StateSerdes
- BooleanDeserializer - Class in org.apache.kafka.common.serialization
- BooleanDeserializer() - Constructor for class org.apache.kafka.common.serialization.BooleanDeserializer
- BooleanSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.BooleanSerde
- BooleanSerializer - Class in org.apache.kafka.common.serialization
- BooleanSerializer() - Constructor for class org.apache.kafka.common.serialization.BooleanSerializer
- bootstrap(List<InetSocketAddress>) - Static method in class org.apache.kafka.common.Cluster
- 
Create a "bootstrap" cluster using the given list of host/ports
- BOOTSTRAP_CONTROLLERS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- 
bootstrap.controllers
- BOOTSTRAP_CONTROLLERS_DOC - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- 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
- BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
bootstrap.servers
- Bootstrap and balancing - Search tag in interface org.apache.kafka.clients.admin.Admin
- Section
- bound() - Method in class org.apache.kafka.common.metrics.Quota
- bound() - Method in exception class org.apache.kafka.common.metrics.QuotaViolationException
- branch(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.BranchedKStream
- 
Define a branch for records that match the predicate.
- branch(Predicate<? super K, ? super V>, Branched<K, V>) - Method in interface org.apache.kafka.streams.kstream.BranchedKStream
- 
Define a branch for records that match the predicate.
- Branched<K,V> - Class in org.apache.kafka.streams.kstream
- 
TheBranchedclass is used to define the optional parameters when building branches withBranchedKStream.
- BranchedKStream<K,V> - Interface in org.apache.kafka.streams.kstream
- 
Branches the records in the original stream based on the predicates supplied for the branch definitions.
- Broker - Search tag in interface org.apache.kafka.common.ClusterResourceListener
- Section
- BROKER - Enum constant in enum class org.apache.kafka.clients.admin.EndpointType
- BROKER - Enum constant in enum class org.apache.kafka.common.config.ConfigResource.Type
- BROKER_LOGGER - Enum constant in enum class org.apache.kafka.common.config.ConfigResource.Type
- Broker Compatibility - Search tag in interface org.apache.kafka.clients.admin.Admin
- Section
- brokerId() - Method in class org.apache.kafka.clients.admin.DescribeProducersOptions
- brokerId() - Method in class org.apache.kafka.common.TopicPartitionReplica
- brokerId() - Method in interface org.apache.kafka.server.authorizer.AuthorizerServerInfo
- 
Returns broker id.
- brokerId() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogMetadata
- brokerId(int) - Method in class org.apache.kafka.clients.admin.DescribeProducersOptions
- BrokerIdNotRegisteredException - Exception Class in org.apache.kafka.common.errors
- BrokerIdNotRegisteredException(String) - Constructor for exception class org.apache.kafka.common.errors.BrokerIdNotRegisteredException
- BrokerIdNotRegisteredException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.BrokerIdNotRegisteredException
- BrokerNotAvailableException - Exception Class in org.apache.kafka.common.errors
- BrokerNotAvailableException(String) - Constructor for exception class org.apache.kafka.common.errors.BrokerNotAvailableException
- BrokerNotAvailableException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.BrokerNotAvailableException
- BrokerNotFoundException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates that none of the specifiedbrokerscould be found.
- BrokerNotFoundException(String) - Constructor for exception class org.apache.kafka.streams.errors.BrokerNotFoundException
- BrokerNotFoundException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.BrokerNotFoundException
- BrokerNotFoundException(Throwable) - Constructor for exception class org.apache.kafka.streams.errors.BrokerNotFoundException
- brokerTopicStatsMetrics() - Static method in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- BUFFER_MEMORY_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
buffer.memory
- BUFFERED_RECORDS_PER_PARTITION_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
buffered.records.per.partition
- BUFFERED_RECORDS_PER_PARTITION_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- BufferExhaustedException - Exception Class in org.apache.kafka.clients.producer
- 
This exception is thrown if the producer cannot allocate memory for a record within max.block.ms due to the buffer being too full.
- BufferExhaustedException(String) - Constructor for exception class org.apache.kafka.clients.producer.BufferExhaustedException
- build() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- 
Build the Schema using the current settings
- build() - Method in interface org.apache.kafka.streams.state.StoreBuilder
- 
Build the store as defined by the builder.
- build() - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Returns theTopologythat represents the specified processing logic.
- build(Properties) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Returns theTopologythat represents the specified processing logic and accepts aPropertiesinstance used to indicate whether to optimize topology or not.
- build(AuthenticationContext) - Method in interface org.apache.kafka.common.security.auth.KafkaPrincipalBuilder
- 
Build a kafka principal from the authentication context.
- BUILD_REMOTE_LOG_AUX_STATE_REQUESTS_PER_SEC_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- builder() - Static method in class org.apache.kafka.connect.data.Date
- 
Returns a SchemaBuilder for a Date.
- builder() - Static method in class org.apache.kafka.connect.data.Time
- 
Returns a SchemaBuilder for a Time.
- builder() - Static method in class org.apache.kafka.connect.data.Timestamp
- 
Returns a SchemaBuilder for a Timestamp.
- builder(int) - Static method in class org.apache.kafka.connect.data.Decimal
- 
Returns a SchemaBuilder for a Decimal with the given scale factor.
- buildFromEndpoint(String) - Static method in class org.apache.kafka.streams.state.HostInfo
- BUILT_IN_METRICS_VERSION_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
built.in.metrics.version
- BuiltInDslStoreSuppliers - Class in org.apache.kafka.streams.state
- 
Collection of builtinDslStoreSuppliersfor Kafka Streams.
- BuiltInDslStoreSuppliers() - Constructor for class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers
- BuiltInDslStoreSuppliers.InMemoryDslStoreSuppliers - Class in org.apache.kafka.streams.state
- 
ADslStoreSuppliersthat supplies all stores backed by an in-memory map
- BuiltInDslStoreSuppliers.RocksDBDslStoreSuppliers - Class in org.apache.kafka.streams.state
- 
ADslStoreSuppliersthat supplies all stores backed by RocksDB
- byBrokerId() - Method in class org.apache.kafka.clients.admin.ListTransactionsResult
- 
Get a future which returns a map containing the underlying listing future for each broker in the cluster.
- byDuration(Duration) - Static method in class org.apache.kafka.streams.AutoOffsetReset
- 
Creates anAutoOffsetResetinstance for the specified reset duration.
- ByteArray() - Static method in class org.apache.kafka.common.serialization.Serdes
- 
A serde for nullablebyte[]type.
- 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
- 
A serde for nullableByteBuffertype.
- 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
- 
ByteBufferSerializeralwaysrewindsthe position of the input buffer to zero for serialization.
- ByteBufferSerializer() - Constructor for class org.apache.kafka.common.serialization.ByteBufferSerializer
- bytes() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- Bytes() - Static method in class org.apache.kafka.common.serialization.Serdes
- 
A serde for nullableBytestype.
- BYTES - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
- 
Sequence of unsigned 8-bit bytes
- BYTES_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- 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
- CACHE_MAX_BYTES_BUFFERING_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.Since 3.4. Use"statestore.cache.max.bytes"instead.
- CACHE_MAX_BYTES_BUFFERING_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- cacheSize - Variable in class org.apache.kafka.streams.TopologyConfig
- 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() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedPunctuator
- cancel() - Method in interface org.apache.kafka.streams.processor.Cancellable
- 
Cancel the scheduled operation to avoid future calls.
- cancel() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedPunctuator
- 
Deprecated.
- cancel(boolean) - Method in class org.apache.kafka.common.KafkaFuture
- 
If not already completed, completes this future with a CancellationException.
- Cancellable - Interface in org.apache.kafka.streams.processor
- 
Cancellable interface returned inProcessingContext.schedule(Duration, PunctuationType, Punctuator).
- cancelled() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedPunctuator
- cancelled() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedPunctuator
- 
Deprecated.
- canDefineTransactionBoundaries(Map<String, String>) - Method in class org.apache.kafka.connect.source.SourceConnector
- 
Signals whether the connector implementation is capable of defining the transaction boundaries for a connector with the given configuration.
- canMoveStandbyTask(KafkaStreamsState, KafkaStreamsState, TaskId, Map<ProcessId, KafkaStreamsAssignment>) - Method in interface org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils.MoveStandbyTaskPredicate
- CapturedForward(Record<K, V>) - Constructor for class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedForward
- CapturedForward(Record<K, V>, Optional<String>) - Constructor for class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedForward
- centerValue() - Method in class org.apache.kafka.common.metrics.stats.Frequency
- 
Get the value of this metrics center point.
- CHECK_CRCS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- 
check.crcs
- Checkpoint - Class in org.apache.kafka.connect.mirror
- 
Checkpoint records emitted by MirrorCheckpointConnector.
- Checkpoint(String, TopicPartition, long, long, String) - Constructor for class org.apache.kafka.connect.mirror.Checkpoint
- checkpointsTopic(String) - Method in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
- checkpointsTopic(String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
- 
Returns the name of the checkpoints topic for given cluster alias.
- checkpointTopics() - Method in class org.apache.kafka.connect.mirror.MirrorClient
- 
Finds all checkpoints topics on this cluster.
- checkpointTopics(Map<String, Object>) - Static method in class org.apache.kafka.connect.mirror.RemoteClusterUtils
- 
Finds all checkpoints topics
- checkQuotas() - Method in class org.apache.kafka.common.metrics.Sensor
- 
Check if we have violated our quota for any metric that has a configured quota
- checkQuotas(long) - Method in class org.apache.kafka.common.metrics.Sensor
- child(String) - Static method in class org.apache.kafka.streams.processor.To
- 
Forward the key/value pair to one of the downstream processors designated by the downstream processor name.
- childName() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedForward
- 
The child this data was forwarded to.
- childName() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedForward
- 
Deprecated.The child this data was forwarded to.
- CLASS - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigType
- CLASS - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Type
- 
Used for values that implement a Kafka interface.
- CLASSIC - Enum constant in enum class org.apache.kafka.clients.consumer.GroupProtocol
- 
Classic group protocol.
- CLASSIC - Enum constant in enum class org.apache.kafka.common.GroupType
- ClassicGroupDescription - Class in org.apache.kafka.clients.admin
- 
A detailed description of a single classic group in the cluster.
- ClassicGroupDescription(String, String, String, Collection<MemberDescription>, ClassicGroupState, Node) - Constructor for class org.apache.kafka.clients.admin.ClassicGroupDescription
- ClassicGroupDescription(String, String, String, Collection<MemberDescription>, ClassicGroupState, Node, Set<AclOperation>) - Constructor for class org.apache.kafka.clients.admin.ClassicGroupDescription
- ClassicGroupState - Enum Class in org.apache.kafka.common
- 
The classic group state.
- cleanUp() - Method in class org.apache.kafka.streams.KafkaStreams
- 
Do a cleanup of the localStateStoredirectory (StreamsConfig.STATE_DIR_CONFIG) by deleting all data with regard to theapplication ID.
- 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
- clear() - Method in class org.apache.kafka.common.metrics.stats.Histogram
- clear() - Method in class org.apache.kafka.connect.header.ConnectHeaders
- clear() - Method in interface org.apache.kafka.connect.header.Headers
- 
Removes all headers from this object.
- 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 - Enum constant in enum class org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
- CLIENT_ID - Static variable in class org.apache.kafka.common.quota.ClientQuotaEntity
- 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
- CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
client.id
- CLIENT_ID_DOC - Static variable in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- CLIENT_METRICS - Enum constant in enum class org.apache.kafka.common.config.ConfigResource.Type
- CLIENT_RACK_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- 
client.rack
- CLIENT_SECRET_CONFIG - Static variable in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- CLIENT_SECRET_DOC - Static variable in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- CLIENT_TAG_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Prefix used to add arbitrary tags to a Kafka Stream's instance as key-value pairs.
- 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
- clientAddress() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
- 
Returns client IP address from which request was sent.
- clientId() - Method in class org.apache.kafka.clients.admin.MemberDescription
- 
The client id of the group member.
- clientId() - Method in class org.apache.kafka.clients.admin.ShareMemberDescription
- 
The client id of the group member.
- clientId() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
- 
Returns the client id from the request header.
- clientInstanceId() - Method in interface org.apache.kafka.server.telemetry.ClientTelemetryPayload
- 
Method returns the client's instance id.
- clientInstanceId(Duration) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Determines the client's unique client instance ID used for telemetry.
- clientInstanceId(Duration) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- clientInstanceId(Duration) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- clientInstanceId(Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
- clientInstanceId(Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
- 
Determines the client's unique client instance ID used for telemetry.
- clientInstanceId(Duration) - Method in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- 
Determines the client's unique client instance ID used for telemetry.
- clientInstanceId(Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- clientInstanceId(Duration) - Method in class org.apache.kafka.clients.consumer.MockShareConsumer
- clientInstanceId(Duration) - Method in interface org.apache.kafka.clients.consumer.ShareConsumer
- clientInstanceId(Duration) - Method in class org.apache.kafka.clients.producer.KafkaProducer
- 
Determines the client's unique client instance ID used for telemetry.
- clientInstanceId(Duration) - Method in class org.apache.kafka.clients.producer.MockProducer
- clientInstanceId(Duration) - Method in interface org.apache.kafka.clients.producer.Producer
- clientInstanceIds(Duration) - Method in class org.apache.kafka.streams.KafkaStreams
- 
Returns the internal clients' assignedclient instance ids.
- ClientInstanceIds - Interface in org.apache.kafka.streams
- 
Encapsulates theclient instance idused for metrics collection by producers, consumers, and the admin client used by Kafka Streams.
- ClientMetricsResourceListing - Class in org.apache.kafka.clients.admin
- ClientMetricsResourceListing(String) - Constructor for class org.apache.kafka.clients.admin.ClientMetricsResourceListing
- clientProps() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
- 
Provides configs with prefix "producer.override." forsource connectorsand alsosink connectorsthat are configured with a DLQ topic.
- ClientQuotaAlteration - Class in org.apache.kafka.common.quota
- 
Describes a configuration alteration to be made to a client quota entity.
- ClientQuotaAlteration(ClientQuotaEntity, Collection<ClientQuotaAlteration.Op>) - Constructor for class org.apache.kafka.common.quota.ClientQuotaAlteration
- ClientQuotaAlteration.Op - Class in org.apache.kafka.common.quota
- ClientQuotaCallback - Interface in org.apache.kafka.server.quota
- 
Quota callback interface for brokers and controllers that enables customization of client quota computation.
- ClientQuotaEntity - Class in org.apache.kafka.common.quota
- 
Describes a client quota entity, which is a mapping of entity types to their names.
- ClientQuotaEntity - Interface in org.apache.kafka.server.quota
- 
The metadata for an entity for which quota is configured.
- ClientQuotaEntity(Map<String, String>) - Constructor for class org.apache.kafka.common.quota.ClientQuotaEntity
- 
Constructs a quota entity for the given types and names.
- ClientQuotaEntity.ConfigEntity - Interface in org.apache.kafka.server.quota
- 
Interface representing a quota configuration entity.
- ClientQuotaEntity.ConfigEntityType - Enum Class in org.apache.kafka.server.quota
- 
Entity type of aClientQuotaEntity.ConfigEntity
- ClientQuotaFilter - Class in org.apache.kafka.common.quota
- 
Describes a client quota entity filter.
- ClientQuotaFilterComponent - Class in org.apache.kafka.common.quota
- 
Describes a component for applying a client quota filter.
- ClientQuotaType - Enum Class in org.apache.kafka.server.quota
- 
Types of quotas that may be configured on brokers for client requests.
- clientReceiver() - Method in interface org.apache.kafka.server.telemetry.ClientTelemetry
- 
Called by the broker to fetch instance ofClientTelemetryReceiver.
- Clients - Search tag in interface org.apache.kafka.common.ClusterResourceListener
- Section
- clientTagPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
- 
Prefix a client tag key withStreamsConfig.CLIENT_TAG_PREFIX.
- clientTags() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- 
The client tags for this KafkaStreams client, if set any have been via configs using theStreamsConfig.clientTagPrefix(java.lang.String)
- ClientTelemetry - Interface in org.apache.kafka.server.telemetry
- 
AMetricsReportermay implement this interface to indicate support for collecting client telemetry on the server side.
- ClientTelemetryPayload - Interface in org.apache.kafka.server.telemetry
- 
A client telemetry payload as sent by the client to the telemetry receiver.
- ClientTelemetryReceiver - Interface in org.apache.kafka.server.telemetry
- 
ClientTelemetryReceiverdefines the behaviour for telemetry receiver on the broker side which receives client telemetry metrics.
- clientType() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
- close() - Method in interface org.apache.kafka.clients.admin.Admin
- 
Close the Admin 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.KafkaShareConsumer
- 
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.consumer.MockShareConsumer
- close() - Method in interface org.apache.kafka.clients.consumer.ShareConsumer
- 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 class org.apache.kafka.clients.producer.RoundRobinPartitioner
- close() - Method in class org.apache.kafka.common.config.provider.DirectoryConfigProvider
- close() - Method in class org.apache.kafka.common.config.provider.EnvVarConfigProvider
- close() - Method in class org.apache.kafka.common.config.provider.FileConfigProvider
- close() - Method in interface org.apache.kafka.common.MessageFormatter
- 
Closes the formatter
- close() - Method in class org.apache.kafka.common.metrics.JmxReporter
- close() - Method in class org.apache.kafka.common.metrics.Metrics
- 
Close this metrics repository.
- close() - Method in interface org.apache.kafka.common.metrics.MetricsReporter
- 
Called when the metrics repository is closed.
- close() - Method in interface org.apache.kafka.common.security.auth.AuthenticateCallbackHandler
- 
Closes this instance.
- close() - Method in interface org.apache.kafka.common.security.auth.Login
- 
Closes this instance.
- close() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- close() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallbackHandler
- close() - Method in interface org.apache.kafka.common.serialization.Deserializer
- 
Close this deserializer.
- close() - Method in class org.apache.kafka.common.serialization.ListDeserializer
- close() - Method in class org.apache.kafka.common.serialization.ListSerializer
- 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.connect.mirror.MirrorClient
- 
Closes internal clients.
- close() - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
- close() - Method in class org.apache.kafka.connect.storage.StringConverter
- close() - Method in interface org.apache.kafka.connect.transforms.predicates.Predicate
- close() - Method in interface org.apache.kafka.connect.transforms.Transformation
- 
Signal that this transformation instance will no longer will be used.
- close() - Method in interface org.apache.kafka.server.quota.ClientQuotaCallback
- 
Closes this instance.
- close() - Method in class org.apache.kafka.streams.KafkaStreams
- 
Shutdown thisKafkaStreamsinstance by signaling all the threads to stop, and then wait for them to join.
- close() - Method in class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
- close() - Method in class org.apache.kafka.streams.kstream.SessionWindowedSerializer
- close() - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
- close() - Method in class org.apache.kafka.streams.kstream.TimeWindowedSerializer
- close() - Method in interface org.apache.kafka.streams.kstream.Transformer
- 
Deprecated.Close this transformer and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
- 
Deprecated.Close this transformer and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKey
- 
Close this processor and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.processor.api.FixedKeyProcessor
- 
Close this processor and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.processor.api.Processor
- 
Close this processor and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.processor.StateStore
- 
Close the storage engine.
- close() - Method in interface org.apache.kafka.streams.state.KeyValueIterator
- close() - Method in interface org.apache.kafka.streams.state.VersionedRecordIterator
- close() - Method in interface org.apache.kafka.streams.state.WindowStoreIterator
- close() - Method in class org.apache.kafka.streams.TopologyTestDriver
- 
Close the driver, its topology, and all processors.
- close() - Method in interface org.apache.kafka.tools.api.RecordReader
- 
Closes this reader.
- close(String, Options) - Method in interface org.apache.kafka.streams.state.RocksDBConfigSetter
- 
Close any user-constructed objects that inherit fromorg.rocksdb.RocksObject.
- close(Duration) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Close the Admin client and release all associated resources.
- close(Duration) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- close(Duration) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- 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.KafkaShareConsumer
- 
Tries to close the consumer cleanly within the specified timeout.
- close(Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- close(Duration) - Method in class org.apache.kafka.clients.consumer.MockShareConsumer
- close(Duration) - Method in interface org.apache.kafka.clients.consumer.ShareConsumer
- close(Duration) - Method in class org.apache.kafka.clients.producer.KafkaProducer
- 
This method waits up totimeoutfor the producer to complete the sending of all incomplete requests.
- close(Duration) - Method in class org.apache.kafka.clients.producer.MockProducer
- close(Duration) - Method in interface org.apache.kafka.clients.producer.Producer
- close(Duration) - Method in class org.apache.kafka.streams.KafkaStreams
- 
Shutdown thisKafkaStreamsby signaling all the threads to stop, and then wait up to the timeout for the threads to join.
- close(Collection<TopicPartition>) - Method in class org.apache.kafka.connect.sink.SinkTask
- 
The SinkTask uses this method to close writers for partitions that are no longer assigned to the SinkTask.
- close(KafkaStreams.CloseOptions) - Method in class org.apache.kafka.streams.KafkaStreams
- 
Shutdown thisKafkaStreamsby signaling all the threads to stop, and then wait up to the timeout for the threads to join.
- closed() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- closed() - Method in class org.apache.kafka.clients.producer.MockProducer
- closeException - Variable in class org.apache.kafka.clients.producer.MockProducer
- CloseOptions() - Constructor for class org.apache.kafka.streams.KafkaStreams.CloseOptions
- Cluster - Class in org.apache.kafka.common
- 
An immutable 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>, Set<String>, Node, Map<String, Uuid>) - Constructor for class org.apache.kafka.common.Cluster
- 
Create a new cluster with the given id, nodes, partitions and topicIds
- 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 - Enum constant in enum class 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 - Enum constant in enum class 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 Class in org.apache.kafka.common.errors
- ClusterAuthorizationException(String) - Constructor for exception class org.apache.kafka.common.errors.ClusterAuthorizationException
- ClusterAuthorizationException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.ClusterAuthorizationException
- clusterDetails() - Method in interface org.apache.kafka.connect.health.ConnectClusterState
- 
Get details about the setup of the Connect cluster.
- clusterId() - Method in class org.apache.kafka.clients.admin.AddRaftVoterOptions
- 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.clients.admin.RemoveRaftVoterOptions
- clusterId() - Method in class org.apache.kafka.common.ClusterResource
- 
Return the cluster id.
- clusterResource() - Method in class org.apache.kafka.common.Cluster
- clusterResource() - Method in interface org.apache.kafka.server.authorizer.AuthorizerServerInfo
- 
Returns cluster metadata for the broker running this authorizer including cluster id.
- ClusterResource - Class in org.apache.kafka.common
- 
TheClusterResourceclass encapsulates metadata for a Kafka cluster.
- ClusterResource(String) - Constructor for class org.apache.kafka.common.ClusterResource
- 
CreateClusterResourcewith 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.
- clusterState() - Method in interface org.apache.kafka.connect.rest.ConnectRestExtensionContext
- 
Provides the cluster state and health information about the connectors and tasks.
- code() - Method in enum class org.apache.kafka.clients.admin.FeatureUpdate.UpgradeType
- code() - Method in enum class org.apache.kafka.common.acl.AclOperation
- 
Return the code of this operation.
- code() - Method in enum class org.apache.kafka.common.acl.AclPermissionType
- 
Return the code of this permission type.
- code() - Method in enum class org.apache.kafka.common.resource.PatternType
- code() - Method in enum class org.apache.kafka.common.resource.ResourceType
- 
Return the code of this resource.
- cogroup(Aggregator<? super K, ? super V, VOut>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
- 
Create a newCogroupedKStreamfrom this grouped KStream to allow cogrouping otherKGroupedStreamto it.
- cogroup(KGroupedStream<K, V>, Aggregator<? super K, ? super V, VAgg>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
- 
Add an alreadygrouped KStreamto thisCogroupedKStream.
- CogroupedKStream<K,VAgg> - Interface in org.apache.kafka.streams.kstream
- 
CogroupedKStreamis an abstraction of multiple grouped record streams ofKeyValuepairs.
- Collecting branches in a single scope - Search tag in interface org.apache.kafka.streams.kstream.BranchedKStream
- Section
- combine(List<SampledStat.Sample>, MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.Avg
- combine(List<SampledStat.Sample>, MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.Frequencies
- combine(List<SampledStat.Sample>, MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.Max
- combine(List<SampledStat.Sample>, MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.Min
- combine(List<SampledStat.Sample>, MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.Percentiles
- combine(List<SampledStat.Sample>, MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
- combine(List<SampledStat.Sample>, MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.WindowedSum
- 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
- commit() - Method in class org.apache.kafka.connect.source.SourceTask
- 
This method is invoked periodically when offsets are committed for this source task.
- commit() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- commit() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
- 
Request a commit.
- commit() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- commit() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Request a commit.
- COMMIT_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
commit.interval.ms
- 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 lastKafkaConsumer.poll(Duration)for all the subscribed list of topics and partition.
- commitAsync() - Method in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- 
Commit the acknowledgements for the records returned.
- commitAsync() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- commitAsync() - Method in class org.apache.kafka.clients.consumer.MockShareConsumer
- commitAsync() - Method in interface org.apache.kafka.clients.consumer.ShareConsumer
- 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 lastpoll()for the subscribed list of topics and partitions.
- commitAsync(OffsetCommitCallback) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- CommitCallback - Interface in org.apache.kafka.streams.processor
- 
Stores can register this callback to be notified upon successful commit.
- commitCount() - Method in class org.apache.kafka.clients.producer.MockProducer
- CommitFailedException - Exception Class in org.apache.kafka.clients.consumer
- 
This exception is raised when an offset commit withKafkaConsumer.commitSync()fails with an unrecoverable error.
- CommitFailedException() - Constructor for exception class org.apache.kafka.clients.consumer.CommitFailedException
- CommitFailedException(String) - Constructor for exception class org.apache.kafka.clients.consumer.CommitFailedException
- commitRecord(SourceRecord, RecordMetadata) - Method in class org.apache.kafka.connect.source.SourceTask
- 
Commit an individualSourceRecordwhen the callback from the producer client is received.
- commitRecord(SourceRecord, RecordMetadata) - Method in class org.apache.kafka.connect.tools.VerifiableSourceTask
- 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 lastpoll()for all the subscribed list of topics and partitions.
- commitSync() - Method in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- 
Commit the acknowledgements for the records returned.
- commitSync() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- commitSync() - Method in class org.apache.kafka.clients.consumer.MockShareConsumer
- commitSync() - Method in interface org.apache.kafka.clients.consumer.ShareConsumer
- 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 lastpoll()for all the subscribed list of topics and partitions.
- commitSync(Duration) - Method in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- 
Commit the acknowledgements for the records returned.
- commitSync(Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- commitSync(Duration) - Method in class org.apache.kafka.clients.consumer.MockShareConsumer
- commitSync(Duration) - Method in interface org.apache.kafka.clients.consumer.ShareConsumer
- 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() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- 
WhetherProcessingContext.commit()has been called in this context.
- committed() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.WhetherProcessorContext.commit()has been called in this context.
- committed(Set<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
- committed(Set<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
- 
Get the last committed offsets for the given partitions (whether the commit happened by this process or another).
- committed(Set<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- committed(Set<TopicPartition>, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
- committed(Set<TopicPartition>, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
- 
Get the last committed offsets for the given partitions (whether the commit happened by this process or another).
- committed(Set<TopicPartition>, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- committedOffsets() - Method in interface org.apache.kafka.streams.TaskMetadata
- 
Offsets of the source topic partitions committed so far by the task.
- commitTransaction() - Method in class org.apache.kafka.clients.producer.KafkaProducer
- 
Commits the ongoing transaction.
- commitTransaction() - Method in class org.apache.kafka.clients.producer.MockProducer
- commitTransaction() - Method in interface org.apache.kafka.clients.producer.Producer
- commitTransaction() - Method in interface org.apache.kafka.connect.source.TransactionContext
- 
Request a transaction commit after the next batch of records fromSourceTask.poll()is processed.
- commitTransaction(SourceRecord) - Method in interface org.apache.kafka.connect.source.TransactionContext
- 
Request a transaction commit after a source record is processed.
- commitTransactionException - Variable in class org.apache.kafka.clients.producer.MockProducer
- compareTo(Uuid) - Method in class org.apache.kafka.common.Uuid
- compareTo(ProcessId) - Method in class org.apache.kafka.streams.processor.assignment.ProcessId
- compareTo(TaskId) - Method in class org.apache.kafka.streams.processor.TaskId
- compilePredicate(Map<String, ?>) - Static method in class org.apache.kafka.common.metrics.JmxReporter
- COMPLETE_ABORT - Enum constant in enum class org.apache.kafka.clients.admin.TransactionState
- COMPLETE_COMMIT - Enum constant in enum class org.apache.kafka.clients.admin.TransactionState
- COMPLETE_RECORD_DATA_CONFIG - Static variable in class org.apache.kafka.connect.tools.VerifiableSourceTask
- completedFuture(U) - Static method in class org.apache.kafka.common.KafkaFuture
- 
Returns a new KafkaFuture that is already completed with the given value.
- completeNext() - Method in class org.apache.kafka.clients.producer.MockProducer
- 
Complete the earliest uncompleted call successfully.
- COMPLETING_REBALANCE - Enum constant in enum class org.apache.kafka.common.ClassicGroupState
- COMPLETING_REBALANCE - Enum constant in enum class org.apache.kafka.common.ConsumerGroupState
- 
Deprecated.
- COMPLETING_REBALANCE - Enum constant in enum class org.apache.kafka.common.GroupState
- components() - Method in class org.apache.kafka.common.quota.ClientQuotaFilter
- CompoundStat - Interface in org.apache.kafka.common.metrics
- 
A compound stat is a stat where a single measurement and associated data structure feeds many metrics.
- CompoundStat.NamedMeasurable - Class in org.apache.kafka.common.metrics
- COMPRESSION_GZIP_LEVEL_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
compression.gzip.level
- COMPRESSION_GZIP_LEVEL_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
- COMPRESSION_GZIP_LEVEL_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
- COMPRESSION_LZ4_LEVEL_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
compression.lz4.level
- COMPRESSION_LZ4_LEVEL_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
- COMPRESSION_LZ4_LEVEL_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
- 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
- COMPRESSION_ZSTD_LEVEL_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
compression.zstd.level
- COMPRESSION_ZSTD_LEVEL_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
- COMPRESSION_ZSTD_LEVEL_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
- ConcurrentTransactionsException - Exception Class in org.apache.kafka.common.errors
- ConcurrentTransactionsException(String) - Constructor for exception class org.apache.kafka.common.errors.ConcurrentTransactionsException
- config() - Method in class org.apache.kafka.clients.admin.CreateTopicsResult.TopicMetadataAndConfig
- config() - Method in class org.apache.kafka.common.metrics.KafkaMetric
- 
Get the configuration of this metric.
- config() - Method in class org.apache.kafka.common.metrics.Metrics
- config() - Method in class org.apache.kafka.connect.connector.Connector
- 
Define the configuration for the connector.
- config() - Method in interface org.apache.kafka.connect.storage.Converter
- 
Configuration specification for this converter.
- config() - Method in interface org.apache.kafka.connect.storage.HeaderConverter
- 
Configuration specification for this set of header converters.
- config() - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
- config() - Method in class org.apache.kafka.connect.storage.StringConverter
- config() - Method in class org.apache.kafka.connect.tools.MockConnector
- config() - Method in class org.apache.kafka.connect.tools.MockSinkConnector
- config() - Method in class org.apache.kafka.connect.tools.MockSourceConnector
- config() - Method in class org.apache.kafka.connect.tools.SchemaSourceConnector
- config() - Method in class org.apache.kafka.connect.tools.VerifiableSinkConnector
- config() - Method in class org.apache.kafka.connect.tools.VerifiableSourceConnector
- config() - Method in interface org.apache.kafka.connect.transforms.predicates.Predicate
- 
Configuration specification for this predicate.
- config() - Method in interface org.apache.kafka.connect.transforms.Transformation
- 
Configuration specification for this transformation.
- config(String) - Method in class org.apache.kafka.clients.admin.CreateTopicsResult
- 
Returns a future that provides topic configs for the topic when the request completes.
- config(MetricConfig) - Method in class org.apache.kafka.common.metrics.KafkaMetric
- 
Set the metric config.
- 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
- CONFIG_PROVIDERS_CONFIG - Static variable in class org.apache.kafka.common.config.AbstractConfig
- ConfigChangeCallback - Interface in org.apache.kafka.common.config
- 
A callback passed toConfigProviderfor subscribing to changes.
- ConfigData - Class in org.apache.kafka.common.config
- 
Configuration data from aConfigProvider.
- 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() - Static method in class org.apache.kafka.clients.admin.AdminClientConfig
- configDef() - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
- configDef() - Static method in class org.apache.kafka.clients.producer.ProducerConfig
- configDef() - Static method in class org.apache.kafka.connect.storage.StringConverterConfig
- configDef() - Static method in class org.apache.kafka.streams.StreamsConfig
- 
Return a copy of the config definition.
- 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.CaseInsensitiveValidString - Class in org.apache.kafka.common.config
- ConfigDef.CompositeValidator - Class in org.apache.kafka.common.config
- ConfigDef.ConfigKey - Class in org.apache.kafka.common.config
- ConfigDef.Importance - Enum Class in org.apache.kafka.common.config
- 
The importance level for a configuration
- ConfigDef.LambdaValidator - Class in org.apache.kafka.common.config
- ConfigDef.ListSize - Class in org.apache.kafka.common.config
- 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 theConfigDef.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 Class in org.apache.kafka.common.config
- 
The type for a configuration value
- 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 Class 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() - Method in class org.apache.kafka.clients.admin.AlterConfigOp
- 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, ConfigEntry.ConfigSource, boolean, boolean, List<ConfigEntry.ConfigSynonym>, ConfigEntry.ConfigType, String) - Constructor for class org.apache.kafka.clients.admin.ConfigEntry
- 
Create a configuration with the provided values.
- ConfigEntry.ConfigSource - Enum Class 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 aConfigEntry.
- ConfigEntry.ConfigType - Enum Class in org.apache.kafka.clients.admin
- 
Data type of configuration entry.
- ConfigException - Exception Class in org.apache.kafka.common.config
- 
Thrown if the user supplies an invalid configuration
- ConfigException(String) - Constructor for exception class org.apache.kafka.common.config.ConfigException
- ConfigException(String, Object) - Constructor for exception class org.apache.kafka.common.config.ConfigException
- ConfigException(String, Object, String) - Constructor for exception class 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 Class 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 interface org.apache.kafka.connect.sink.SinkTaskContext
- 
Get the Task configuration.
- configs() - Method in interface org.apache.kafka.connect.source.SourceTaskContext
- 
Get the Task configuration.
- 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 ofConfigProviderinstances 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 fromConfigTransformer.
- 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() - Method in interface org.apache.kafka.connect.rest.ConnectRestExtensionContext
- 
Provides an implementation ofConfigurablethat can be used to register JAX-RS resources.
- 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.RoundRobinPartitioner
- configure(Map<String, ?>) - Method in class org.apache.kafka.common.config.provider.DirectoryConfigProvider
- configure(Map<String, ?>) - Method in class org.apache.kafka.common.config.provider.EnvVarConfigProvider
- 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 interface org.apache.kafka.common.MessageFormatter
- 
Configures the MessageFormatter
- configure(Map<String, ?>) - Method in class org.apache.kafka.common.metrics.JmxReporter
- configure(Map<String, ?>) - Method in interface org.apache.kafka.common.security.auth.SecurityProviderCreator
- 
Configure method is used to configure the generator to create the Security Provider
- configure(Map<String, ?>) - Method in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
- configure(Map<String, ?>) - Method in class org.apache.kafka.connect.mirror.IdentityReplicationPolicy
- configure(Map<String, ?>) - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
- configure(Map<String, ?>) - Method in class org.apache.kafka.connect.storage.StringConverter
- configure(Map<String, ?>) - Method in class org.apache.kafka.streams.errors.DefaultProductionExceptionHandler
- configure(Map<String, ?>) - Method in class org.apache.kafka.streams.errors.LogAndContinueExceptionHandler
- configure(Map<String, ?>) - Method in class org.apache.kafka.streams.errors.LogAndContinueProcessingExceptionHandler
- configure(Map<String, ?>) - Method in class org.apache.kafka.streams.errors.LogAndFailExceptionHandler
- configure(Map<String, ?>) - Method in class org.apache.kafka.streams.errors.LogAndFailProcessingExceptionHandler
- configure(Map<String, ?>) - Method in enum class org.apache.kafka.streams.kstream.Materialized.StoreType
- configure(Map<String, ?>) - Method in interface org.apache.kafka.streams.processor.api.ProcessorWrapper
- configure(Map<String, ?>) - Method in interface org.apache.kafka.streams.processor.assignment.TaskAssignor
- configure(Map<String, ?>) - Method in interface org.apache.kafka.streams.state.DslStoreSuppliers
- configure(Map<String, ?>) - Method in interface org.apache.kafka.tools.api.RecordReader
- 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.ListDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.ListSerializer
- 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.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, ?>, boolean) - Method in interface org.apache.kafka.connect.storage.Converter
- 
Configure this class.
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.connect.storage.StringConverter
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.SessionWindowedSerializer
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.TimeWindowedSerializer
- 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, List<AppConfigurationEntry>) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- configure(Map<String, ?>, String, List<AppConfigurationEntry>) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallbackHandler
- 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
- ConnectClusterDetails - Interface in org.apache.kafka.connect.health
- 
Provides immutable Connect cluster information, such as the ID of the backing Kafka cluster.
- ConnectClusterState - Interface in org.apache.kafka.connect.health
- 
Provides the ability to lookup connector metadata, including status and configurations, as well as immutable cluster information such as Kafka cluster ID.
- ConnectedStoreProvider - Interface in org.apache.kafka.streams.processor
- 
Provides a set ofStoreBuilders that will be automatically added to the topology and connected to the associated processor.
- ConnectException - Exception Class in org.apache.kafka.connect.errors
- 
ConnectException is the top-level exception type generated by Kafka Connect and connector implementations.
- ConnectException(String) - Constructor for exception class org.apache.kafka.connect.errors.ConnectException
- ConnectException(String, Throwable) - Constructor for exception class org.apache.kafka.connect.errors.ConnectException
- ConnectException(Throwable) - Constructor for exception class org.apache.kafka.connect.errors.ConnectException
- ConnectHeaders - Class in org.apache.kafka.connect.header
- 
A basicHeadersimplementation.
- ConnectHeaders() - Constructor for class org.apache.kafka.connect.header.ConnectHeaders
- ConnectHeaders(Iterable<Header>) - Constructor for class org.apache.kafka.connect.header.ConnectHeaders
- 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
- CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
connections.max.idle.ms
- Connector - Class in org.apache.kafka.connect.connector
- 
Connectors manage integration of Kafka Connect with another system, either as an input that ingests data into Kafka or an output that passes data to an external system.
- Connector() - Constructor for class org.apache.kafka.connect.connector.Connector
- CONNECTOR - Enum constant in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
- 
Transactions will be defined by the connector itself, via aTransactionContext.
- CONNECTOR_FAILURE - Static variable in class org.apache.kafka.connect.tools.MockConnector
- connectorClass() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
- 
The class of the Connector.
- ConnectorClientConfigOverridePolicy - Interface in org.apache.kafka.connect.connector.policy
- 
An interface for enforcing a policy on overriding of Kafka client configs via the connector configs.
- ConnectorClientConfigRequest - Class in org.apache.kafka.connect.connector.policy
- ConnectorClientConfigRequest(String, ConnectorType, Class<? extends Connector>, Map<String, Object>, ConnectorClientConfigRequest.ClientType) - Constructor for class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
- ConnectorClientConfigRequest.ClientType - Enum Class in org.apache.kafka.connect.connector.policy
- connectorConfig(String) - Method in interface org.apache.kafka.connect.health.ConnectClusterState
- 
Lookup the current configuration of a connector.
- ConnectorContext - Interface in org.apache.kafka.connect.connector
- 
ConnectorContext allowsConnectors to proactively interact with the Kafka Connect runtime.
- connectorHealth(String) - Method in interface org.apache.kafka.connect.health.ConnectClusterState
- 
Lookup the current health of a connector and its tasks.
- ConnectorHealth - Class in org.apache.kafka.connect.health
- 
Provides basic health information about the connector and its tasks.
- ConnectorHealth(String, ConnectorState, Map<Integer, TaskState>, ConnectorType) - Constructor for class org.apache.kafka.connect.health.ConnectorHealth
- connectorName() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
- 
Name of the connector specified in the connector config.
- connectors() - Method in interface org.apache.kafka.connect.health.ConnectClusterState
- 
Get the names of the connectors currently deployed in this cluster.
- connectorState() - Method in class org.apache.kafka.connect.health.ConnectorHealth
- 
Provides the current state of the connector.
- ConnectorState - Class in org.apache.kafka.connect.health
- 
Describes the status, worker ID, and any errors associated with a connector.
- ConnectorState(String, String, String) - Constructor for class org.apache.kafka.connect.health.ConnectorState
- 
Provides an instance of the ConnectorState.
- ConnectorTransactionBoundaries - Enum Class in org.apache.kafka.connect.source
- 
An enum to represent the level of support for connector-defined transaction boundaries.
- connectorType() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
- 
Type of the Connector.
- ConnectorType - Enum Class in org.apache.kafka.connect.health
- 
Enum definition that identifies the type of the connector.
- ConnectorUtils - Class in org.apache.kafka.connect.util
- 
Utilities that connector implementations might find useful.
- ConnectorUtils() - Constructor for class org.apache.kafka.connect.util.ConnectorUtils
- connectProcessorAndStateStores(String, String...) - Method in class org.apache.kafka.streams.Topology
- 
Connect aprocessorto one or morestate stores.
- ConnectRecord<R> - Class in org.apache.kafka.connect.connector
- 
Base class for records containing data to be copied to/from Kafka.
- ConnectRecord(String, Integer, Schema, Object, Schema, Object, Long) - Constructor for class org.apache.kafka.connect.connector.ConnectRecord
- ConnectRecord(String, Integer, Schema, Object, Schema, Object, Long, Iterable<Header>) - Constructor for class org.apache.kafka.connect.connector.ConnectRecord
- ConnectRestExtension - Interface in org.apache.kafka.connect.rest
- 
A plugin interface to allow registration of new JAX-RS resources like Filters, REST endpoints, providers, etc.
- ConnectRestExtensionContext - Interface in org.apache.kafka.connect.rest
- 
The interface provides the ability forConnectRestExtensionimplementations to access the JAX-RSConfigurableand cluster stateConnectClusterState.
- ConnectSchema - Class in org.apache.kafka.connect.data
- ConnectSchema(Schema.Type) - Constructor for class org.apache.kafka.connect.data.ConnectSchema
- 
Construct a default schema for a primitive type.
- ConnectSchema(Schema.Type, boolean, Object, String, Integer, String) - Constructor for class org.apache.kafka.connect.data.ConnectSchema
- 
Construct a Schema for a primitive type, setting schema parameters, struct fields, and key and value schemas to null.
- ConnectSchema(Schema.Type, boolean, Object, String, Integer, String, Map<String, String>, List<Field>, Schema, Schema) - Constructor for class org.apache.kafka.connect.data.ConnectSchema
- 
Construct a Schema.
- CONSTANT - Enum constant in enum class org.apache.kafka.common.metrics.stats.Percentiles.BucketSizing
- ConstantBinScheme(int, double, double) - Constructor for class org.apache.kafka.common.metrics.stats.Histogram.ConstantBinScheme
- 
Create a bin scheme with the specified number of bins that all have the same width.
- Consumed<K,V> - Class in org.apache.kafka.streams.kstream
- 
TheConsumedclass is used to define the optional parameters when usingStreamsBuilderto build instances ofKStream,KTable, andGlobalKTable.
- Consumer<K,V> - Interface in org.apache.kafka.clients.consumer
- CONSUMER - Enum constant in enum class org.apache.kafka.clients.consumer.GroupProtocol
- 
Consumer group protocol
- CONSUMER - Enum constant in enum class org.apache.kafka.common.GroupType
- CONSUMER - Enum constant in enum class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
- CONSUMER_CLIENT_PREFIX - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- CONSUMER_GROUP_ID_KEY - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
- CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Prefix used to isolateconsumerconfigs from other client configs.
- consumerClientId() - Method in interface org.apache.kafka.streams.ThreadMetadata
- 
Client ID of the Kafka consumer used by the stream thread.
- consumerClientIds() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- consumerConfig() - Method in class org.apache.kafka.connect.mirror.MirrorClientConfig
- 
Sub-config for Consumer clients.
- ConsumerConfig - Class in org.apache.kafka.clients.consumer
- 
The consumer configuration keys
- 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
- 
Deprecated.
- ConsumerGroupDescription(String, boolean, Collection<MemberDescription>, String, ConsumerGroupState, Node, Set<AclOperation>) - Constructor for class org.apache.kafka.clients.admin.ConsumerGroupDescription
- 
Deprecated.
- ConsumerGroupDescription(String, boolean, Collection<MemberDescription>, String, GroupType, ConsumerGroupState, Node, Set<AclOperation>) - Constructor for class org.apache.kafka.clients.admin.ConsumerGroupDescription
- 
Deprecated.
- ConsumerGroupDescription(String, boolean, Collection<MemberDescription>, String, GroupType, GroupState, Node, Set<AclOperation>, Optional<Integer>, Optional<Integer>) - Constructor for class org.apache.kafka.clients.admin.ConsumerGroupDescription
- consumerGroupId() - Method in class org.apache.kafka.connect.mirror.Checkpoint
- 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.
- ConsumerGroupListing(String, boolean, Optional<ConsumerGroupState>) - Constructor for class org.apache.kafka.clients.admin.ConsumerGroupListing
- 
Deprecated.Since 4.0. UseConsumerGroupListing(String, Optional, boolean)instead.
- ConsumerGroupListing(String, boolean, Optional<ConsumerGroupState>, Optional<GroupType>) - Constructor for class org.apache.kafka.clients.admin.ConsumerGroupListing
- 
Deprecated.Since 4.0. UseConsumerGroupListing(String, Optional, Optional, boolean)instead.
- ConsumerGroupListing(String, Optional<GroupState>, boolean) - Constructor for class org.apache.kafka.clients.admin.ConsumerGroupListing
- 
Create an instance with the specified parameters.
- ConsumerGroupListing(String, Optional<GroupState>, Optional<GroupType>, boolean) - Constructor for class org.apache.kafka.clients.admin.ConsumerGroupListing
- 
Create an instance with the specified parameters.
- ConsumerGroupMetadata - Class in org.apache.kafka.clients.consumer
- 
A metadata struct containing the consumer group information.
- ConsumerGroupMetadata(String) - Constructor for class org.apache.kafka.clients.consumer.ConsumerGroupMetadata
- ConsumerGroupMetadata(String, int, String, Optional<String>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerGroupMetadata
- consumerGroupOffsetsHistory() - Method in class org.apache.kafka.clients.producer.MockProducer
- 
Get the list of committed consumer group offsets since the last call toMockProducer.clear()
- ConsumerGroupPartitionAssignor - Interface in org.apache.kafka.coordinator.group.api.assignor
- 
Server-side partition assignor for consumer groups used by the GroupCoordinator.
- Consumer Groups and Topic Subscriptions - Search tag in class org.apache.kafka.clients.consumer.KafkaConsumer
- Section
- ConsumerGroupState - Enum Class in org.apache.kafka.common
- 
Deprecated.Since 4.0. UseGroupStateinstead.
- consumerId() - Method in class org.apache.kafka.clients.admin.MemberDescription
- 
The consumer id of the group member.
- consumerId() - Method in class org.apache.kafka.clients.admin.ShareMemberDescription
- 
The consumer id of the group member.
- consumerInstanceIds() - Method in interface org.apache.kafka.streams.ClientInstanceIds
- 
Returns theclient instance idof the consumers.
- 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.
- ConsumerPartitionAssignor - Interface in org.apache.kafka.clients.consumer
- 
This interface is used to define custom partition assignment for use inKafkaConsumer.
- ConsumerPartitionAssignor.Assignment - Class in org.apache.kafka.clients.consumer
- ConsumerPartitionAssignor.GroupAssignment - Class in org.apache.kafka.clients.consumer
- ConsumerPartitionAssignor.GroupSubscription - Class in org.apache.kafka.clients.consumer
- ConsumerPartitionAssignor.RebalanceProtocol - Enum Class in org.apache.kafka.clients.consumer
- 
The rebalance protocol defines partition assignment and revocation semantics.
- ConsumerPartitionAssignor.Subscription - Class in org.apache.kafka.clients.consumer
- consumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
- 
Prefix a property withStreamsConfig.CONSUMER_PREFIX.
- 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, int, int, K, V, Headers, Optional<Integer>) - 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, int, int, K, V, Headers, Optional<Integer>, Optional<Short>) - 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).
- ConsumerRecords<K,V> - Class in org.apache.kafka.clients.consumer
- 
A container that holds the listConsumerRecordper partition for a particular topic.
- ConsumerRecords(Map<TopicPartition, List<ConsumerRecord<K, V>>>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecords
- 
Deprecated.Since 4.0. UseConsumerRecords(Map, Map)instead.
- ConsumerRecords(Map<TopicPartition, List<ConsumerRecord<K, V>>>, Map<TopicPartition, OffsetAndMetadata>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecords
- Consumption Flow Control - Search tag in class org.apache.kafka.clients.consumer.KafkaConsumer
- Section
- contains(Collection<ClientQuotaFilterComponent>) - Static method in class org.apache.kafka.common.quota.ClientQuotaFilter
- 
Constructs and returns a quota filter that matches all provided components.
- containsMbean(String) - Method in class org.apache.kafka.common.metrics.JmxReporter
- containsOnly(Collection<ClientQuotaFilterComponent>) - Static method in class org.apache.kafka.common.quota.ClientQuotaFilter
- 
Constructs and returns a quota filter that matches all provided components.
- contentType() - Method in interface org.apache.kafka.server.telemetry.ClientTelemetryPayload
- 
Method returns the content-type format of the metrics data which is being sent by the client.
- contextChange(MetricsContext) - Method in class org.apache.kafka.common.metrics.JmxReporter
- contextChange(MetricsContext) - Method in interface org.apache.kafka.common.metrics.MetricsReporter
- 
Sets the context labels for the service or library exposing metrics.
- contextLabels() - Method in class org.apache.kafka.common.metrics.KafkaMetricsContext
- contextLabels() - Method in interface org.apache.kafka.common.metrics.MetricsContext
- 
Returns the labels for this metrics context.
- ContextualFixedKeyProcessor<KIn,VIn, - Class in org.apache.kafka.streams.processor.apiVOut> 
- 
An abstract implementation ofFixedKeyProcessorthat manages theFixedKeyProcessorContextinstance.
- ContextualProcessor<KIn,VIn, - Class in org.apache.kafka.streams.processor.apiKOut, VOut> 
- 
An abstract implementation ofProcessorthat manages theProcessorContextinstance.
- CONTINUE - Enum constant in enum class org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
- 
Continue processing.
- CONTINUE - Enum constant in enum class org.apache.kafka.streams.errors.ProcessingExceptionHandler.ProcessingHandlerResponse
- 
Continue processing.
- CONTINUE - Enum constant in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
- 
Continue processing.
- 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
- CONTROLLER - Enum constant in enum class org.apache.kafka.clients.admin.EndpointType
- CONTROLLER_MUTATION - Enum constant in enum class org.apache.kafka.server.quota.ClientQuotaType
- ControllerMovedException - Exception Class in org.apache.kafka.common.errors
- ControllerMovedException(String) - Constructor for exception class org.apache.kafka.common.errors.ControllerMovedException
- ControllerMovedException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.ControllerMovedException
- Controlling The Consumer's Position - Search tag in class org.apache.kafka.clients.consumer.KafkaConsumer
- Section
- Converter - Interface in org.apache.kafka.connect.storage
- 
The Converter interface provides support for translating between Kafka Connect's runtime data format and byte[].
- ConverterConfig - Class in org.apache.kafka.connect.storage
- 
Abstract class that defines the configuration options forConverterandHeaderConverterinstances.
- ConverterType - Enum Class in org.apache.kafka.connect.storage
- 
The type ofConverterandHeaderConverter.
- convertToBoolean(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to aSchema.Type.BOOLEANvalue.
- convertToByte(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to anSchema.Type.INT8byte value.
- convertToDate(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to adatevalue.
- convertToDecimal(Schema, Object, int) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to adecimalvalue.
- convertToDouble(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to aSchema.Type.FLOAT64double value.
- convertToFloat(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to aSchema.Type.FLOAT32float value.
- convertToInteger(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to anSchema.Type.INT32int value.
- convertToList(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to anSchema.Type.ARRAYvalue.
- convertToLong(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to anSchema.Type.INT64long value.
- convertToMap(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to aSchema.Type.MAPvalue.
- convertToShort(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to anSchema.Type.INT16short value.
- convertToString(Object, ConfigDef.Type) - Static method in class org.apache.kafka.common.config.ConfigDef
- convertToString(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to aSchema.Type.STRINGvalue.
- 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.
- convertToStruct(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to aSchema.Type.STRUCTvalue.
- convertToTime(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to atimevalue.
- convertToTimestamp(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to atimestampvalue.
- convertToTimestampedFormat(byte[]) - Static method in interface org.apache.kafka.streams.state.TimestampedBytesStore
- COOPERATIVE - Enum constant in enum class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
- COOPERATIVE_STICKY_ASSIGNOR_NAME - Static variable in class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
- CooperativeStickyAssignor - Class in org.apache.kafka.clients.consumer
- 
A cooperative version of theAbstractStickyAssignor.
- CooperativeStickyAssignor() - Constructor for class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
- coordinator() - Method in class org.apache.kafka.clients.admin.ClassicGroupDescription
- 
The classic group coordinator, or null if the coordinator is not known.
- coordinator() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
- 
The consumer group coordinator, or null if the coordinator is not known.
- coordinator() - Method in class org.apache.kafka.clients.admin.ShareGroupDescription
- 
The share group coordinator, or null if the coordinator is not known.
- coordinatorEpoch() - Method in class org.apache.kafka.clients.admin.AbortTransactionSpec
- coordinatorEpoch() - Method in class org.apache.kafka.clients.admin.ProducerState
- coordinatorId() - Method in class org.apache.kafka.clients.admin.TransactionDescription
- CoordinatorLoadInProgressException - Exception Class 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 class org.apache.kafka.common.errors.CoordinatorLoadInProgressException
- CoordinatorLoadInProgressException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.CoordinatorLoadInProgressException
- CoordinatorNotAvailableException - Exception Class 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 class org.apache.kafka.common.errors.CoordinatorNotAvailableException
- CoordinatorNotAvailableException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.CoordinatorNotAvailableException
- copy() - Method in class org.apache.kafka.streams.query.Position
- 
Create a deep copy of the Position.
- COPY_SEGMENT_FINISHED - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
- 
This state indicates that the segment copying to remote storage is finished.
- COPY_SEGMENT_STARTED - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
- 
This state indicates that the segment copying to remote storage is started but not yet finished.
- copyLogSegmentData(RemoteLogSegmentMetadata, LogSegmentData) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteStorageManager
- 
Copies the givenLogSegmentDataprovided for the givenremoteLogSegmentMetadata.
- correlationId() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
- 
Returns the correlation id from the request header.
- corruptedTasks() - Method in exception class org.apache.kafka.streams.errors.TaskCorruptedException
- CorruptRecordException - Exception Class 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 class org.apache.kafka.common.errors.CorruptRecordException
- CorruptRecordException(String) - Constructor for exception class org.apache.kafka.common.errors.CorruptRecordException
- CorruptRecordException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.CorruptRecordException
- CorruptRecordException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.CorruptRecordException
- count() - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
- 
The number of records for all topics
- count() - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
- 
Count the number of records in this stream by the grouped key.
- count() - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- count() - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
- 
Count the number of records in this stream by the grouped key and defined sessions.
- count() - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
- 
Count the number of records in this stream by the grouped key and defined windows.
- count(Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
- 
Count the number of records in this stream by the grouped key.
- count(Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- count(Materialized<K, Long, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
- 
Count the number of records in this stream by the grouped key and defined sessions.
- count(Materialized<K, Long, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
- 
Count the number of records in this stream by the grouped key and defined windows.
- count(Named) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
- 
Count the number of records in this stream by the grouped key.
- count(Named) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- count(Named) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
- 
Count the number of records in this stream by the grouped key and defined sessions.
- count(Named) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
- 
Count the number of records in this stream by the grouped key and defined windows.
- count(Named, Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
- 
Count the number of records in this stream by the grouped key.
- count(Named, Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- count(Named, Materialized<K, Long, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
- 
Count the number of records in this stream by the grouped key and defined sessions.
- count(Named, Materialized<K, Long, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
- 
Count the number of records in this stream by the grouped key and defined windows.
- counts() - Method in class org.apache.kafka.common.metrics.stats.Histogram
- create(Map<String, Object>) - Static method in interface org.apache.kafka.clients.admin.Admin
- 
Create a new Admin with the given configuration.
- create(Map<String, Object>) - Static method in class org.apache.kafka.clients.admin.AdminClient
- 
Create a new Admin with the given configuration.
- create(Properties) - Static method in interface org.apache.kafka.clients.admin.Admin
- 
Create a new Admin with the given configuration.
- create(Properties) - Static method in class org.apache.kafka.clients.admin.AdminClient
- 
Create a new Admin with the given configuration.
- create(Record<KIn, VIn>) - Static method in class org.apache.kafka.streams.processor.api.InternalFixedKeyRecordFactory
- 
Only allowed way to createFixedKeyRecords.
- create(StateStoreProvider, String) - Method in interface org.apache.kafka.streams.state.QueryableStoreType
- 
Create an instance ofT(usually a facade) that developers can use to query the underlyingStateStores.
- create(StateStoreProvider, String) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.KeyValueStoreType
- create(StateStoreProvider, String) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.SessionStoreType
- create(StateStoreProvider, String) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.WindowStoreType
- CREATE - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
- 
CREATE operation.
- CREATE_TOKENS - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
- 
CREATE_TOKENS operation.
- createAcls(Collection<AclBinding>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
This is a convenience method forAdmin.createAcls(Collection, CreateAclsOptions)with default options.
- createAcls(Collection<AclBinding>, CreateAclsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Creates access control lists (ACLs) which are bound to specific resources.
- createAcls(Collection<AclBinding>, CreateAclsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- createAcls(Collection<AclBinding>, CreateAclsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- createAcls(AuthorizableRequestContext, List<AclBinding>) - Method in interface org.apache.kafka.server.authorizer.Authorizer
- 
Creates new ACL bindings.
- CreateAclsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.createAcls(Collection).
- CreateAclsOptions() - Constructor for class org.apache.kafka.clients.admin.CreateAclsOptions
- CreateAclsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.createAcls(Collection)call.
- createClientSslEngine(String, int, String) - Method in interface org.apache.kafka.common.security.auth.SslEngineFactory
- 
Creates a newSSLEngineobject to be used by the client.
- CREATED - Enum constant in enum class org.apache.kafka.streams.KafkaStreams.State
- createDelegationToken() - Method in interface org.apache.kafka.clients.admin.Admin
- 
Create a Delegation Token.
- createDelegationToken(CreateDelegationTokenOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Create a Delegation Token.
- createDelegationToken(CreateDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- 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
- 
The result of theKafkaAdminClient.createDelegationToken(CreateDelegationTokenOptions)call.
- createInputTopic(String, Serializer<K>, Serializer<V>) - Method in class org.apache.kafka.streams.TopologyTestDriver
- 
CreateTestInputTopicto be used for piping records to topic Uses current system time as start timestamp for records.
- createInputTopic(String, Serializer<K>, Serializer<V>, Instant, Duration) - Method in class org.apache.kafka.streams.TopologyTestDriver
- 
CreateTestInputTopicto be used for piping records to topic Uses provided start timestamp and autoAdvance parameter for records
- createOutputTopic(String, Deserializer<K>, Deserializer<V>) - Method in class org.apache.kafka.streams.TopologyTestDriver
- 
CreateTestOutputTopicto be used for reading records from topic
- createPartitions(Map<String, NewPartitions>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Increase the number of partitions of the topics given as the keys ofnewPartitionsaccording to the corresponding values.
- createPartitions(Map<String, NewPartitions>, CreatePartitionsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Increase the number of partitions of the topics given as the keys ofnewPartitionsaccording to the corresponding values.
- createPartitions(Map<String, NewPartitions>, CreatePartitionsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- createPartitions(Map<String, NewPartitions>, CreatePartitionsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- CreatePartitionsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.createPartitions(Map).
- CreatePartitionsOptions() - Constructor for class org.apache.kafka.clients.admin.CreatePartitionsOptions
- CreatePartitionsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.createPartitions(Map)call.
- createServerSslEngine(String, int) - Method in interface org.apache.kafka.common.security.auth.SslEngineFactory
- 
Creates a newSSLEngineobject to be used by the server.
- 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 interface org.apache.kafka.clients.admin.Admin
- 
Create a batch of new topics with the default options.
- createTopics(Collection<NewTopic>, CreateTopicsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Create a batch of new topics.
- createTopics(Collection<NewTopic>, CreateTopicsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- createTopics(Collection<NewTopic>, CreateTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- CreateTopicsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.createTopics(Collection).
- CreateTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.CreateTopicsOptions
- CreateTopicsResult - Class in org.apache.kafka.clients.admin
- 
The result ofAdmin.createTopics(Collection).
- CreateTopicsResult.TopicMetadataAndConfig - Class in org.apache.kafka.clients.admin
- createWithUpdates(RemoteLogSegmentMetadataUpdate) - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- 
Creates a new RemoteLogSegmentMetadata applying the givenrlsmUpdateon this instance.
- credentialInfo() - Method in class org.apache.kafka.clients.admin.UserScramCredentialUpsertion
- credentialInfos() - Method in class org.apache.kafka.clients.admin.UserScramCredentialsDescription
- Cross-Version Compatibility - Search tag in class org.apache.kafka.clients.consumer.KafkaConsumer
- Section
- Cross-Version Compatibility - Search tag in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- Section
- CumulativeCount - Class in org.apache.kafka.common.metrics.stats
- 
A non-sampled version ofWindowedCountmaintained over all time.
- CumulativeCount() - Constructor for class org.apache.kafka.common.metrics.stats.CumulativeCount
- CumulativeSum - Class in org.apache.kafka.common.metrics.stats
- 
An non-sampled cumulative total maintained over all time.
- CumulativeSum() - Constructor for class org.apache.kafka.common.metrics.stats.CumulativeSum
- CumulativeSum(double) - Constructor for class org.apache.kafka.common.metrics.stats.CumulativeSum
- current(long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
- currentLag(TopicPartition) - Method in interface org.apache.kafka.clients.consumer.Consumer
- currentLag(TopicPartition) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
- 
Get the consumer's current lag on the partition.
- currentLag(TopicPartition) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- currentOffsetPosition() - Method in class org.apache.kafka.streams.LagInfo
- 
Get the current maximum offset on the store partition's changelog topic, that has been successfully written into the store partition's state store.
- currentStreamTimeMs() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- currentStreamTimeMs() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
- 
Return the current stream-time in milliseconds.
- currentStreamTimeMs() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- currentStreamTimeMs() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Return the current stream-time in milliseconds.
- currentSystemTimeMs() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- currentSystemTimeMs() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
- 
Return the current system timestamp (also called wall-clock time) in milliseconds.
- currentSystemTimeMs() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- currentSystemTimeMs() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Return the current system timestamp (also called wall-clock time) in milliseconds.
- currentTransactionStartOffset() - Method in class org.apache.kafka.clients.admin.ProducerState
- customMetadata() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- customMetadata() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
- CustomMetadata(byte[]) - Constructor for class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata.CustomMetadata
D
- 2. Decouple Consumption and Processing - Search tag in class org.apache.kafka.clients.consumer.KafkaConsumer
- Section
- 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.
- data() - Method in interface org.apache.kafka.server.telemetry.ClientTelemetryPayload
- 
Method returns the serialized metrics data as received by the client.
- DataException - Exception Class in org.apache.kafka.connect.errors
- 
Base class for all Kafka Connect data API exceptions.
- DataException(String) - Constructor for exception class org.apache.kafka.connect.errors.DataException
- DataException(String, Throwable) - Constructor for exception class org.apache.kafka.connect.errors.DataException
- DataException(Throwable) - Constructor for exception class org.apache.kafka.connect.errors.DataException
- Date - Class in org.apache.kafka.connect.data
- 
A date representing a calendar day with no time of day or timezone.
- Date() - Constructor for class org.apache.kafka.connect.data.Date
- dateFormatFor(Date) - Static method in class org.apache.kafka.connect.data.Values
- DEAD - Enum constant in enum class org.apache.kafka.common.ClassicGroupState
- DEAD - Enum constant in enum class org.apache.kafka.common.ConsumerGroupState
- 
Deprecated.
- DEAD - Enum constant in enum class org.apache.kafka.common.GroupState
- DEBUG - Enum constant in enum class org.apache.kafka.common.metrics.Sensor.RecordingLevel
- DEBUG_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
- 
TheDEBUGlevel designates fine-grained informational events that are most useful to debug Kafka
- Decimal - Class in org.apache.kafka.connect.data
- 
An arbitrary-precision signed decimal number.
- Decimal() - Constructor for class org.apache.kafka.connect.data.Decimal
- Decoder<T> - Interface in org.apache.kafka.tools.api
- 
A decoder is a method of turning byte arrays into objects.
- DEFAULT - Static variable in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
- 
The default transaction boundary style that will be used for source connectors when no style is explicitly configured.
- DEFAULT_ALLOW_AUTO_CREATE_TOPICS - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- DEFAULT_API_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- DEFAULT_API_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- 
default.api.timeout.ms
- DEFAULT_CLIENT_ID - Enum constant in enum class org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
- DEFAULT_CLIENT_RACK - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- DEFAULT_CLIENT_SUPPLIER_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
default.client.supplier
- DEFAULT_CLIENT_SUPPLIER_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- DEFAULT_CONFIG - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
- DEFAULT_DESERIALIZATION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.Since 4.0. UseStreamsConfig.DESERIALIZATION_EXCEPTION_HANDLER_CLASS_CONFIGinstead.
- DEFAULT_DESERIALIZATION_EXCEPTION_HANDLER_CLASS_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- DEFAULT_DSL_STORE - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- DEFAULT_DSL_STORE_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.Since 3.7. UseStreamsConfig.DSL_STORE_SUPPLIERS_CLASS_CONFIGinstead.
- DEFAULT_DSL_STORE_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- DEFAULT_EXCLUDE - Static variable in class org.apache.kafka.common.metrics.JmxReporter
- DEFAULT_EXCLUDE_INTERNAL_TOPICS - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- DEFAULT_FAILURE_DELAY_MS - Static variable in class org.apache.kafka.connect.tools.MockConnector
- DEFAULT_FETCH_MAX_BYTES - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- DEFAULT_FETCH_MAX_WAIT_MS - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- DEFAULT_FETCH_MIN_BYTES - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- DEFAULT_GROUP_PROTOCOL - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- DEFAULT_GROUP_REMOTE_ASSIGNOR - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- DEFAULT_INCLUDE - Static variable in class org.apache.kafka.common.metrics.JmxReporter
- 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_KEY_SERDE_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
default key.serde
- 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_MAX_POLL_RECORDS - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- DEFAULT_METADATA_RECOVERY_REBOOTSTRAP_TRIGGER_MS - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- DEFAULT_METADATA_RECOVERY_STRATEGY - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- DEFAULT_NUM_SAMPLES - Static variable in class org.apache.kafka.common.metrics.MetricConfig
- DEFAULT_PATTERN - Static variable in class org.apache.kafka.common.config.ConfigTransformer
- DEFAULT_PRODUCTION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.Since 4.0. UseStreamsConfig.PRODUCTION_EXCEPTION_HANDLER_CLASS_CONFIGinstead.
- DEFAULT_SASL_LOGIN_RETRY_BACKOFF_MAX_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_LOGIN_RETRY_BACKOFF_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_MECHANISM - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_OAUTHBEARER_CLOCK_SKEW_SECONDS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_OAUTHBEARER_HEADER_URLENCODE - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_OAUTHBEARER_JWKS_ENDPOINT_REFRESH_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_OAUTHBEARER_JWKS_ENDPOINT_RETRY_BACKOFF_MAX_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_OAUTHBEARER_JWKS_ENDPOINT_RETRY_BACKOFF_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_OAUTHBEARER_SCOPE_CLAIM_NAME - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_OAUTHBEARER_SUB_CLAIM_NAME - 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_STICKY_NON_OVERLAP_COST - Static variable in class org.apache.kafka.streams.processor.assignment.assignors.StickyTaskAssignor
- DEFAULT_STICKY_TRAFFIC_COST - Static variable in class org.apache.kafka.streams.processor.assignment.assignors.StickyTaskAssignor
- DEFAULT_TIMESTAMP_EXTRACTOR_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
default.timestamp.extractor
- DEFAULT_TIMESTAMP_EXTRACTOR_CLASS_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- DEFAULT_USER - Enum constant in enum class org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
- DEFAULT_VALUE_SERDE_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
default.value.serde
- defaultBranch() - Method in interface org.apache.kafka.streams.kstream.BranchedKStream
- 
Finalize the construction of branches and defines the default branch for the messages not intercepted by other branches.
- defaultBranch(Branched<K, V>) - Method in interface org.apache.kafka.streams.kstream.BranchedKStream
- 
Finalize the construction of branches and defines the default branch for the messages not intercepted by other branches.
- DefaultDecoder - Class in org.apache.kafka.tools.api
- 
The default implementation does nothing, just returns the same byte array it takes in.
- DefaultDecoder() - Constructor for class org.apache.kafka.tools.api.DefaultDecoder
- defaultDeserializationExceptionHandler() - Method in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.Since 4.0. UseStreamsConfig.deserializationExceptionHandler()instead.
- defaultKeySerde() - Method in class org.apache.kafka.streams.StreamsConfig
- 
Return anconfiguredinstance ofkey Serde class.
- defaultProductionExceptionHandler() - Method in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.Since 4.0. UseStreamsConfig.productionExceptionHandler()instead.
- DefaultProductionExceptionHandler - Class in org.apache.kafka.streams.errors
- 
ProductionExceptionHandlerthat always instructs streams to fail when an exception happens while attempting to produce result records.
- DefaultProductionExceptionHandler() - Constructor for class org.apache.kafka.streams.errors.DefaultProductionExceptionHandler
- DefaultReplicationPolicy - Class in org.apache.kafka.connect.mirror
- 
Default implementation ofReplicationPolicywhich prepends the source cluster alias to remote topic names.
- DefaultReplicationPolicy() - Constructor for class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
- defaultStandbyTaskAssignment(ApplicationState, Map<ProcessId, KafkaStreamsAssignment>) - Static method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils
- 
Assign standby tasks to KafkaStreams clients according to the default logic.
- defaultTimestampExtractor() - Method in class org.apache.kafka.streams.StreamsConfig
- defaultValue - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
- defaultValue() - Method in class org.apache.kafka.connect.data.ConnectSchema
- defaultValue() - Method in interface org.apache.kafka.connect.data.Schema
- defaultValue() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- defaultValue(Object) - Method in class org.apache.kafka.connect.data.SchemaBuilder
- 
Set the default value for this schema.
- defaultValues() - Method in class org.apache.kafka.common.config.ConfigDef
- defaultValueSerde() - Method in class org.apache.kafka.streams.StreamsConfig
- 
Return anconfiguredinstance ofvalue Serde class.
- 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) - 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, List<String>, ConfigDef.Recommender, String) - 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.
- defineInternal(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String) - Method in class org.apache.kafka.common.config.ConfigDef
- 
Define a new internal configuration.
- DELAY_MS_KEY - Static variable in class org.apache.kafka.connect.tools.MockConnector
- DELEGATION_TOKEN - Enum constant in enum class 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 Class in org.apache.kafka.common.errors
- DelegationTokenAuthorizationException(String) - Constructor for exception class org.apache.kafka.common.errors.DelegationTokenAuthorizationException
- DelegationTokenAuthorizationException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.DelegationTokenAuthorizationException
- DelegationTokenDisabledException - Exception Class in org.apache.kafka.common.errors
- DelegationTokenDisabledException(String) - Constructor for exception class org.apache.kafka.common.errors.DelegationTokenDisabledException
- DelegationTokenDisabledException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.DelegationTokenDisabledException
- DelegationTokenExpiredException - Exception Class in org.apache.kafka.common.errors
- DelegationTokenExpiredException(String) - Constructor for exception class org.apache.kafka.common.errors.DelegationTokenExpiredException
- DelegationTokenExpiredException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.DelegationTokenExpiredException
- DelegationTokenNotFoundException - Exception Class in org.apache.kafka.common.errors
- DelegationTokenNotFoundException(String) - Constructor for exception class org.apache.kafka.common.errors.DelegationTokenNotFoundException
- DelegationTokenNotFoundException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.DelegationTokenNotFoundException
- DelegationTokenOwnerMismatchException - Exception Class in org.apache.kafka.common.errors
- DelegationTokenOwnerMismatchException(String) - Constructor for exception class org.apache.kafka.common.errors.DelegationTokenOwnerMismatchException
- DelegationTokenOwnerMismatchException(String, Throwable) - Constructor for exception class 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(K) - Method in interface org.apache.kafka.streams.state.KeyValueStore
- 
Delete the value from the store (if there is one).
- delete(K, long) - Method in interface org.apache.kafka.streams.state.VersionedKeyValueStore
- 
Delete the value associated with this key from the store, at the specified timestamp (if there is such a value), and return the deleted value.
- delete(Bytes, long) - Method in interface org.apache.kafka.streams.state.VersionedBytesStore
- 
The analog ofVersionedKeyValueStore.delete(Object, long).
- DELETE - Enum constant in enum class org.apache.kafka.clients.admin.AlterConfigOp.OpType
- 
Revert the configuration entry to the default value (possibly null).
- DELETE - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
- 
DELETE operation.
- DELETE_PARTITION_FINISHED - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
- 
This state indicates that the partition is deleted successfully.
- DELETE_PARTITION_MARKED - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
- 
This is used when a topic/partition is marked for delete by the controller.
- DELETE_PARTITION_STARTED - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
- 
This state indicates that the partition deletion is started but not yet finished.
- 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
- DELETE_SEGMENT_FINISHED - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
- 
This state indicates that the segment is deleted successfully.
- DELETE_SEGMENT_STARTED - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
- 
This state indicates that the segment deletion is started but not yet finished.
- deleteAcls(Collection<AclBindingFilter>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
This is a convenience method forAdmin.deleteAcls(Collection, DeleteAclsOptions)with default options.
- deleteAcls(Collection<AclBindingFilter>, DeleteAclsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Deletes access control lists (ACLs) according to the supplied filters.
- deleteAcls(Collection<AclBindingFilter>, DeleteAclsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- deleteAcls(Collection<AclBindingFilter>, DeleteAclsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- deleteAcls(AuthorizableRequestContext, List<AclBindingFilter>) - Method in interface org.apache.kafka.server.authorizer.Authorizer
- 
Deletes all ACL bindings that match the provided filters.
- DeleteAclsOptions - Class in org.apache.kafka.clients.admin
- 
Options for theAdmin.deleteAcls(Collection)call.
- DeleteAclsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteAclsOptions
- DeleteAclsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.deleteAcls(Collection)call.
- 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.
- deleteConsumerGroupOffsets(String, Set<TopicPartition>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Delete committed offsets for a set of partitions in a consumer group with the default options.
- deleteConsumerGroupOffsets(String, Set<TopicPartition>, DeleteConsumerGroupOffsetsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Delete committed offsets for a set of partitions in a consumer group.
- deleteConsumerGroupOffsets(String, Set<TopicPartition>, DeleteConsumerGroupOffsetsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- deleteConsumerGroupOffsets(String, Set<TopicPartition>, DeleteConsumerGroupOffsetsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DeleteConsumerGroupOffsetsOptions - Class in org.apache.kafka.clients.admin
- 
Options for theAdmin.deleteConsumerGroupOffsets(String, Set)call.
- DeleteConsumerGroupOffsetsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteConsumerGroupOffsetsOptions
- DeleteConsumerGroupOffsetsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.deleteConsumerGroupOffsets(String, Set)call.
- deleteConsumerGroups(Collection<String>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Delete consumer groups from the cluster with the default options.
- deleteConsumerGroups(Collection<String>, DeleteConsumerGroupsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Delete consumer groups from the cluster.
- deleteConsumerGroups(Collection<String>, DeleteConsumerGroupsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- deleteConsumerGroups(Collection<String>, DeleteConsumerGroupsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DeleteConsumerGroupsOptions - Class in org.apache.kafka.clients.admin
- 
Options for theAdmin.deleteConsumerGroups(Collection)call.
- DeleteConsumerGroupsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteConsumerGroupsOptions
- DeleteConsumerGroupsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.deleteConsumerGroups(Collection)call.
- 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
- DeletedRecords(long) - Constructor for class org.apache.kafka.clients.admin.DeletedRecords
- 
Create an instance of this class with the provided parameters.
- deleteLogSegmentData(RemoteLogSegmentMetadata) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteStorageManager
- 
Deletes the resources associated with the givenremoteLogSegmentMetadata.
- deleteRecords(Map<TopicPartition, RecordsToDelete>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Delete records whose offset is smaller than the given offset of the corresponding partition.
- deleteRecords(Map<TopicPartition, RecordsToDelete>, DeleteRecordsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Delete records whose offset is smaller than the given offset of the corresponding partition.
- deleteRecords(Map<TopicPartition, RecordsToDelete>, DeleteRecordsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- deleteRecords(Map<TopicPartition, RecordsToDelete>, DeleteRecordsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DeleteRecordsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.deleteRecords(Map, DeleteRecordsOptions).
- DeleteRecordsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteRecordsOptions
- DeleteRecordsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.deleteRecords(Map)call.
- DeleteRecordsResult(Map<TopicPartition, KafkaFuture<DeletedRecords>>) - Constructor for class org.apache.kafka.clients.admin.DeleteRecordsResult
- deleteTopics(Collection<String>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
This is a convenience method forAdmin.deleteTopics(TopicCollection, DeleteTopicsOptions)with default options.
- deleteTopics(Collection<String>, DeleteTopicsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
This is a convenience method forAdmin.deleteTopics(TopicCollection, DeleteTopicsOptions)with default options.
- deleteTopics(TopicCollection) - Method in interface org.apache.kafka.clients.admin.Admin
- 
This is a convenience method forAdmin.deleteTopics(TopicCollection, DeleteTopicsOptions)with default options.
- deleteTopics(TopicCollection, DeleteTopicsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Delete a batch of topics.
- deleteTopics(TopicCollection, DeleteTopicsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- deleteTopics(TopicCollection, DeleteTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DeleteTopicsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.deleteTopics(Collection).
- DeleteTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteTopicsOptions
- DeleteTopicsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.deleteTopics(Collection)call.
- DELIVERY_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
delivery.timeout.ms
- deliveryCount() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
- 
Get the delivery count for the record if available.
- DENIED - Enum constant in enum class org.apache.kafka.server.authorizer.AuthorizationResult
- DENY - Enum constant in enum class org.apache.kafka.common.acl.AclPermissionType
- 
Disallows access.
- dependents - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
- DESCENDING - Enum constant in enum class org.apache.kafka.streams.query.ResultOrder
- describe() - Method in class org.apache.kafka.streams.Topology
- 
Returns a description of the specifiedTopology.
- DESCRIBE - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
- 
DESCRIBE operation.
- DESCRIBE_CONFIGS - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
- 
DESCRIBE_CONFIGS operation.
- DESCRIBE_TOKENS - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
- 
DESCRIBE_TOKENS operation.
- describeAcls(AclBindingFilter) - Method in interface org.apache.kafka.clients.admin.Admin
- 
This is a convenience method forAdmin.describeAcls(AclBindingFilter, DescribeAclsOptions)with default options.
- describeAcls(AclBindingFilter, DescribeAclsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Lists access control lists (ACLs) according to the supplied filter.
- describeAcls(AclBindingFilter, DescribeAclsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeAcls(AclBindingFilter, DescribeAclsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeAclsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.describeAcls(AclBindingFilter).
- DescribeAclsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeAclsOptions
- DescribeAclsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.describeAcls(AclBindingFilter)call.
- describeClassicGroups(Collection<String>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe some classic groups in the cluster, with the default options.
- describeClassicGroups(Collection<String>, DescribeClassicGroupsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe some classic groups in the cluster.
- describeClassicGroups(Collection<String>, DescribeClassicGroupsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeClassicGroups(Collection<String>, DescribeClassicGroupsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeClassicGroupsOptions - Class in org.apache.kafka.clients.admin
- DescribeClassicGroupsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeClassicGroupsOptions
- DescribeClassicGroupsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.describeClassicGroups(Collection, DescribeClassicGroupsOptions)} call.
- DescribeClassicGroupsResult(Map<String, KafkaFuture<ClassicGroupDescription>>) - Constructor for class org.apache.kafka.clients.admin.DescribeClassicGroupsResult
- describeClientQuotas(ClientQuotaFilter) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describes all entities matching the provided filter that have at least one client quota configuration value defined.
- describeClientQuotas(ClientQuotaFilter, DescribeClientQuotasOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describes all entities matching the provided filter that have at least one client quota configuration value defined.
- describeClientQuotas(ClientQuotaFilter, DescribeClientQuotasOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeClientQuotas(ClientQuotaFilter, DescribeClientQuotasOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeClientQuotasOptions - Class in org.apache.kafka.clients.admin
- DescribeClientQuotasOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeClientQuotasOptions
- DescribeClientQuotasResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.describeClientQuotas(ClientQuotaFilter, DescribeClientQuotasOptions)call.
- DescribeClientQuotasResult(KafkaFuture<Map<ClientQuotaEntity, Map<String, Double>>>) - Constructor for class org.apache.kafka.clients.admin.DescribeClientQuotasResult
- 
Maps an entity to its configured quota value(s).
- describeCluster() - Method in interface org.apache.kafka.clients.admin.Admin
- 
Get information about the nodes in the cluster, using the default options.
- describeCluster(DescribeClusterOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Get information about the nodes in the cluster.
- describeCluster(DescribeClusterOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeCluster(DescribeClusterOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeClusterOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.describeCluster().
- DescribeClusterOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeClusterOptions
- DescribeClusterResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.describeCluster()call.
- describeConfigs(Collection<ConfigResource>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Get the configuration for the specified resources with the default options.
- describeConfigs(Collection<ConfigResource>, DescribeConfigsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Get the configuration for the specified resources.
- describeConfigs(Collection<ConfigResource>, DescribeConfigsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeConfigs(Collection<ConfigResource>, DescribeConfigsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeConfigsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.describeConfigs(Collection).
- DescribeConfigsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeConfigsOptions
- DescribeConfigsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.describeConfigs(Collection)call.
- describeConsumerGroups(Collection<String>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe some consumer groups in the cluster, with the default options.
- describeConsumerGroups(Collection<String>, DescribeConsumerGroupsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe some consumer groups in the cluster.
- describeConsumerGroups(Collection<String>, DescribeConsumerGroupsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- 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
- 
The result of theKafkaAdminClient.describeConsumerGroups(Collection, DescribeConsumerGroupsOptions)} call.
- DescribeConsumerGroupsResult(Map<String, KafkaFuture<ConsumerGroupDescription>>) - Constructor for class org.apache.kafka.clients.admin.DescribeConsumerGroupsResult
- describeDelegationToken() - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe the Delegation Tokens.
- describeDelegationToken(DescribeDelegationTokenOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe the Delegation Tokens.
- describeDelegationToken(DescribeDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- 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
- 
The result of theKafkaAdminClient.describeDelegationToken(DescribeDelegationTokenOptions)call.
- describedGroups() - Method in class org.apache.kafka.clients.admin.DescribeClassicGroupsResult
- 
Return a map from group id to futures which yield group descriptions.
- describedGroups() - Method in class org.apache.kafka.clients.admin.DescribeConsumerGroupsResult
- 
Return a map from group id to futures which yield group descriptions.
- describedGroups() - Method in class org.apache.kafka.clients.admin.DescribeShareGroupsResult
- 
Return a map from group id to futures which yield share group descriptions.
- describeFeatures() - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describes finalized as well as supported features.
- describeFeatures(DescribeFeaturesOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describes finalized as well as supported features.
- describeFeatures(DescribeFeaturesOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeFeatures(DescribeFeaturesOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeFeaturesOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.describeFeatures(DescribeFeaturesOptions).
- DescribeFeaturesOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeFeaturesOptions
- DescribeFeaturesResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.describeFeatures(DescribeFeaturesOptions)call.
- describeLogDirs(Collection<Integer>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Query the information of all log directories on the given set of brokers
- describeLogDirs(Collection<Integer>, DescribeLogDirsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Query the information of all log directories on the given set of brokers
- describeLogDirs(Collection<Integer>, DescribeLogDirsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeLogDirs(Collection<Integer>, DescribeLogDirsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeLogDirsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.describeLogDirs(Collection)
- DescribeLogDirsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeLogDirsOptions
- DescribeLogDirsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.describeLogDirs(Collection)call.
- describeMetadataQuorum() - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describes the state of the metadata quorum.
- describeMetadataQuorum(DescribeMetadataQuorumOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describes the state of the metadata quorum.
- describeMetadataQuorum(DescribeMetadataQuorumOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeMetadataQuorum(DescribeMetadataQuorumOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeMetadataQuorumOptions - Class in org.apache.kafka.clients.admin
- DescribeMetadataQuorumOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeMetadataQuorumOptions
- DescribeMetadataQuorumResult - Class in org.apache.kafka.clients.admin
- describeProducers(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe producer state on a set of topic partitions.
- describeProducers(Collection<TopicPartition>, DescribeProducersOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe active producer state on a set of topic partitions.
- describeProducers(Collection<TopicPartition>, DescribeProducersOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeProducers(Collection<TopicPartition>, DescribeProducersOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeProducersOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.describeProducers(Collection).
- DescribeProducersOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeProducersOptions
- DescribeProducersResult - Class in org.apache.kafka.clients.admin
- DescribeProducersResult.PartitionProducerState - Class in org.apache.kafka.clients.admin
- describeReplicaLogDirs(Collection<TopicPartitionReplica>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Query the replica log directory information for the specified replicas.
- describeReplicaLogDirs(Collection<TopicPartitionReplica>, DescribeReplicaLogDirsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Query the replica log directory information for the specified replicas.
- describeReplicaLogDirs(Collection<TopicPartitionReplica>, DescribeReplicaLogDirsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeReplicaLogDirs(Collection<TopicPartitionReplica>, DescribeReplicaLogDirsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeReplicaLogDirsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.describeReplicaLogDirs(Collection).
- DescribeReplicaLogDirsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeReplicaLogDirsOptions
- DescribeReplicaLogDirsResult - Class in org.apache.kafka.clients.admin
- 
The result ofAdmin.describeReplicaLogDirs(Collection).
- DescribeReplicaLogDirsResult.ReplicaLogDirInfo - Class in org.apache.kafka.clients.admin
- describeShareGroups(Collection<String>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe some share groups in the cluster, with the default options.
- describeShareGroups(Collection<String>, DescribeShareGroupsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe some share groups in the cluster.
- describeShareGroups(Collection<String>, DescribeShareGroupsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeShareGroups(Collection<String>, DescribeShareGroupsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeShareGroupsOptions - Class in org.apache.kafka.clients.admin
- DescribeShareGroupsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeShareGroupsOptions
- DescribeShareGroupsResult - Class in org.apache.kafka.clients.admin
- 
The result of theKafkaAdminClient.describeShareGroups(Collection, DescribeShareGroupsOptions)} call.
- DescribeShareGroupsResult(Map<String, KafkaFuture<ShareGroupDescription>>) - Constructor for class org.apache.kafka.clients.admin.DescribeShareGroupsResult
- describeTopics(Collection<String>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe some topics in the cluster, with the default options.
- describeTopics(Collection<String>, DescribeTopicsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe some topics in the cluster.
- describeTopics(TopicCollection) - Method in interface org.apache.kafka.clients.admin.Admin
- 
This is a convenience method forAdmin.describeTopics(TopicCollection, DescribeTopicsOptions)with default options.
- describeTopics(TopicCollection, DescribeTopicsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe some topics in the cluster.
- describeTopics(TopicCollection, DescribeTopicsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeTopics(TopicCollection, DescribeTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeTopicsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.describeTopics(Collection).
- DescribeTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeTopicsOptions
- DescribeTopicsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.describeTopics(Collection)call.
- describeTransactions(Collection<String>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe the state of a set of transactional IDs.
- describeTransactions(Collection<String>, DescribeTransactionsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe the state of a set of transactional IDs from the respective transaction coordinators, which are dynamically discovered.
- describeTransactions(Collection<String>, DescribeTransactionsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeTransactions(Collection<String>, DescribeTransactionsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeTransactionsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.describeTransactions(Collection).
- DescribeTransactionsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeTransactionsOptions
- DescribeTransactionsResult - Class in org.apache.kafka.clients.admin
- describeUserScramCredentials() - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe all SASL/SCRAM credentials.
- describeUserScramCredentials(List<String>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe SASL/SCRAM credentials for the given users.
- describeUserScramCredentials(List<String>, DescribeUserScramCredentialsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Describe SASL/SCRAM credentials.
- describeUserScramCredentials(List<String>, DescribeUserScramCredentialsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeUserScramCredentials(List<String>, DescribeUserScramCredentialsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeUserScramCredentialsOptions - Class in org.apache.kafka.clients.admin
- DescribeUserScramCredentialsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeUserScramCredentialsOptions
- DescribeUserScramCredentialsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.describeUserScramCredentials()call.
- description() - Method in class org.apache.kafka.common.MetricName
- description() - Method in class org.apache.kafka.common.MetricNameTemplate
- 
Get the description of the metric.
- description(String) - Method in class org.apache.kafka.clients.admin.DescribeTransactionsResult
- 
Get the description of a specific transactional ID.
- description(String) - Method in class org.apache.kafka.clients.admin.DescribeUserScramCredentialsResult
- descriptions() - 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.
- DESERIALIZATION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
deserialization.exception.handler
- deserializationExceptionHandler - Variable in class org.apache.kafka.streams.TopologyConfig.TaskConfig
- deserializationExceptionHandler() - Method in class org.apache.kafka.streams.StreamsConfig
- DeserializationExceptionHandler - Interface in org.apache.kafka.streams.errors
- 
Interface that specifies how an exception from source node deserialization (e.g., reading from Kafka) should be handled.
- DeserializationExceptionHandler.DeserializationHandlerResponse - Enum Class in org.apache.kafka.streams.errors
- 
Enumeration that describes the response from the exception handler.
- deserializationExceptionHandlerSupplier - Variable in class org.apache.kafka.streams.TopologyConfig
- deserialize(byte[]) - Method in interface org.apache.kafka.common.security.auth.KafkaPrincipalSerde
- 
Deserialize aKafkaPrincipalfrom byte array.
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.BooleanDeserializer
- 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.FloatDeserializer
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.IntegerDeserializer
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ListDeserializer
- 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, byte[]) - Method in class org.apache.kafka.common.serialization.VoidDeserializer
- deserialize(String, byte[]) - Method in class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
- deserialize(String, byte[]) - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
- 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, ByteBuffer) - Method in class org.apache.kafka.common.serialization.BooleanDeserializer
- deserialize(String, Headers, ByteBuffer) - Method in class org.apache.kafka.common.serialization.ByteBufferDeserializer
- deserialize(String, Headers, ByteBuffer) - Method in interface org.apache.kafka.common.serialization.Deserializer
- 
Deserialize a record value from aByteBufferinto a value or object.
- deserialize(String, Headers, ByteBuffer) - Method in class org.apache.kafka.common.serialization.DoubleDeserializer
- deserialize(String, Headers, ByteBuffer) - Method in class org.apache.kafka.common.serialization.FloatDeserializer
- deserialize(String, Headers, ByteBuffer) - Method in class org.apache.kafka.common.serialization.IntegerDeserializer
- deserialize(String, Headers, ByteBuffer) - Method in class org.apache.kafka.common.serialization.LongDeserializer
- deserialize(String, Headers, ByteBuffer) - Method in class org.apache.kafka.common.serialization.ShortDeserializer
- deserialize(String, Headers, ByteBuffer) - Method in class org.apache.kafka.common.serialization.StringDeserializer
- deserialize(String, Headers, ByteBuffer) - Method in class org.apache.kafka.common.serialization.UUIDDeserializer
- deserialize(String, Headers, ByteBuffer) - Method in class org.apache.kafka.common.serialization.VoidDeserializer
- 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.
- deserializeRecord(ConsumerRecord<byte[], byte[]>) - Static method in class org.apache.kafka.connect.mirror.Checkpoint
- deserializeRecord(ConsumerRecord<byte[], byte[]>) - Static method in class org.apache.kafka.connect.mirror.Heartbeat
- Detecting Consumer Failures - Search tag in class org.apache.kafka.clients.consumer.KafkaConsumer
- Section
- Detecting Consumer Failures - Search tag in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- Section
- Direct Branch Consuming - Search tag in interface org.apache.kafka.streams.kstream.BranchedKStream
- Section
- DirectoryConfigProvider - Class in org.apache.kafka.common.config.provider
- 
An implementation ofConfigProviderbased on a directory of files.
- DirectoryConfigProvider() - Constructor for class org.apache.kafka.common.config.provider.DirectoryConfigProvider
- disableTelemetry() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- disableTelemetry() - Method in class org.apache.kafka.clients.producer.MockProducer
- DisconnectException - Exception Class in org.apache.kafka.common.errors
- 
Server disconnected before a request could be completed.
- DisconnectException() - Constructor for exception class org.apache.kafka.common.errors.DisconnectException
- DisconnectException(String) - Constructor for exception class org.apache.kafka.common.errors.DisconnectException
- DisconnectException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.DisconnectException
- DisconnectException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.DisconnectException
- displayName - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
- divergentOffsets() - Method in exception class org.apache.kafka.clients.consumer.LogTruncationException
- 
Get the divergent offsets for the partitions which were truncated.
- doc() - Method in class org.apache.kafka.connect.data.ConnectSchema
- doc() - Method in interface org.apache.kafka.connect.data.Schema
- doc() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- doc(String) - Method in class org.apache.kafka.connect.data.SchemaBuilder
- 
Set the documentation for this schema.
- documentation - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
- documentation() - Method in class org.apache.kafka.clients.admin.ConfigEntry
- 
Return the config documentation.
- documentationOf(String) - Method in class org.apache.kafka.common.config.AbstractConfig
- DOES_NOT_EXIST - Enum constant in enum class org.apache.kafka.streams.query.FailureReason
- 
The requested store partition does not exist at all.
- Double() - Static method in class org.apache.kafka.common.serialization.Serdes
- 
A serde for nullableDoubletype.
- DOUBLE - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigType
- DOUBLE - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Type
- 
Used for numerical values within the Java Double range.
- 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
- DOWNSTREAM_OFFSET_KEY - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
- downstreamOffset() - Method in class org.apache.kafka.connect.mirror.Checkpoint
- Driver setup - Search tag in class org.apache.kafka.streams.TopologyTestDriver
- Section
- DSL_STORE_SUPPLIERS_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
dsl.store.suppliers.class
- DslKeyValueParams - Class in org.apache.kafka.streams.state
- 
DslKeyValueParamsis a wrapper class for all parameters that function as inputs toDslStoreSuppliers.keyValueStore(DslKeyValueParams).
- DslKeyValueParams(String, boolean) - Constructor for class org.apache.kafka.streams.state.DslKeyValueParams
- DslSessionParams - Class in org.apache.kafka.streams.state
- 
DslSessionParamsis a wrapper class for all parameters that function as inputs toDslStoreSuppliers.sessionStore(DslSessionParams).
- DslSessionParams(String, Duration, EmitStrategy) - Constructor for class org.apache.kafka.streams.state.DslSessionParams
- dslStoreSuppliers - Variable in class org.apache.kafka.streams.TopologyConfig
- DslStoreSuppliers - Interface in org.apache.kafka.streams.state
- 
DslStoreSuppliersdefines a grouping of factories to construct stores for each of the types of state store implementations in Kafka Streams.
- DslWindowParams - Class in org.apache.kafka.streams.state
- 
DslWindowParamsis a wrapper class for all parameters that function as inputs toDslStoreSuppliers.windowStore(DslWindowParams).
- DslWindowParams(String, Duration, Duration, boolean, EmitStrategy, boolean, boolean) - Constructor for class org.apache.kafka.streams.state.DslWindowParams
- DUMMY_THREAD_INDEX - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- duplicate() - Method in class org.apache.kafka.connect.header.ConnectHeaders
- duplicate() - Method in interface org.apache.kafka.connect.header.Headers
- 
Create a copy of thisHeadersobject.
- DuplicateBrokerRegistrationException - Exception Class in org.apache.kafka.common.errors
- DuplicateBrokerRegistrationException(String) - Constructor for exception class org.apache.kafka.common.errors.DuplicateBrokerRegistrationException
- DuplicateBrokerRegistrationException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.DuplicateBrokerRegistrationException
- DuplicateResourceException - Exception Class in org.apache.kafka.common.errors
- 
Exception thrown due to a request that illegally refers to the same resource twice (for example, trying to both create and delete the same SCRAM credential for a particular user in a single request).
- DuplicateResourceException(String) - Constructor for exception class org.apache.kafka.common.errors.DuplicateResourceException
- 
Constructor
- DuplicateResourceException(String, String) - Constructor for exception class org.apache.kafka.common.errors.DuplicateResourceException
- 
Constructor
- DuplicateResourceException(String, String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.DuplicateResourceException
- 
Constructor
- DuplicateResourceException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.DuplicateResourceException
- DuplicateSequenceException - Exception Class in org.apache.kafka.common.errors
- DuplicateSequenceException(String) - Constructor for exception class org.apache.kafka.common.errors.DuplicateSequenceException
- DuplicateVoterException - Exception Class in org.apache.kafka.common.errors
- DuplicateVoterException(String) - Constructor for exception class org.apache.kafka.common.errors.DuplicateVoterException
- DuplicateVoterException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.DuplicateVoterException
- DYNAMIC_BROKER_CONFIG - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
- DYNAMIC_BROKER_LOGGER_CONFIG - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
- DYNAMIC_CLIENT_METRICS_CONFIG - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
- DYNAMIC_DEFAULT_BROKER_CONFIG - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
- DYNAMIC_GROUP_CONFIG - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
- DYNAMIC_TOPIC_CONFIG - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
- Dynamic branching - Search tag in interface org.apache.kafka.streams.kstream.BranchedKStream
- Section
E
- EAGER - Enum constant in enum class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
- earliest() - Static method in class org.apache.kafka.clients.admin.OffsetSpec
- 
Used to retrieve the earliest offset of a partition
- earliest() - Static method in class org.apache.kafka.streams.AutoOffsetReset
- 
Creates anAutoOffsetResetinstance representing "earliest".
- EARLIEST - Enum constant in enum class org.apache.kafka.clients.consumer.OffsetResetStrategy
- 
Deprecated.
- EARLIEST - Enum constant in enum class org.apache.kafka.streams.Topology.AutoOffsetReset
- 
Deprecated.
- earliestLocal() - Static method in class org.apache.kafka.clients.admin.OffsetSpec
- 
Used to retrieve the local log start offset.
- EarliestLocalSpec() - Constructor for class org.apache.kafka.clients.admin.OffsetSpec.EarliestLocalSpec
- EarliestSpec() - Constructor for class org.apache.kafka.clients.admin.OffsetSpec.EarliestSpec
- earlyStartListeners() - Method in interface org.apache.kafka.server.authorizer.AuthorizerServerInfo
- 
Returns the configured early start listeners.
- ElectionNotNeededException - Exception Class in org.apache.kafka.common.errors
- ElectionNotNeededException(String) - Constructor for exception class org.apache.kafka.common.errors.ElectionNotNeededException
- ElectionNotNeededException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.ElectionNotNeededException
- ElectionType - Enum Class in org.apache.kafka.common
- electLeaders(ElectionType, Set<TopicPartition>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Elect a replica as leader for topic partitions.
- electLeaders(ElectionType, Set<TopicPartition>, ElectLeadersOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Elect a replica as leader for the givenpartitions, or for all partitions if the argument topartitionsis null.
- electLeaders(ElectionType, Set<TopicPartition>, ElectLeadersOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- electLeaders(ElectionType, Set<TopicPartition>, ElectLeadersOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- ElectLeadersOptions - Class in org.apache.kafka.clients.admin
- ElectLeadersOptions() - Constructor for class org.apache.kafka.clients.admin.ElectLeadersOptions
- ElectLeadersResult - Class in org.apache.kafka.clients.admin
- 
The result ofAdmin.electLeaders(ElectionType, Set, ElectLeadersOptions)The API of this class is evolving, seeAdminfor details.
- EligibleLeadersNotAvailableException - Exception Class in org.apache.kafka.common.errors
- EligibleLeadersNotAvailableException(String) - Constructor for exception class org.apache.kafka.common.errors.EligibleLeadersNotAvailableException
- EligibleLeadersNotAvailableException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.EligibleLeadersNotAvailableException
- elr() - Method in class org.apache.kafka.common.TopicPartitionInfo
- 
Return the eligible leader replicas of the partition.
- embed(String, String, int, ConfigDef) - Method in class org.apache.kafka.common.config.ConfigDef
- EMIT_INTERVAL_MS_KSTREAMS_OUTER_JOIN_SPURIOUS_RESULTS_FIX - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- EMIT_INTERVAL_MS_KSTREAMS_WINDOWED_AGGREGATION - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- emitEarlyWhenFull() - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
- 
Set the buffer to just emit the oldest records when any of its constraints are violated.
- emitStrategy() - Method in class org.apache.kafka.streams.state.DslSessionParams
- emitStrategy() - Method in class org.apache.kafka.streams.state.DslWindowParams
- emitStrategy(EmitStrategy) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
- 
Configure when the aggregated result will be emitted forSessionWindowedKStream.
- emitStrategy(EmitStrategy) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
- 
Configure when the aggregated result will be emitted forTimeWindowedKStream.
- EmitStrategy - Interface in org.apache.kafka.streams.kstream
- 
This interface controls the strategy that can be used to control how we emit results in a processor.
- EmitStrategy.StrategyType - Enum Class in org.apache.kafka.streams.kstream
- 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() - Static method in class org.apache.kafka.common.security.auth.SaslExtensions
- 
Creates an "empty" instance indicating no SASL extensions.
- EMPTY - Enum constant in enum class org.apache.kafka.clients.admin.TransactionState
- EMPTY - Enum constant in enum class org.apache.kafka.common.ClassicGroupState
- EMPTY - Enum constant in enum class org.apache.kafka.common.ConsumerGroupState
- 
Deprecated.
- EMPTY - Enum constant in enum class org.apache.kafka.common.GroupState
- EMPTY - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecords
- emptyPosition() - Static method in class org.apache.kafka.streams.query.Position
- 
Create a new, empty Position.
- 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
- ENABLE_METRICS_PUSH_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- 
enable.metrics.push
- ENABLE_METRICS_PUSH_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- 
enable.metrics.push
- ENABLE_METRICS_PUSH_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
enable.metrics.push
- ENABLE_METRICS_PUSH_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
enable.metrics.push
- ENABLE_METRICS_PUSH_DOC - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- ENABLE_METRICS_PUSH_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- ENABLE_METRICS_PUSH_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- ENABLE_METRICS_PUSH_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- ENABLE_PROCESS_PROCESSVALUE_FIX - Static variable in class org.apache.kafka.streams.TopologyConfig.InternalConfig
- enableExecutionInfo() - Method in class org.apache.kafka.streams.query.StateQueryRequest
- 
Requests for stores and the Streams runtime to record any useful details about how the query was executed.
- enableStaleStores() - Method in class org.apache.kafka.streams.StoreQueryParameters
- 
Enable querying of stale state stores, i.e., allow to query active tasks during restore as well as standby tasks.
- encoding() - Method in class org.apache.kafka.connect.storage.StringConverterConfig
- 
Get the string encoding.
- ENCODING_CONFIG - Static variable in class org.apache.kafka.connect.storage.StringConverterConfig
- ENCODING_DEFAULT - Static variable in class org.apache.kafka.connect.storage.StringConverterConfig
- end() - Method in class org.apache.kafka.streams.kstream.Window
- 
Return the end timestamp of this window.
- endOffset() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- endOffsetPosition() - Method in class org.apache.kafka.streams.LagInfo
- 
Get the end offset position for this store partition's changelog topic on the Kafka brokers.
- endOffsets() - Method in interface org.apache.kafka.streams.TaskMetadata
- 
End offsets of the source topic partitions of the task.
- 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
- Endpoint - Class in org.apache.kafka.common
- 
Represents a broker endpoint.
- Endpoint(String, SecurityProtocol, String, int) - Constructor for class org.apache.kafka.common.Endpoint
- endpoints() - Method in class org.apache.kafka.clients.admin.QuorumInfo.Node
- endpoints() - Method in interface org.apache.kafka.server.authorizer.AuthorizerServerInfo
- 
Returns endpoints for all listeners including the advertised host and port to which the listener is bound.
- EndpointType - Enum Class in org.apache.kafka.clients.admin
- 
Identifies the endpoint type, as specified by KIP-919.
- endTime() - Method in class org.apache.kafka.streams.kstream.Window
- 
Return the end time of this window.
- enforceRebalance() - Method in interface org.apache.kafka.clients.consumer.Consumer
- enforceRebalance() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
- enforceRebalance() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- enforceRebalance(String) - Method in interface org.apache.kafka.clients.consumer.Consumer
- enforceRebalance(String) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
- 
Alert the consumer to trigger a new rebalance by rejoining the group.
- enforceRebalance(String) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.CaseInsensitiveValidString
- 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.LambdaValidator
- ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.ListSize
- 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
- entities() - Method in class org.apache.kafka.clients.admin.DescribeClientQuotasResult
- 
Returns a map from quota entity to a future which can be used to check the status of the operation.
- entity() - Method in class org.apache.kafka.common.quota.ClientQuotaAlteration
- entityType() - Method in class org.apache.kafka.common.quota.ClientQuotaFilterComponent
- 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.
- entries() - Method in class org.apache.kafka.common.quota.ClientQuotaEntity
- entry() - Method in class org.apache.kafka.common.acl.AclBinding
- entryFilter() - Method in class org.apache.kafka.common.acl.AclBindingFilter
- EnvVarConfigProvider - Class in org.apache.kafka.common.config.provider
- 
An implementation ofConfigProviderbased on environment variables.
- EnvVarConfigProvider() - Constructor for class org.apache.kafka.common.config.provider.EnvVarConfigProvider
- EnvVarConfigProvider(Map<String, String>) - Constructor for class org.apache.kafka.common.config.provider.EnvVarConfigProvider
- eosEnabled - Variable in class org.apache.kafka.streams.TopologyConfig
- eosEnabled - Variable in class org.apache.kafka.streams.TopologyConfig.TaskConfig
- epochId(String) - Method in class org.apache.kafka.clients.admin.FenceProducersResult
- 
Returns a future that provides the epoch ID generated while initializing the given transaction when the request completes.
- equals(Object) - Method in class org.apache.kafka.clients.admin.AbortTransactionSpec
- equals(Object) - Method in class org.apache.kafka.clients.admin.AlterConfigOp
- equals(Object) - Method in class org.apache.kafka.clients.admin.ClassicGroupDescription
- equals(Object) - Method in class org.apache.kafka.clients.admin.ClientMetricsResourceListing
- 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.ConsumerGroupListing
- equals(Object) - Method in class org.apache.kafka.clients.admin.DescribeProducersOptions
- equals(Object) - Method in class org.apache.kafka.clients.admin.FeatureMetadata
- equals(Object) - Method in class org.apache.kafka.clients.admin.FeatureUpdate
- equals(Object) - Method in class org.apache.kafka.clients.admin.FinalizedVersionRange
- equals(Object) - Method in class org.apache.kafka.clients.admin.GroupListing
- equals(Object) - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsSpec
- equals(Object) - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
- equals(Object) - Method in class org.apache.kafka.clients.admin.ListTransactionsOptions
- 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.MemberToRemove
- equals(Object) - Method in class org.apache.kafka.clients.admin.NewTopic
- equals(Object) - Method in class org.apache.kafka.clients.admin.ProducerState
- equals(Object) - Method in class org.apache.kafka.clients.admin.QuorumInfo
- equals(Object) - Method in class org.apache.kafka.clients.admin.QuorumInfo.Node
- equals(Object) - Method in class org.apache.kafka.clients.admin.QuorumInfo.ReplicaState
- equals(Object) - Method in class org.apache.kafka.clients.admin.RaftVoterEndpoint
- equals(Object) - Method in class org.apache.kafka.clients.admin.RecordsToDelete
- equals(Object) - Method in class org.apache.kafka.clients.admin.ScramCredentialInfo
- equals(Object) - Method in class org.apache.kafka.clients.admin.ShareGroupDescription
- equals(Object) - Method in class org.apache.kafka.clients.admin.ShareMemberAssignment
- equals(Object) - Method in class org.apache.kafka.clients.admin.ShareMemberDescription
- equals(Object) - Method in class org.apache.kafka.clients.admin.SupportedVersionRange
- equals(Object) - Method in class org.apache.kafka.clients.admin.TopicDescription
- equals(Object) - Method in class org.apache.kafka.clients.admin.TransactionDescription
- equals(Object) - Method in class org.apache.kafka.clients.admin.TransactionListing
- equals(Object) - Method in class org.apache.kafka.clients.admin.UserScramCredentialsDescription
- equals(Object) - Method in class org.apache.kafka.clients.consumer.ConsumerGroupMetadata
- 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.consumer.SubscriptionPattern
- 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.Cluster
- equals(Object) - Method in class org.apache.kafka.common.ClusterResource
- 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.Endpoint
- 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.metrics.Quota
- equals(Object) - Method in class org.apache.kafka.common.Node
- equals(Object) - Method in class org.apache.kafka.common.PartitionInfo
- equals(Object) - Method in class org.apache.kafka.common.quota.ClientQuotaAlteration.Op
- equals(Object) - Method in class org.apache.kafka.common.quota.ClientQuotaEntity
- equals(Object) - Method in class org.apache.kafka.common.quota.ClientQuotaFilter
- equals(Object) - Method in class org.apache.kafka.common.quota.ClientQuotaFilterComponent
- equals(Object) - Method in class org.apache.kafka.common.resource.Resource
- 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
- 
Implements equals using the reference comparison implementation fromObject.equals(Object).
- 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.TopicIdPartition
- 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
- equals(Object) - Method in class org.apache.kafka.common.Uuid
- 
Returns true iff obj is another Uuid represented by the same two long values.
- equals(Object) - Method in class org.apache.kafka.connect.connector.ConnectRecord
- equals(Object) - Method in class org.apache.kafka.connect.data.ConnectSchema
- equals(Object) - Method in class org.apache.kafka.connect.data.Field
- equals(Object) - Method in class org.apache.kafka.connect.data.SchemaAndValue
- equals(Object) - Method in class org.apache.kafka.connect.data.Struct
- equals(Object) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- equals(Object) - Method in class org.apache.kafka.connect.health.AbstractState
- equals(Object) - Method in class org.apache.kafka.connect.health.ConnectorHealth
- equals(Object) - Method in class org.apache.kafka.connect.health.TaskState
- equals(Object) - Method in class org.apache.kafka.connect.mirror.Checkpoint
- equals(Object) - Method in class org.apache.kafka.connect.mirror.SourceAndTarget
- equals(Object) - Method in class org.apache.kafka.connect.sink.SinkRecord
- equals(Object) - Method in class org.apache.kafka.connect.source.SourceRecord
- equals(Object) - Method in class org.apache.kafka.coordinator.group.api.assignor.GroupAssignment
- equals(Object) - Method in class org.apache.kafka.server.authorizer.Action
- equals(Object) - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
- equals(Object) - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentId
- equals(Object) - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata.CustomMetadata
- equals(Object) - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- equals(Object) - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
- equals(Object) - Method in class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteMetadata
- equals(Object) - Method in class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
- equals(Object) - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
- equals(Object) - Method in class org.apache.kafka.streams.AutoOffsetReset
- equals(Object) - Method in class org.apache.kafka.streams.KeyQueryMetadata
- equals(Object) - Method in class org.apache.kafka.streams.KeyValue
- equals(Object) - Method in class org.apache.kafka.streams.kstream.Consumed
- equals(Object) - Method in class org.apache.kafka.streams.kstream.JoinWindows
- equals(Object) - Method in class org.apache.kafka.streams.kstream.Produced
- equals(Object) - Method in class org.apache.kafka.streams.kstream.SessionWindows
- equals(Object) - Method in class org.apache.kafka.streams.kstream.SlidingWindows
- equals(Object) - Method in class org.apache.kafka.streams.kstream.TimeWindows
- equals(Object) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
- equals(Object) - Method in class org.apache.kafka.streams.kstream.Window
- equals(Object) - Method in class org.apache.kafka.streams.kstream.Windowed
- equals(Object) - Method in class org.apache.kafka.streams.LagInfo
- equals(Object) - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
- equals(Object) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedForward
- equals(Object) - Method in class org.apache.kafka.streams.processor.api.Record
- equals(Object) - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask
- equals(Object) - Method in class org.apache.kafka.streams.processor.assignment.ProcessId
- equals(Object) - Method in class org.apache.kafka.streams.processor.TaskId
- equals(Object) - Method in class org.apache.kafka.streams.processor.To
- equals(Object) - Method in class org.apache.kafka.streams.query.Position
- equals(Object) - Method in class org.apache.kafka.streams.query.PositionBound
- equals(Object) - Method in class org.apache.kafka.streams.state.DslKeyValueParams
- equals(Object) - Method in class org.apache.kafka.streams.state.DslSessionParams
- equals(Object) - Method in class org.apache.kafka.streams.state.DslWindowParams
- equals(Object) - Method in class org.apache.kafka.streams.state.HostInfo
- equals(Object) - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
- equals(Object) - Method in class org.apache.kafka.streams.state.VersionedRecord
- equals(Object) - Method in class org.apache.kafka.streams.StoreQueryParameters
- equals(Object) - Method in interface org.apache.kafka.streams.StreamsMetadata
- 
Compares the specified object with this StreamsMetadata.
- equals(Object) - Method in interface org.apache.kafka.streams.TaskMetadata
- 
Compares the specified object with this TaskMetadata.
- equals(Object) - Method in class org.apache.kafka.streams.test.TestRecord
- equals(Object) - Method in interface org.apache.kafka.streams.ThreadMetadata
- 
Compares the specified object with this ThreadMetadata.
- errantRecordReporter() - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
- 
Get the reporter to which the sink task can report problematic or failedrecordspassed to theSinkTask.put(java.util.Collection)method.
- ErrantRecordReporter - Interface in org.apache.kafka.connect.sink
- 
Component that aSinkTaskcan use to report problematic records (and their corresponding problems) as it writes them throughSinkTask.put(java.util.Collection).
- error() - Method in class org.apache.kafka.clients.admin.LogDirDescription
- 
Returns `ApiException` if the log directory is offline or an error occurred, otherwise returns null.
- 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
- 
Set the error values as per RFC 6749: The OAuth 2.0 Authorization Framework.
- error(String, String, String) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
- 
Set the error values as per RFC 7628: A Set of Simple Authentication and Security Layer (SASL) Mechanisms for OAuth.
- ERROR - Enum constant in enum class org.apache.kafka.streams.KafkaStreams.State
- ERROR_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
- 
TheERRORlevel designates error events that might still allow the broker to continue running.
- 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.
- ErrorHandlerContext - Interface in org.apache.kafka.streams.errors
- 
This interface allows user code to inspect the context of a record that has failed during processing.
- 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.
- errors() - Method in class org.apache.kafka.clients.admin.ListGroupsResult
- 
Returns a future which yields just the errors which occurred.
- errorScope() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
- 
Return the (potentially null) error scope value as per RFC 7628: A Set of Simple Authentication and Security Layer (SASL) Mechanisms for OAuth.
- errorStatus() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
- 
Return the (potentially null) error status value as per RFC 7628: A Set of Simple Authentication and Security Layer (SASL) Mechanisms for OAuth and the IANA OAuth Extensions Error Registry.
- 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.
- eventTimestampMs() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogMetadata
- eventWindow() - Method in class org.apache.kafka.common.metrics.MetricConfig
- eventWindow(long) - Method in class org.apache.kafka.common.metrics.MetricConfig
- EXACTLY_ONCE_V2 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"processing.guarantee"for exactly-once processing guarantees.
- exactlyOnceSupport(Map<String, String>) - Method in class org.apache.kafka.connect.source.SourceConnector
- 
Signals whether the connector supports exactly-once semantics with a proposed configuration.
- ExactlyOnceSupport - Enum Class in org.apache.kafka.connect.source
- 
An enum to represent the level of support for exactly-once semantics from a source connector.
- 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.
- exception() - Method in class org.apache.kafka.server.authorizer.AclCreateResult
- 
Returns any exception during create.
- exception() - Method in class org.apache.kafka.server.authorizer.AclDeleteResult.AclBindingDeleteResult
- 
Returns any exception that resulted in failure to delete ACL binding.
- exception() - Method in class org.apache.kafka.server.authorizer.AclDeleteResult
- 
Returns any exception while attempting to match ACL filter to delete ACLs.
- EXCLUDE_CONFIG - Static variable in class org.apache.kafka.common.metrics.JmxReporter
- EXCLUDE_INTERNAL_TOPICS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- 
exclude.internal.topics
- executionInfoEnabled() - Method in class org.apache.kafka.streams.query.StateQueryRequest
- 
Whether the request includes detailed execution information.
- expireDelegationToken(byte[]) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Expire a Delegation Token.
- expireDelegationToken(byte[], ExpireDelegationTokenOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Expire a Delegation Token.
- expireDelegationToken(byte[], ExpireDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- 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
- 
The result of theKafkaAdminClient.expireDelegationToken(byte[], ExpireDelegationTokenOptions)call.
- 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
- exportMetrics(AuthorizableRequestContext, ClientTelemetryPayload) - Method in interface org.apache.kafka.server.telemetry.ClientTelemetryReceiver
- 
Called by the broker when a client reports telemetry metrics.
- extensions() - Method in class org.apache.kafka.common.security.auth.SaslExtensionsCallback
- 
Returns always non-nullSaslExtensionsconsisting 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.
- extract(K, V, RecordContext) - Method in interface org.apache.kafka.streams.processor.TopicNameExtractor
- 
Extracts the topic name to send to.
- extract(ConsumerRecord<Object, Object>, long) - Method in class org.apache.kafka.streams.processor.FailOnInvalidTimestamp
- 
Extracts the embedded metadata timestamp from the givenConsumerRecord.
- extract(ConsumerRecord<Object, Object>, long) - Method in class org.apache.kafka.streams.processor.LogAndSkipOnInvalidTimestamp
- 
Extracts the embedded metadata timestamp from the givenConsumerRecord.
- extract(ConsumerRecord<Object, Object>, long) - Method in class org.apache.kafka.streams.processor.UsePartitionTimeOnInvalidTimestamp
- 
Extracts the embedded metadata timestamp from the givenConsumerRecord.
- extract(ConsumerRecord<Object, Object>, long) - Method in interface org.apache.kafka.streams.processor.TimestampExtractor
- 
Extracts a timestamp from a record.
- extract(ConsumerRecord<Object, Object>, long) - Method in class org.apache.kafka.streams.processor.WallclockTimestampExtractor
- 
Return the current wall clock time as timestamp.
F
- FAIL - Enum constant in enum class org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
- 
Fail processing.
- FAIL - Enum constant in enum class org.apache.kafka.streams.errors.ProcessingExceptionHandler.ProcessingHandlerResponse
- 
Fail processing.
- FAIL - Enum constant in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
- 
Fail processing.
- FAILED_BUILD_REMOTE_LOG_AUX_STATE_PER_SEC_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- FAILED_REMOTE_COPY_PER_SEC_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- FAILED_REMOTE_DELETE_PER_SEC_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- FAILED_REMOTE_FETCH_PER_SEC_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- FailOnInvalidTimestamp - Class in org.apache.kafka.streams.processor
- 
Retrieves embedded metadata timestamps from Kafka messages.
- FailOnInvalidTimestamp() - Constructor for class org.apache.kafka.streams.processor.FailOnInvalidTimestamp
- FailureReason - Enum Class in org.apache.kafka.streams.query
- 
This enumeration type captures the various top-level reasons that a particular partition of a store would fail to execute a query.
- FATAL_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
- 
TheFATALlevel designates a very severe error that will lead the Kafka broker to abort.
- featureMetadata() - Method in class org.apache.kafka.clients.admin.DescribeFeaturesResult
- FeatureMetadata - Class in org.apache.kafka.clients.admin
- 
Encapsulates details about finalized as well as supported features.
- FeatureUpdate - Class in org.apache.kafka.clients.admin
- 
Encapsulates details about an update to a finalized feature.
- FeatureUpdate(short, FeatureUpdate.UpgradeType) - Constructor for class org.apache.kafka.clients.admin.FeatureUpdate
- FeatureUpdate.UpgradeType - Enum Class in org.apache.kafka.clients.admin
- FeatureUpdateFailedException - Exception Class in org.apache.kafka.common.errors
- FeatureUpdateFailedException(String) - Constructor for exception class org.apache.kafka.common.errors.FeatureUpdateFailedException
- FeatureUpdateFailedException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.FeatureUpdateFailedException
- FencedInstanceIdException - Exception Class in org.apache.kafka.common.errors
- FencedInstanceIdException(String) - Constructor for exception class org.apache.kafka.common.errors.FencedInstanceIdException
- FencedInstanceIdException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.FencedInstanceIdException
- FencedLeaderEpochException - Exception Class 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 class org.apache.kafka.common.errors.FencedLeaderEpochException
- FencedLeaderEpochException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.FencedLeaderEpochException
- FencedMemberEpochException - Exception Class in org.apache.kafka.common.errors
- FencedMemberEpochException(String) - Constructor for exception class org.apache.kafka.common.errors.FencedMemberEpochException
- fencedProducers() - Method in class org.apache.kafka.clients.admin.FenceProducersResult
- 
Return a map from transactional ID to futures which can be used to check the status of individual fencings.
- FencedStateEpochException - Exception Class in org.apache.kafka.common.errors
- 
Thrown when the share coordinator rejected the request because the share-group state epoch did not match.
- FencedStateEpochException(String) - Constructor for exception class org.apache.kafka.common.errors.FencedStateEpochException
- fenceProducer() - Method in class org.apache.kafka.clients.producer.MockProducer
- fenceProducers(Collection<String>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Fence out all active producers that use any of the provided transactional IDs, with the default options.
- fenceProducers(Collection<String>, FenceProducersOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Fence out all active producers that use any of the provided transactional IDs.
- fenceProducers(Collection<String>, FenceProducersOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- fenceProducers(Collection<String>, FenceProducersOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- FenceProducersOptions - Class in org.apache.kafka.clients.admin
- FenceProducersOptions() - Constructor for class org.apache.kafka.clients.admin.FenceProducersOptions
- FenceProducersResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.fenceProducers(Collection)call.
- fetch(K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
- 
Retrieve all aggregated sessions for the provided key.
- fetch(K, long) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
- 
Get the value of key from a window.
- fetch(K, long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
- 
Get all the key-value pairs with the given key and the time range from all the existing windows.
- fetch(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
- 
Get all the key-value pairs with the given key and the time range from all the existing windows.
- fetch(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
- fetch(K, K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
- 
Retrieve all aggregated sessions for the given range of keys.
- fetch(K, K, long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
- 
Get all the key-value pairs in the given key range and time range from all the existing windows.
- fetch(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
- 
Get all the key-value pairs in the given key range and time range from all the existing windows.
- fetch(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
- FETCH - Enum constant in enum class 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
- fetchAll(long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
- 
Gets all the key-value pairs that belong to the windows within in the given time range.
- fetchAll(Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
- 
Gets all the key-value pairs that belong to the windows within in the given time range.
- fetchAll(Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
- fetchIndex(RemoteLogSegmentMetadata, RemoteStorageManager.IndexType) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteStorageManager
- 
Returns the index for the respective log segment ofRemoteLogSegmentMetadata.
- fetchLogSegment(RemoteLogSegmentMetadata, int) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteStorageManager
- 
Returns the remote log segment data file/object as InputStream for the givenRemoteLogSegmentMetadatastarting from the given startPosition.
- fetchLogSegment(RemoteLogSegmentMetadata, int, int) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteStorageManager
- 
Returns the remote log segment data file/object as InputStream for the givenRemoteLogSegmentMetadatastarting from the given startPosition.
- fetchSession(K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
- 
Get the value of key from a single session.
- fetchSession(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
- 
Get the value of key from a single session.
- fetchSession(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
- FetchSessionIdNotFoundException - Exception Class in org.apache.kafka.common.errors
- FetchSessionIdNotFoundException() - Constructor for exception class org.apache.kafka.common.errors.FetchSessionIdNotFoundException
- FetchSessionIdNotFoundException(String) - Constructor for exception class org.apache.kafka.common.errors.FetchSessionIdNotFoundException
- FetchSessionTopicIdException - Exception Class in org.apache.kafka.common.errors
- FetchSessionTopicIdException(String) - Constructor for exception class org.apache.kafka.common.errors.FetchSessionTopicIdException
- field(String) - Method in class org.apache.kafka.connect.data.ConnectSchema
- field(String) - Method in interface org.apache.kafka.connect.data.Schema
- 
Get aFieldfor this Schema by name.
- field(String) - Method in class org.apache.kafka.connect.data.SchemaBuilder
- field(String, Schema) - Method in class org.apache.kafka.connect.data.SchemaBuilder
- 
Add a field to thisSchema.Type.STRUCTschema.
- Field - Class in org.apache.kafka.connect.data
- Field(String, int, Schema) - Constructor for class org.apache.kafka.connect.data.Field
- fields() - Method in class org.apache.kafka.connect.data.ConnectSchema
- fields() - Method in interface org.apache.kafka.connect.data.Schema
- 
Get the list of Fields for this Schema.
- fields() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- 
Get the list of fields for this Schema.
- 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 ofConfigProviderthat represents a Properties file.
- FileConfigProvider() - Constructor for class org.apache.kafka.common.config.provider.FileConfigProvider
- fillInStackTrace() - Method in exception class org.apache.kafka.common.errors.ApiException
- fillInStackTrace() - Method in exception class org.apache.kafka.common.metrics.QuotaViolationException
- filter(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Create a newKStreamthat consists of all records of this stream which satisfy the given predicate.
- filter(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTablethat consists of all records of thisKTablewhich satisfy the given predicate, with default serializers, deserializers, and state store.
- filter(Predicate<? super K, ? super V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTablethat consists of all records of thisKTablewhich satisfy the given predicate, with thekey serde,value serde, and the underlyingmaterialized state storageconfigured in theMaterializedinstance.
- filter(Predicate<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Create a newKStreamthat consists of all records of this stream which satisfy the given predicate.
- filter(Predicate<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTablethat consists of all records of thisKTablewhich satisfy the given predicate, with default serializers, deserializers, and state store.
- filter(Predicate<? super K, ? super V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTablethat consists of all records of thisKTablewhich satisfy the given predicate, with thekey serde,value serde, and the underlyingmaterialized state storageconfigured in theMaterializedinstance.
- filteredDuration() - Method in class org.apache.kafka.clients.admin.ListTransactionsOptions
- 
Returns the duration ms value being filtered.
- filteredProducerIds() - Method in class org.apache.kafka.clients.admin.ListTransactionsOptions
- 
Returns the set of producerIds that are being filtered or empty if none have been specified.
- filteredStates() - Method in class org.apache.kafka.clients.admin.ListTransactionsOptions
- 
Returns the set of states to be filtered or empty if no states have been specified.
- filterNot(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Create a newKStreamthat consists all records of this stream which do not satisfy the given predicate.
- filterNot(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTablethat consists all records of thisKTablewhich do not satisfy the given predicate, with default serializers, deserializers, and state store.
- filterNot(Predicate<? super K, ? super V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTablethat consists all records of thisKTablewhich do not satisfy the given predicate, with thekey serde,value serde, and the underlyingmaterialized state storageconfigured in theMaterializedinstance.
- filterNot(Predicate<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Create a newKStreamthat consists all records of this stream which do not satisfy the given predicate.
- filterNot(Predicate<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTablethat consists all records of thisKTablewhich do not satisfy the given predicate, with default serializers, deserializers, and state store.
- filterNot(Predicate<? super K, ? super V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTablethat consists all records of thisKTablewhich do not satisfy the given predicate, with thekey serde,value serde, and the underlyingmaterialized state storageconfigured in theMaterializedinstance.
- filterOnDuration(long) - Method in class org.apache.kafka.clients.admin.ListTransactionsOptions
- 
Filter only the transactions that are running longer than the specified duration.
- filterProducerIds(Collection<Long>) - Method in class org.apache.kafka.clients.admin.ListTransactionsOptions
- 
Filter only the transactions from producers in a specific set of producerIds.
- filterStates(Collection<TransactionState>) - Method in class org.apache.kafka.clients.admin.ListTransactionsOptions
- 
Filter only the transactions that are in a specific set of states.
- finalizedFeatures() - Method in class org.apache.kafka.clients.admin.FeatureMetadata
- 
Returns a map of finalized feature versions.
- finalizedFeaturesEpoch() - Method in class org.apache.kafka.clients.admin.FeatureMetadata
- 
The epoch for the finalized features.
- FinalizedVersionRange - Class in org.apache.kafka.clients.admin
- 
Represents a range of version levels supported by every broker in a cluster for some feature.
- FinalizedVersionRange(short, short) - Constructor for class org.apache.kafka.clients.admin.FinalizedVersionRange
- 
Raises an exception unless the following condition is met:minVersionLevel >= 1andmaxVersionLevel >= 1andmaxVersionLevel >= minVersionLevel.
- 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.ResourcePatternFilter
- findSessions(long, long) - Method in interface org.apache.kafka.streams.state.SessionStore
- 
Return all the session window entries that ends between the specified range (both ends are inclusive).
- findSessions(K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
- 
Fetch any sessions with the matching key and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from earliest to latest.
- findSessions(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
- 
Fetch any sessions with the matching key and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from earliest to latest.
- findSessions(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
- findSessions(K, K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
- 
Fetch any sessions in the given range of keys and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from earliest to latest.
- findSessions(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
- 
Fetch any sessions in the given range of keys and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from earliest to latest.
- findSessions(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
- FixedKeyProcessor<KIn,VIn, - Interface in org.apache.kafka.streams.processor.apiVOut> 
- 
A processor of key-value pair records where keys are immutable.
- FixedKeyProcessorContext<KForward,VForward> - Interface in org.apache.kafka.streams.processor.api
- 
Processor context interface forFixedKeyRecord.
- FixedKeyProcessorSupplier<KIn,VIn, - Interface in org.apache.kafka.streams.processor.apiVOut> 
- 
A processor supplier that can create one or moreFixedKeyProcessorinstances.
- FixedKeyRecord<K,V> - Class in org.apache.kafka.streams.processor.api
- 
A data class representing an incoming record with fixed key for processing in aFixedKeyProcessoror a record to forward to downstream processors viaFixedKeyProcessorContext.
- flatMap(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Transform each record of the input stream into zero or more records in the output stream (both key and value type can be altered arbitrarily).
- flatMap(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Transform each record of the input stream into zero or more records in the output stream (both key and value type can be altered arbitrarily).
- flatMapValues(ValueMapper<? super V, ? extends Iterable<? extends VR>>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Create a newKStreamby transforming the value of each record in this stream into zero or more values with the same key in the new stream.
- flatMapValues(ValueMapper<? super V, ? extends Iterable<? extends VR>>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Create a newKStreamby transforming the value of each record in this stream into zero or more values with the same key in the new stream.
- flatMapValues(ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Create a newKStreamby transforming the value of each record in this stream into zero or more values with the same key in the new stream.
- flatMapValues(ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Create a newKStreamby transforming the value of each record in this stream into zero or more values with the same key in the new stream.
- Float() - Static method in class org.apache.kafka.common.serialization.Serdes
- 
A serde for nullableFloattype.
- float32() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- FLOAT32 - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
- 
32-bit IEEE 754 floating point number
- FLOAT32_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- float64() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- FLOAT64 - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
- 
64-bit IEEE 754 floating point number
- FLOAT64_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- 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 iflinger.msis 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() - Method in interface org.apache.kafka.streams.processor.StateStore
- 
Flush any cached data
- flush(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.apache.kafka.connect.sink.SinkTask
- 
Flush all records that have beenSinkTask.put(Collection)for the specified topic-partitions.
- flush(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.apache.kafka.connect.tools.VerifiableSinkTask
- 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
- flushException - Variable in class org.apache.kafka.clients.producer.MockProducer
- followupRebalanceDeadline() - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment
- forBooleanValues(MetricName, MetricName) - Static method in class org.apache.kafka.common.metrics.stats.Frequencies
- 
Create a Frequencies instance with metrics for the frequency of a boolean sensor that records 0.0 for false and 1.0 for true.
- forChangelog(boolean) - Method in class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
- forConfig(String) - Static method in enum class org.apache.kafka.common.config.SslClientAuth
- foreach(ForeachAction<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Perform an action on each record ofKStream.
- foreach(ForeachAction<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Perform an action on each record ofKStream.
- ForeachAction<K,V> - Interface in org.apache.kafka.streams.kstream
- 
TheForeachActioninterface for performing an action on akey-value pair.
- ForeachProcessor<K,V> - Class in org.apache.kafka.streams.kstream
- 
Deprecated.Since 4.0 and should not be used any longer.
- ForeachProcessor(ForeachAction<K, V>) - Constructor for class org.apache.kafka.streams.kstream.ForeachProcessor
- 
Deprecated.
- forFailure(FailureReason, String) - Static method in interface org.apache.kafka.streams.query.QueryResult
- 
Static factory method to create a result object for a failed query.
- forGroupId(String) - Static method in exception class org.apache.kafka.common.errors.GroupAuthorizationException
- forId(byte) - Static method in enum class org.apache.kafka.clients.admin.AlterConfigOp.OpType
- forId(byte) - Static method in enum class org.apache.kafka.clients.consumer.AcknowledgeType
- forId(byte) - Static method in enum class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
- forId(byte) - Static method in enum class org.apache.kafka.common.config.ConfigResource.Type
- forId(byte) - Static method in enum class org.apache.kafka.common.IsolationLevel
- forId(byte) - Static method in enum class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
- forId(byte) - Static method in enum class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
- forId(int) - Static method in enum class org.apache.kafka.common.metrics.Sensor.RecordingLevel
- forId(short) - Static method in enum class org.apache.kafka.common.security.auth.SecurityProtocol
- formatRemoteTopic(String, String) - Method in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
- formatRemoteTopic(String, String) - Method in class org.apache.kafka.connect.mirror.IdentityReplicationPolicy
- 
UnlikeDefaultReplicationPolicy, IdentityReplicationPolicy does not include the source cluster alias in the remote topic name.
- formatRemoteTopic(String, String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
- 
Returns the remote topic name for the given topic and source cluster alias.
- forName(String) - Static method in enum class org.apache.kafka.common.metrics.Sensor.RecordingLevel
- 
Case insensitive lookup by protocol name
- forName(String) - Static method in enum class org.apache.kafka.common.security.auth.SecurityProtocol
- 
Case insensitive lookup by protocol name
- forResult(R) - Static method in interface org.apache.kafka.streams.query.QueryResult
- 
Static factory method to create a result object for a successful query.
- forStatefulTasks() - Method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils.RackAwareOptimizationParams
- 
Return a new config object with the tasksToOptimize set to all stateful tasks in the given ApplicationState
- forStatelessTasks() - Method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils.RackAwareOptimizationParams
- 
Return a new config object with the tasksToOptimize set to all stateless tasks in the given ApplicationState
- forTasks(SortedSet<TaskId>) - Method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils.RackAwareOptimizationParams
- 
Return a new config object with the provided tasksToOptimize
- forTimestamp(long) - Static method in class org.apache.kafka.clients.admin.OffsetSpec
- 
Used to retrieve the earliest offset whose timestamp is greater than or equal to the given timestamp in the corresponding partition
- forType(EmitStrategy.StrategyType) - Static method in enum class org.apache.kafka.streams.kstream.EmitStrategy.StrategyType
- forUnknownQueryType(Query<R>, StateStore) - Static method in interface org.apache.kafka.streams.query.QueryResult
- 
Static factory method to create a failed query result object to indicate that the store does not know how to handle the query.
- forward(K, V) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- forward(K, V) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Forward a key/value pair to all downstream processors.
- forward(K, V, To) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- forward(K, V, To) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Forward a key/value pair to the specified downstream processors.
- forward(FixedKeyRecord<K, V>) - Method in interface org.apache.kafka.streams.processor.api.FixedKeyProcessorContext
- 
Forward a record to all child processors.
- forward(FixedKeyRecord<K, V>, String) - Method in interface org.apache.kafka.streams.processor.api.FixedKeyProcessorContext
- 
Forward a record to the specified child processor.
- forward(Record<K, V>) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- forward(Record<K, V>) - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
- 
Forward a record to all child processors.
- forward(Record<K, V>, String) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- forward(Record<K, V>, String) - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
- 
Forward a record to the specified child processor.
- forwarded() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- 
Get all the forwarded data this context has observed.
- forwarded() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.Get all the forwarded data this context has observed.
- forwarded(String) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- 
Get all the forwarded data this context has observed for a specific child by name.
- forwarded(String) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.Get all the forwarded data this context has observed for a specific child by name.
- FORWARDING_ADMIN_CLASS - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- FORWARDING_ADMIN_CLASS_DEFAULT - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- FORWARDING_ADMIN_CLASS_DOC - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- ForwardingAdmin - Class in org.apache.kafka.clients.admin
- 
ForwardingAdminis the default value offorwarding.admin.classin MirrorMaker.
- ForwardingAdmin(Map<String, Object>) - Constructor for class org.apache.kafka.clients.admin.ForwardingAdmin
- Frequencies - Class in org.apache.kafka.common.metrics.stats
- 
ACompoundStatthat represents a normalized distribution with aFrequencymetric for each bucketed value.
- Frequencies(int, double, double, Frequency...) - Constructor for class org.apache.kafka.common.metrics.stats.Frequencies
- 
Create a Frequencies that captures the values in the specified range into the given number of buckets, where the buckets are centered around the minimum, maximum, and intermediate values.
- frequency(MetricConfig, long, double) - Method in class org.apache.kafka.common.metrics.stats.Frequencies
- 
Return the computed frequency describing the number of occurrences of the values in the bucket for the given center point, relative to the total number of occurrences in the samples.
- Frequency - Class in org.apache.kafka.common.metrics.stats
- 
Definition of a frequency metric used in aFrequenciescompound statistic.
- Frequency(MetricName, double) - Constructor for class org.apache.kafka.common.metrics.stats.Frequency
- 
Create an instance with the given name and center point value.
- fromBin(int) - Method in interface org.apache.kafka.common.metrics.stats.Histogram.BinScheme
- 
Determine the value at the upper range of the specified bin.
- fromBin(int) - Method in class org.apache.kafka.common.metrics.stats.Histogram.ConstantBinScheme
- fromBin(int) - Method in class org.apache.kafka.common.metrics.stats.Histogram.LinearBinScheme
- fromBytes(byte[]) - Method in interface org.apache.kafka.tools.api.Decoder
- fromBytes(byte[]) - Method in class org.apache.kafka.tools.api.DefaultDecoder
- fromBytes(byte[]) - Method in class org.apache.kafka.tools.api.IntegerDecoder
- fromBytes(byte[]) - Method in class org.apache.kafka.tools.api.LongDecoder
- fromBytes(byte[]) - Method in class org.apache.kafka.tools.api.StringDecoder
- fromCode(byte) - Static method in enum class 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 class 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 class org.apache.kafka.common.resource.PatternType
- 
Return the PatternType with the provided code orPatternType.UNKNOWNif one cannot be found.
- fromCode(byte) - Static method in enum class org.apache.kafka.common.resource.ResourceType
- 
Return the ResourceType with the provided code or `ResourceType.UNKNOWN` if one cannot be found.
- fromCode(int) - Static method in enum class org.apache.kafka.clients.admin.FeatureUpdate.UpgradeType
- fromConnectData(String, Headers, Schema, Object) - Method in interface org.apache.kafka.connect.storage.Converter
- 
Convert a Kafka Connect data object to a native object for serialization, potentially using the supplied topic and headers in the record as necessary.
- fromConnectData(String, Schema, Object) - Method in interface org.apache.kafka.connect.storage.Converter
- 
Convert a Kafka Connect data object to a native object for serialization.
- fromConnectData(String, Schema, Object) - Method in class org.apache.kafka.connect.storage.StringConverter
- fromConnectHeader(String, String, Schema, Object) - Method in interface org.apache.kafka.connect.storage.HeaderConverter
- fromConnectHeader(String, String, Schema, Object) - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
- fromConnectHeader(String, String, Schema, Object) - Method in class org.apache.kafka.connect.storage.StringConverter
- fromId(byte) - Static method in enum class org.apache.kafka.clients.admin.EndpointType
- fromLogical(Schema, BigDecimal) - Static method in class org.apache.kafka.connect.data.Decimal
- 
Convert a value from its logical format (BigDecimal) to its encoded format (byte[]).
- fromLogical(Schema, Date) - Static method in class org.apache.kafka.connect.data.Date
- 
Convert a value from its logical format (Date) to its encoded format (int).
- fromLogical(Schema, Date) - Static method in class org.apache.kafka.connect.data.Time
- 
Convert a value from its logical format (Date) to its encoded format (int).
- fromLogical(Schema, Date) - Static method in class org.apache.kafka.connect.data.Timestamp
- 
Convert a value from its logical format (Date) to its encoded format (long).
- fromMap(Map<String, ? extends Map<Integer, Long>>) - Static method in class org.apache.kafka.streams.query.Position
- 
Create a new Position and populate it with a mapping of topic -> partition -> offset.
- fromMechanismName(String) - Static method in enum class org.apache.kafka.clients.admin.ScramMechanism
- fromNameAndType(String, QueryableStoreType<T>) - Static method in class org.apache.kafka.streams.StoreQueryParameters
- fromProperty(String) - Static method in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
- 
Parse aSourceTask.TransactionBoundaryfrom the given string.
- fromRecord(String, KafkaPrincipal, KafkaPrincipal, Collection<KafkaPrincipal>, long, long, long) - Static method in class org.apache.kafka.common.security.token.delegation.TokenInformation
- fromString(String) - Static method in enum class org.apache.kafka.common.acl.AclOperation
- 
Parse the given string as an ACL operation.
- fromString(String) - Static method in enum class org.apache.kafka.common.acl.AclPermissionType
- 
Parse the given string as an ACL permission.
- fromString(String) - Static method in enum class org.apache.kafka.common.resource.PatternType
- 
Return the PatternType with the provided name orPatternType.UNKNOWNif one cannot be found.
- fromString(String) - Static method in enum class 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.Uuid
- 
Creates a UUID based on a base64 string encoding used in the toString() method.
- fromTime() - Method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
- 
The starting time point of the query, if specified
- fromTime(Instant) - Method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
- 
Specifies the starting time point for the key query.
- fromType(byte) - Static method in enum class org.apache.kafka.clients.admin.ScramMechanism
G
- Gauge<T> - Interface in org.apache.kafka.common.metrics
- 
A gauge metric is an instantaneous reading of a particular value.
- generateNew(TopicIdPartition) - Static method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentId
- 
Creates a newRemoteLogSegmentIdfor the providedTopicIdPartitionwith a random Uuid.
- generationId() - Method in class org.apache.kafka.clients.consumer.ConsumerGroupMetadata
- generationId() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
- get() - Method in class org.apache.kafka.common.KafkaFuture
- 
Waits if necessary for this future to complete, and then returns its result.
- get() - Method in interface org.apache.kafka.streams.kstream.TransformerSupplier
- 
Deprecated.Return a newly constructedTransformerinstance.
- get() - Method in interface org.apache.kafka.streams.kstream.ValueTransformerSupplier
- 
Deprecated.Return a newly constructedValueTransformerinstance.
- get() - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKeySupplier
- 
Return a newly constructedValueTransformerWithKeyinstance.
- get() - Method in interface org.apache.kafka.streams.processor.api.FixedKeyProcessorSupplier
- 
Return a newly constructedFixedKeyProcessorinstance.
- get() - Method in interface org.apache.kafka.streams.processor.api.ProcessorSupplier
- 
Return a newly constructedProcessorinstance.
- get() - Method in interface org.apache.kafka.streams.state.StoreSupplier
- 
Return a newStateStoreinstance.
- 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 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.DirectoryConfigProvider
- 
Retrieves the data contained in regular files in the directory given bypath.
- get(String) - Method in class org.apache.kafka.common.config.provider.EnvVarConfigProvider
- get(String) - Method in class org.apache.kafka.common.config.provider.FileConfigProvider
- 
Retrieves the data at the given Properties file.
- get(String) - Method in class org.apache.kafka.connect.data.Struct
- 
Get the value of a field, returning the default value if no value has been set yet and a default value is specified in the field's schema.
- 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.DirectoryConfigProvider
- 
Retrieves the data contained in the regular files named bykeysin the directory given bypath.
- get(String, Set<String>) - Method in class org.apache.kafka.common.config.provider.EnvVarConfigProvider
- 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.
- get(K) - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
- 
Get the value corresponding to this key.
- get(K) - Method in interface org.apache.kafka.streams.state.VersionedKeyValueStore
- 
Get the current (i.e., latest by timestamp) record associated with this key.
- get(K, long) - Method in interface org.apache.kafka.streams.state.VersionedKeyValueStore
- 
Get the record associated with this key as of the specified timestamp (i.e., the existing record with the largest timestamp not exceeding the provided timestamp bound).
- get(Bytes, long) - Method in interface org.apache.kafka.streams.state.VersionedBytesStore
- 
The analog ofVersionedKeyValueStore.get(Object, long).
- get(Field) - Method in class org.apache.kafka.connect.data.Struct
- 
Get the value of a field, returning the default value if no value has been set yet and a default value is specified in the field's schema.
- getAdmin(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
- 
Create anAdminwhich is used for internal topic management.
- getAdminConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
- 
Get the configs for theadmin client.
- getAllStateStores() - Method in class org.apache.kafka.streams.TopologyTestDriver
- 
Get allStateStoresfrom the topology.
- getArray(String) - Method in class org.apache.kafka.connect.data.Struct
- 
Equivalent to callingStruct.get(String)and casting the result to a List.
- getAssignorInstances(List<String>, Map<String, Object>) - Static method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
- 
Get a list of configured instances ofConsumerPartitionAssignorbased on the class names/types specified byConsumerConfig.PARTITION_ASSIGNMENT_STRATEGY_CONFIG
- getBoolean(String) - Method in class org.apache.kafka.common.config.AbstractConfig
- getBoolean(String) - Method in class org.apache.kafka.connect.data.Struct
- 
Equivalent to callingStruct.get(String)and casting the result to a Boolean.
- getBoolean(Map<String, Object>, String, boolean) - Static method in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- getBoolean(Map<String, Object>, String, boolean) - Static method in class org.apache.kafka.streams.TopologyConfig.InternalConfig
- getBytes(String) - Method in class org.apache.kafka.connect.data.Struct
- 
Equivalent to callingStruct.get(String)and casting the result to a byte[].
- getClass(String) - Method in class org.apache.kafka.common.config.AbstractConfig
- getClientTags() - Method in class org.apache.kafka.streams.StreamsConfig
- 
Get the configured client tags set withStreamsConfig.CLIENT_TAG_PREFIXprefix.
- 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.
- getConfiguredInstance(String, Class<T>, Map<String, Object>) - 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.
- getConsumer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
- 
Create aConsumerwhich is used to read records of source topics.
- getCurrentReplicaLogDir() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
- 
The current log directory of the replica of this partition on the given broker.
- getCurrentReplicaOffsetLag() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
- 
Defined as max(HW of partition - LEO of the replica, 0).
- getDouble(String) - Method in class org.apache.kafka.common.config.AbstractConfig
- getExecutionInfo() - Method in interface org.apache.kafka.streams.query.QueryResult
- 
If detailed execution information was requested inStateQueryRequest.enableExecutionInfo(), this method returned the execution details for this partition's result.
- getFailureMessage() - Method in interface org.apache.kafka.streams.query.QueryResult
- 
If this partition failed to execute the query, returns the failure message.
- getFailureReason() - Method in interface org.apache.kafka.streams.query.QueryResult
- 
If this partition failed to execute the query, returns the reason.
- getFloat32(String) - Method in class org.apache.kafka.connect.data.Struct
- 
Equivalent to callingStruct.get(String)and casting the result to a Float.
- getFloat64(String) - Method in class org.apache.kafka.connect.data.Struct
- 
Equivalent to callingStruct.get(String)and casting the result to a Double.
- getFutureReplicaLogDir() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
- 
The future log directory of the replica of this partition on the given broker.
- getFutureReplicaOffsetLag() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
- 
The LEO of the replica - LEO of the future log of this replica in the destination log directory.
- getGlobalConsumer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
- 
Create aConsumerwhich is used to consume records forGlobalKTable.
- getGlobalConsumerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
- 
Get the configs for theglobal consumer.
- getGlobalResult() - Method in class org.apache.kafka.streams.query.StateQueryResult
- 
The query's result for global store queries.
- getHeaders() - Method in class org.apache.kafka.streams.test.TestRecord
- getInnerSerializer() - Method in class org.apache.kafka.common.serialization.ListSerializer
- getInt(String) - Method in class org.apache.kafka.common.config.AbstractConfig
- getInt16(String) - Method in class org.apache.kafka.connect.data.Struct
- 
Equivalent to callingStruct.get(String)and casting the result to a Short.
- getInt32(String) - Method in class org.apache.kafka.connect.data.Struct
- 
Equivalent to callingStruct.get(String)and casting the result to an Integer.
- getInt64(String) - Method in class org.apache.kafka.connect.data.Struct
- 
Equivalent to callingStruct.get(String)and casting the result to a Long.
- getInt8(String) - Method in class org.apache.kafka.connect.data.Struct
- 
Equivalent to callingStruct.get(String)and casting the result to a Byte.
- getInterval() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedPunctuator
- getIntervalMs() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedPunctuator
- 
Deprecated.
- getKafkaClientSupplier() - Method in class org.apache.kafka.streams.StreamsConfig
- 
Return configured KafkaClientSupplier
- getKey() - Method in class org.apache.kafka.streams.query.KeyQuery
- 
Return the key that was specified for this query.
- getKey() - Method in class org.apache.kafka.streams.query.WindowKeyQuery
- getKey() - Method in class org.apache.kafka.streams.query.WindowRangeQuery
- getKey() - Method in class org.apache.kafka.streams.test.TestRecord
- getKeyValueStore(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
- 
Get theKeyValueStoreorTimestampedKeyValueStorewith the given name.
- getLeastSignificantBits() - Method in class org.apache.kafka.common.Uuid
- 
Returns the least significant bits of the UUID's 128 value.
- getList(String) - Method in class org.apache.kafka.common.config.AbstractConfig
- getLong(String) - Method in class org.apache.kafka.common.config.AbstractConfig
- getLong(Map<String, Object>, String, long) - Static method in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- getLowerBound() - Method in class org.apache.kafka.streams.query.RangeQuery
- 
The lower bound of the query, if specified.
- getMainConsumerConfigs(String, String, int) - Method in class org.apache.kafka.streams.StreamsConfig
- 
Get the configs to themain consumer.
- getMap(String) - Method in class org.apache.kafka.connect.data.Struct
- 
Equivalent to callingStruct.get(String)and casting the result to a Map.
- getMostSignificantBits() - Method in class org.apache.kafka.common.Uuid
- 
Returns the most significant bits of the UUID's 128 value.
- getName() - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
- getName() - Method in enum class org.apache.kafka.connect.data.Schema.Type
- getName() - Method in enum class org.apache.kafka.connect.storage.ConverterType
- 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.
- getOnlyPartitionResult() - Method in class org.apache.kafka.streams.query.StateQueryResult
- 
For queries that are expected to match records in only one partition, returns the result.
- getPartitionPositions(String) - Method in class org.apache.kafka.streams.query.Position
- 
Return the partition -> offset mapping for a specific topic.
- getPartitionResults() - Method in class org.apache.kafka.streams.query.StateQueryResult
- 
The query's result for each partition that executed the query.
- getPartitions() - Method in class org.apache.kafka.streams.query.StateQueryRequest
- 
If the request is for specific partitions, return the set of partitions to query.
- getPassword(String) - Method in class org.apache.kafka.common.config.AbstractConfig
- getPosition() - Method in interface org.apache.kafka.streams.processor.StateStore
- 
Returns the position the state store is at with respect to the input topic/partitions
- getPosition() - Method in interface org.apache.kafka.streams.query.QueryResult
- 
This state partition's exact position in its history when this query was executed.
- getPosition() - Method in class org.apache.kafka.streams.query.StateQueryResult
- 
The position of the state store at the moment it executed the query.
- getPositionBound() - Method in class org.apache.kafka.streams.query.StateQueryRequest
- 
The bound that this request places on its query, in terms of the partitions' positions against its inputs.
- getPrincipalType() - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
- getProducer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
- 
Create aProducerwhich is used to write records to sink topics.
- getProducerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
- 
Get the configs for theproducer.
- getProvider() - Method in interface org.apache.kafka.common.security.auth.SecurityProviderCreator
- 
Generate the security provider configured
- getPunctuator() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedPunctuator
- getPunctuator() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedPunctuator
- 
Deprecated.
- getQuery() - Method in class org.apache.kafka.streams.query.StateQueryRequest
- 
The query this request is meant to run.
- getQueueSize() - Method in class org.apache.kafka.streams.TestOutputTopic
- 
Get size of unread record in the topic queue.
- getRecordTime() - Method in class org.apache.kafka.streams.test.TestRecord
- getRestoreConsumer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
- 
Create aConsumerwhich is used to read records to restoreStateStores.
- getRestoreConsumerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
- 
Get the configs for therestore-consumer.
- getResult() - Method in interface org.apache.kafka.streams.query.QueryResult
- 
Returns the result of executing the query on one partition.
- getSensor(String) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Get the sensor with the given name if it exists
- getSessionStore(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
- 
Get theSessionStorewith the given name.
- getShort(String) - Method in class org.apache.kafka.common.config.AbstractConfig
- getStateStore(String) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- getStateStore(String) - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
- 
Get the state store given the store name.
- getStateStore(String) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- getStateStore(String) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Get the state store given the store name.
- getStateStore(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
- 
Get theStateStorewith the given name.
- getStateStoreContext() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- 
Used to get aStateStoreContextfor use withStateStore.init(StateStoreContext, StateStore)if you need to initialize a store for your tests.
- getStoreName() - Method in class org.apache.kafka.streams.query.StateQueryRequest
- 
The name of the store this request is for.
- getString(String) - Method in class org.apache.kafka.common.config.AbstractConfig
- getString(String) - Method in class org.apache.kafka.connect.data.Struct
- 
Equivalent to callingStruct.get(String)and casting the result to a String.
- getString(Map<String, Object>, String, String) - Static method in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- getStruct(String) - Method in class org.apache.kafka.connect.data.Struct
- 
Equivalent to callingStruct.get(String)and casting the result to a Struct.
- getTaskConfig() - Method in class org.apache.kafka.streams.TopologyConfig
- getTimeFrom() - Method in class org.apache.kafka.streams.query.WindowKeyQuery
- getTimeFrom() - Method in class org.apache.kafka.streams.query.WindowRangeQuery
- getTimestampedKeyValueStore(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
- 
Get theTimestampedKeyValueStorewith the given name.
- getTimestampedWindowStore(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
- 
Get theTimestampedWindowStorewith the given name.
- getTimeTo() - Method in class org.apache.kafka.streams.query.WindowKeyQuery
- getTimeTo() - Method in class org.apache.kafka.streams.query.WindowRangeQuery
- getTopics() - Method in class org.apache.kafka.streams.query.Position
- 
Return the topics that are represented in this Position.
- getType() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedPunctuator
- getType() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedPunctuator
- 
Deprecated.
- getUpperBound() - Method in class org.apache.kafka.streams.query.RangeQuery
- 
The upper bound of the query, if specified
- getValue() - Method in class org.apache.kafka.streams.test.TestRecord
- getValueOrNull(ValueAndTimestamp<V>) - Static method in class org.apache.kafka.streams.state.ValueAndTimestamp
- 
Return the wrappedvalueof the givenvalueAndTimestampparameter if the parameter is notnull.
- getVersionedKeyValueStore(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
- 
Get theVersionedKeyValueStorewith the given name.
- getWindowSize() - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
- getWindowStore(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
- 
Get theWindowStoreorTimestampedWindowStorewith the given name.
- getWithoutDefault(String) - Method in class org.apache.kafka.connect.data.Struct
- 
Get the underlying raw value for the field without accounting for default values.
- GLOBAL_CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Prefix used to overrideconsumerconfigs for the global consumer client from the general consumer client configs.
- globalConsumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
- 
Prefix a property withStreamsConfig.GLOBAL_CONSUMER_PREFIX.
- GlobalKTable<K,V> - Interface in org.apache.kafka.streams.kstream
- 
GlobalKTableis an abstraction of a changelog stream from a primary-keyed table.
- globalStores() - Method in interface org.apache.kafka.streams.TopologyDescription
- 
All global stores of the represented topology.
- globalTable(String) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Create aGlobalKTablefor the specified topic.
- globalTable(String, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Create aGlobalKTablefor the specified topic.
- globalTable(String, Consumed<K, V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Create aGlobalKTablefor the specified topic.
- globalTable(String, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Create aGlobalKTablefor the specified topic.
- grace(Duration) - Method in class org.apache.kafka.streams.kstream.JoinWindows
- 
Deprecated.Since 3.0. UseJoinWindows.ofTimeDifferenceAndGrace(Duration, Duration)instead.
- gracePeriod() - Method in class org.apache.kafka.streams.kstream.Joined
- 
Deprecated.Since 4.0 and should not be used any longer.
- gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.JoinWindows
- gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.SessionWindows
- gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.SlidingWindows
- gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.TimeWindows
- gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
- gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.Windows
- 
Return the window grace period (the time to admit out-of-order events after the end of the window.) Delay is defined as (stream_time - record_timestamp).
- 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 - Enum constant in enum class org.apache.kafka.common.config.ConfigResource.Type
- GROUP - Enum constant in enum class org.apache.kafka.common.resource.ResourceType
- 
A consumer group.
- GROUP_ID_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- 
group.id
- GROUP_INSTANCE_ID_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- 
group.instance.id
- GROUP_PROTOCOL_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- 
group.protocol
- GROUP_PROTOCOL_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- GROUP_REMOTE_ASSIGNOR_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- 
group.remote.assignor
- GROUP_REMOTE_ASSIGNOR_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- groupAssignment() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.GroupAssignment
- GroupAssignment - Class in org.apache.kafka.coordinator.group.api.assignor
- 
The partition assignment for a consumer group.
- GroupAssignment(Map<String, ConsumerPartitionAssignor.Assignment>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.GroupAssignment
- GroupAssignment(Map<String, MemberAssignment>) - Constructor for class org.apache.kafka.coordinator.group.api.assignor.GroupAssignment
- GroupAuthorizationException - Exception Class in org.apache.kafka.common.errors
- GroupAuthorizationException(String) - Constructor for exception class org.apache.kafka.common.errors.GroupAuthorizationException
- GroupAuthorizationException(String, String) - Constructor for exception class org.apache.kafka.common.errors.GroupAuthorizationException
- groupBy(KeyValueMapper<? super K, ? super V, KR>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Group the records of thisKStreamon a new key that is selected using the providedKeyValueMapperand default serializers and deserializers.
- groupBy(KeyValueMapper<? super K, ? super V, KR>, Grouped<KR, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Group the records of thisKStreamon a new key that is selected using the providedKeyValueMapperandSerdes as specified byGrouped.
- groupBy(KeyValueMapper<? super K, ? super V, KeyValue<KR, VR>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Re-groups the records of thisKTableusing the providedKeyValueMapperand default serializers and deserializers.
- groupBy(KeyValueMapper<? super K, ? super V, KeyValue<KR, VR>>, Grouped<KR, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Re-groups the records of thisKTableusing the providedKeyValueMapperandSerdes as specified byGrouped.
- groupByKey() - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Group the records by their current key into aKGroupedStreamwhile preserving the original values and default serializers and deserializers.
- groupByKey(Grouped<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Group the records by their current key into aKGroupedStreamwhile preserving the original values and using the serializers as defined byGrouped.
- Grouped<K,V> - Class in org.apache.kafka.streams.kstream
- 
The class that is used to capture the key and valueSerdes and set the part of name used for repartition topics when performingKStream.groupBy(KeyValueMapper, Grouped),KStream.groupByKey(Grouped), orKTable.groupBy(KeyValueMapper, Grouped)operations.
- groupEpoch() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
- 
The epoch of the consumer group.
- groupId() - Method in class org.apache.kafka.clients.admin.ClassicGroupDescription
- 
The id of the classic group.
- 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 class org.apache.kafka.clients.admin.GroupListing
- 
The group Id.
- groupId() - Method in class org.apache.kafka.clients.admin.ShareGroupDescription
- 
The id of the share group.
- groupId() - Method in class org.apache.kafka.clients.consumer.ConsumerGroupMetadata
- groupId() - Method in exception class org.apache.kafka.common.errors.GroupAuthorizationException
- 
Return the group ID that failed authorization.
- GroupIdNotFoundException - Exception Class in org.apache.kafka.common.errors
- GroupIdNotFoundException(String) - Constructor for exception class org.apache.kafka.common.errors.GroupIdNotFoundException
- groupInstanceId() - Method in class org.apache.kafka.clients.admin.MemberDescription
- 
The instance id of the group member.
- groupInstanceId() - Method in class org.apache.kafka.clients.admin.MemberToRemove
- groupInstanceId() - Method in class org.apache.kafka.clients.consumer.ConsumerGroupMetadata
- groupInstanceId() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
- GroupListing - Class in org.apache.kafka.clients.admin
- 
A listing of a group in the cluster.
- GroupListing(String, Optional<GroupType>, String, Optional<GroupState>) - Constructor for class org.apache.kafka.clients.admin.GroupListing
- 
Create an instance with the specified parameters.
- GroupMaxSizeReachedException - Exception Class in org.apache.kafka.common.errors
- 
Indicates that a consumer group is already at its configured maximum capacity and cannot accommodate more members
- GroupMaxSizeReachedException(String) - Constructor for exception class org.apache.kafka.common.errors.GroupMaxSizeReachedException
- groupMetadata() - Method in interface org.apache.kafka.clients.consumer.Consumer
- groupMetadata() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
- 
Return the current group metadata associated with this consumer.
- groupMetadata() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- GroupNotEmptyException - Exception Class in org.apache.kafka.common.errors
- GroupNotEmptyException(String) - Constructor for exception class org.apache.kafka.common.errors.GroupNotEmptyException
- groupPartitions(List<T>, int) - Static method in class org.apache.kafka.connect.util.ConnectorUtils
- 
Given a list of elements and a target number of groups, generates list of groups of elements to match the target number of groups, spreading them evenly among the groups.
- GroupProtocol - Enum Class in org.apache.kafka.clients.consumer
- groups() - Method in class org.apache.kafka.common.config.ConfigDef
- 
Get the groups for the configuration
- GroupSpec - Interface in org.apache.kafka.coordinator.group.api.assignor
- 
The group metadata specifications required to compute the target assignment.
- groupState() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
- 
The group state, or UNKNOWN if the state is too new for us to parse.
- groupState() - Method in class org.apache.kafka.clients.admin.ConsumerGroupListing
- 
Group state
- groupState() - Method in class org.apache.kafka.clients.admin.GroupListing
- 
The group state.
- groupState() - Method in class org.apache.kafka.clients.admin.ShareGroupDescription
- 
The group state, or UNKNOWN if the state is too new for us to parse.
- GroupState - Enum Class in org.apache.kafka.common
- 
The group state.
- groupStates() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsOptions
- 
Returns the list of group states that are requested or empty if no states have been specified.
- groupStates() - Method in class org.apache.kafka.clients.admin.ListGroupsOptions
- 
Returns the list of group states that are requested or empty if no states have been specified.
- groupStatesForType(GroupType) - Static method in enum class org.apache.kafka.common.GroupState
- GroupSubscribedToTopicException - Exception Class in org.apache.kafka.common.errors
- GroupSubscribedToTopicException(String) - Constructor for exception class org.apache.kafka.common.errors.GroupSubscribedToTopicException
- groupSubscription() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.GroupSubscription
- GroupSubscription(Map<String, ConsumerPartitionAssignor.Subscription>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.GroupSubscription
- GroupType - Enum Class in org.apache.kafka.common
- GSSAPI_MECHANISM - Static variable in class org.apache.kafka.common.config.SaslConfigs
H
- handle(Throwable) - Method in interface org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler
- 
Inspect the exception received in a stream thread and respond with an action.
- handle(Callback[]) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- handle(Callback[]) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallbackHandler
- handle(ProducerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.DefaultProductionExceptionHandler
- 
Deprecated.Since 3.9. UseDefaultProductionExceptionHandler.handle(ErrorHandlerContext, ProducerRecord, Exception)instead.
- handle(ProducerRecord<byte[], byte[]>, Exception) - Method in interface org.apache.kafka.streams.errors.ProductionExceptionHandler
- 
Deprecated.Since 3.9. UseProductionExceptionHandler.handle(ErrorHandlerContext, ProducerRecord, Exception)instead.
- handle(ErrorHandlerContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in interface org.apache.kafka.streams.errors.DeserializationExceptionHandler
- 
Inspect a record and the exception received.
- handle(ErrorHandlerContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndContinueExceptionHandler
- handle(ErrorHandlerContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndFailExceptionHandler
- handle(ErrorHandlerContext, ProducerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.DefaultProductionExceptionHandler
- handle(ErrorHandlerContext, ProducerRecord<byte[], byte[]>, Exception) - Method in interface org.apache.kafka.streams.errors.ProductionExceptionHandler
- 
Inspect a record that we attempted to produce, and the exception that resulted from attempting to produce it and determine to continue or stop processing.
- handle(ErrorHandlerContext, Record<?, ?>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndContinueProcessingExceptionHandler
- handle(ErrorHandlerContext, Record<?, ?>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndFailProcessingExceptionHandler
- handle(ErrorHandlerContext, Record<?, ?>, Exception) - Method in interface org.apache.kafka.streams.errors.ProcessingExceptionHandler
- 
Inspect a record and the exception received
- handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in interface org.apache.kafka.streams.errors.DeserializationExceptionHandler
- 
Deprecated.Since 3.9. UseDeserializationExceptionHandler.handle(ErrorHandlerContext, ConsumerRecord, Exception)instead.
- handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndContinueExceptionHandler
- 
Deprecated.Since 3.9. UseLogAndContinueExceptionHandler.handle(ErrorHandlerContext, ConsumerRecord, Exception)instead.
- handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndFailExceptionHandler
- 
Deprecated.Since 3.9. UseLogAndFailExceptionHandler.handle(ErrorHandlerContext, ConsumerRecord, Exception)instead.
- handleSerializationException(ProducerRecord, Exception) - Method in interface org.apache.kafka.streams.errors.ProductionExceptionHandler
- 
Deprecated.
- handleSerializationException(ErrorHandlerContext, ProducerRecord, Exception, ProductionExceptionHandler.SerializationExceptionOrigin) - Method in interface org.apache.kafka.streams.errors.ProductionExceptionHandler
- 
Handles serialization exception and determine if the process should continue.
- hasCompletedShutdown() - Method in enum class org.apache.kafka.streams.KafkaStreams.State
- hasDefault() - Method in class org.apache.kafka.common.config.ConfigDef.ConfigKey
- hasExpired() - Method in class org.apache.kafka.common.metrics.Sensor
- 
Return true if the Sensor is eligible for removal due to inactivity.
- hashCode() - Method in class org.apache.kafka.clients.admin.AbortTransactionSpec
- hashCode() - Method in class org.apache.kafka.clients.admin.AlterConfigOp
- hashCode() - Method in class org.apache.kafka.clients.admin.ClassicGroupDescription
- hashCode() - Method in class org.apache.kafka.clients.admin.ClientMetricsResourceListing
- 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.ConsumerGroupListing
- hashCode() - Method in class org.apache.kafka.clients.admin.DescribeProducersOptions
- hashCode() - Method in class org.apache.kafka.clients.admin.FeatureMetadata
- hashCode() - Method in class org.apache.kafka.clients.admin.FeatureUpdate
- hashCode() - Method in class org.apache.kafka.clients.admin.FinalizedVersionRange
- hashCode() - Method in class org.apache.kafka.clients.admin.GroupListing
- hashCode() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsSpec
- hashCode() - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
- hashCode() - Method in class org.apache.kafka.clients.admin.ListTransactionsOptions
- 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.MemberToRemove
- hashCode() - Method in class org.apache.kafka.clients.admin.NewTopic
- hashCode() - Method in class org.apache.kafka.clients.admin.ProducerState
- hashCode() - Method in class org.apache.kafka.clients.admin.QuorumInfo
- hashCode() - Method in class org.apache.kafka.clients.admin.QuorumInfo.Node
- hashCode() - Method in class org.apache.kafka.clients.admin.QuorumInfo.ReplicaState
- hashCode() - Method in class org.apache.kafka.clients.admin.RaftVoterEndpoint
- hashCode() - Method in class org.apache.kafka.clients.admin.RecordsToDelete
- hashCode() - Method in class org.apache.kafka.clients.admin.ScramCredentialInfo
- hashCode() - Method in class org.apache.kafka.clients.admin.ShareGroupDescription
- hashCode() - Method in class org.apache.kafka.clients.admin.ShareMemberAssignment
- hashCode() - Method in class org.apache.kafka.clients.admin.ShareMemberDescription
- hashCode() - Method in class org.apache.kafka.clients.admin.SupportedVersionRange
- hashCode() - Method in class org.apache.kafka.clients.admin.TopicDescription
- hashCode() - Method in class org.apache.kafka.clients.admin.TransactionDescription
- hashCode() - Method in class org.apache.kafka.clients.admin.TransactionListing
- hashCode() - Method in class org.apache.kafka.clients.admin.UserScramCredentialsDescription
- hashCode() - Method in class org.apache.kafka.clients.consumer.ConsumerGroupMetadata
- 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.consumer.SubscriptionPattern
- 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.Cluster
- hashCode() - Method in class org.apache.kafka.common.ClusterResource
- 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.Endpoint
- 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.metrics.Quota
- hashCode() - Method in class org.apache.kafka.common.Node
- hashCode() - Method in class org.apache.kafka.common.PartitionInfo
- hashCode() - Method in class org.apache.kafka.common.quota.ClientQuotaAlteration.Op
- hashCode() - Method in class org.apache.kafka.common.quota.ClientQuotaEntity
- hashCode() - Method in class org.apache.kafka.common.quota.ClientQuotaFilter
- hashCode() - Method in class org.apache.kafka.common.quota.ClientQuotaFilterComponent
- hashCode() - Method in class org.apache.kafka.common.resource.Resource
- 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
- 
ImplementshashCodeusing the native implementation fromObject.hashCode().
- 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.TopicIdPartition
- 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
- hashCode() - Method in class org.apache.kafka.common.Uuid
- 
Returns a hash code for this UUID
- hashCode() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- hashCode() - Method in class org.apache.kafka.connect.data.ConnectSchema
- hashCode() - Method in class org.apache.kafka.connect.data.Field
- hashCode() - Method in class org.apache.kafka.connect.data.SchemaAndValue
- hashCode() - Method in class org.apache.kafka.connect.data.Struct
- hashCode() - Method in class org.apache.kafka.connect.header.ConnectHeaders
- hashCode() - Method in class org.apache.kafka.connect.health.AbstractState
- hashCode() - Method in class org.apache.kafka.connect.health.ConnectorHealth
- hashCode() - Method in class org.apache.kafka.connect.health.TaskState
- hashCode() - Method in class org.apache.kafka.connect.mirror.Checkpoint
- hashCode() - Method in class org.apache.kafka.connect.mirror.SourceAndTarget
- hashCode() - Method in class org.apache.kafka.connect.sink.SinkRecord
- hashCode() - Method in class org.apache.kafka.connect.source.SourceRecord
- hashCode() - Method in class org.apache.kafka.coordinator.group.api.assignor.GroupAssignment
- hashCode() - Method in class org.apache.kafka.server.authorizer.Action
- hashCode() - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
- hashCode() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentId
- hashCode() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata.CustomMetadata
- hashCode() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- hashCode() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
- hashCode() - Method in class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteMetadata
- hashCode() - Method in class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
- hashCode() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
- hashCode() - Method in class org.apache.kafka.streams.AutoOffsetReset
- hashCode() - Method in class org.apache.kafka.streams.KeyQueryMetadata
- hashCode() - Method in class org.apache.kafka.streams.KeyValue
- hashCode() - Method in class org.apache.kafka.streams.kstream.Consumed
- hashCode() - Method in class org.apache.kafka.streams.kstream.JoinWindows
- hashCode() - Method in class org.apache.kafka.streams.kstream.Produced
- hashCode() - Method in class org.apache.kafka.streams.kstream.SessionWindows
- hashCode() - Method in class org.apache.kafka.streams.kstream.SlidingWindows
- hashCode() - Method in class org.apache.kafka.streams.kstream.TimeWindows
- hashCode() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
- hashCode() - Method in class org.apache.kafka.streams.kstream.Window
- hashCode() - Method in class org.apache.kafka.streams.kstream.Windowed
- hashCode() - Method in class org.apache.kafka.streams.LagInfo
- hashCode() - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
- hashCode() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedForward
- hashCode() - Method in class org.apache.kafka.streams.processor.api.Record
- hashCode() - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask
- hashCode() - Method in class org.apache.kafka.streams.processor.assignment.ProcessId
- hashCode() - Method in class org.apache.kafka.streams.processor.TaskId
- hashCode() - Method in class org.apache.kafka.streams.processor.To
- 
Equality is implemented in support of tests, *not* for use in Hash collections, since this class is mutable.
- hashCode() - Method in class org.apache.kafka.streams.query.Position
- hashCode() - Method in class org.apache.kafka.streams.query.PositionBound
- hashCode() - Method in class org.apache.kafka.streams.state.DslKeyValueParams
- hashCode() - Method in class org.apache.kafka.streams.state.DslSessionParams
- hashCode() - Method in class org.apache.kafka.streams.state.DslWindowParams
- hashCode() - Method in class org.apache.kafka.streams.state.HostInfo
- hashCode() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
- hashCode() - Method in class org.apache.kafka.streams.state.VersionedRecord
- hashCode() - Method in class org.apache.kafka.streams.StoreQueryParameters
- hashCode() - Method in interface org.apache.kafka.streams.StreamsMetadata
- 
Returns the hash code value for this TaskMetadata.
- hashCode() - Method in interface org.apache.kafka.streams.TaskMetadata
- 
Returns the hash code value for this TaskMetadata.
- hashCode() - Method in class org.apache.kafka.streams.test.TestRecord
- hashCode() - Method in interface org.apache.kafka.streams.ThreadMetadata
- 
Returns the hash code value for this ThreadMetadata.
- hasMetrics() - Method in class org.apache.kafka.common.metrics.Sensor
- 
Return if metrics were registered with this sensor.
- hasNotStarted() - Method in enum class org.apache.kafka.streams.KafkaStreams.State
- 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
- hasStartedOrFinishedShuttingDown() - Method in enum class org.apache.kafka.streams.KafkaStreams.State
- 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
- Header - Interface in org.apache.kafka.connect.header
- 
AHeaderis a key-value pair, and multiple headers can be included with the key, value, and timestamp in each Kafka message.
- HEADER - Enum constant in enum class org.apache.kafka.connect.storage.ConverterType
- HEADER_SCHEMA - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
- HEADER_SCHEMA - Static variable in class org.apache.kafka.connect.mirror.Heartbeat
- HeaderConverter - Interface in org.apache.kafka.connect.storage
- 
The HeaderConverter interface provides support for translating between Kafka Connect's runtime data format and byte[].
- headers() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
- 
The headers (never null)
- headers() - Method in class org.apache.kafka.clients.producer.ProducerRecord
- headers() - Method in exception class org.apache.kafka.common.errors.RecordDeserializationException
- headers() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- 
Get the headers for this record.
- headers() - Method in interface org.apache.kafka.streams.errors.ErrorHandlerContext
- 
Return the headers of the current source record; could be an empty header if it is not available.
- headers() - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
- 
The headers of the record.
- headers() - Method in class org.apache.kafka.streams.processor.api.Record
- 
The headers of the record.
- headers() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedForward
- 
Deprecated.
- headers() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.Returns the headers of the current input record; could benullif it is not available.
- headers() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Return the headers of the current input record; could be an empty header if it is not available.
- headers() - Method in interface org.apache.kafka.streams.processor.RecordContext
- 
Return the headers of the current input record; could be an empty header if it is not available.
- headers() - Method in class org.apache.kafka.streams.test.TestRecord
- 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
- Headers - Interface in org.apache.kafka.connect.header
- 
A mutable ordered collection ofHeaderobjects.
- Headers.HeaderTransform - Interface in org.apache.kafka.connect.header
- 
A function to transform the suppliedHeader.
- Heartbeat - Class in org.apache.kafka.connect.mirror
- 
Heartbeat records emitted by MirrorHeartbeatConnector.
- Heartbeat(String, String, long) - Constructor for class org.apache.kafka.connect.mirror.Heartbeat
- HEARTBEAT_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- 
heartbeat.interval.ms
- heartbeatsTopic() - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
- 
Returns the name of heartbeats topic.
- heartbeatTopics() - Method in class org.apache.kafka.connect.mirror.MirrorClient
- 
Finds all heartbeats topics on this cluster.
- heartbeatTopics(Map<String, Object>) - Static method in class org.apache.kafka.connect.mirror.RemoteClusterUtils
- 
Finds all heartbeats topics
- HETEROGENEOUS - Enum constant in enum class org.apache.kafka.coordinator.group.api.assignor.SubscriptionType
- 
A heterogeneous subscription type means that not all the members of the group use the same subscription.
- HIGH - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Importance
- highestOffsetForEpoch(TopicIdPartition, int) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
- 
Returns the highest log offset of topic partition for the given leader epoch in remote storage.
- highWatermark() - Method in class org.apache.kafka.clients.admin.QuorumInfo
- Histogram - Class in org.apache.kafka.common.metrics.stats
- Histogram(Histogram.BinScheme) - Constructor for class org.apache.kafka.common.metrics.stats.Histogram
- Histogram.BinScheme - Interface in org.apache.kafka.common.metrics.stats
- 
An algorithm for determining the bin in which a value is to be placed as well as calculating the upper end of each bin.
- Histogram.ConstantBinScheme - Class in org.apache.kafka.common.metrics.stats
- 
A scheme for calculating the bins where the width of each bin is a constant determined by the range of values and the number of bins.
- Histogram.LinearBinScheme - Class in org.apache.kafka.common.metrics.stats
- 
A scheme for calculating the bins where the width of each bin is one more than the previous bin, and therefore the bin widths are increasing at a linear rate.
- history() - Method in class org.apache.kafka.clients.producer.MockProducer
- 
Get the list of sent records since the last call toMockProducer.clear()
- historyRetentionMs() - Method in interface org.apache.kafka.streams.state.VersionedBytesStoreSupplier
- 
Returns the history retention (in milliseconds) that stores created from this supplier will have.
- hmac() - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
- hmacAsBase64String() - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
- HOMOGENEOUS - Enum constant in enum class org.apache.kafka.coordinator.group.api.assignor.SubscriptionType
- 
A homogeneous subscription type means that all the members of the group use the same subscription.
- 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.clients.admin.RaftVoterEndpoint
- host() - Method in class org.apache.kafka.clients.admin.ShareMemberDescription
- 
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.Endpoint
- 
Returns advertised host name of this endpoint.
- host() - Method in class org.apache.kafka.common.Node
- 
The host name for this node
- host() - Method in class org.apache.kafka.streams.state.HostInfo
- host() - Method in interface org.apache.kafka.streams.StreamsMetadata
- 
Host where the Streams client runs.
- hostInfo() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- 
TheHostInfoof this KafkaStreams client, if set via theapplication.serverconfig
- hostInfo() - Method in interface org.apache.kafka.streams.StreamsMetadata
- 
The value ofStreamsConfig.APPLICATION_SERVER_CONFIGconfigured for the Streams client.
- HostInfo - Class in org.apache.kafka.streams.state
- 
Represents a user defined endpoint in aKafkaStreamsapplication.
- HostInfo(String, int) - Constructor for class org.apache.kafka.streams.state.HostInfo
I
- id - Variable in enum class org.apache.kafka.clients.consumer.AcknowledgeType
- id - Variable in enum class org.apache.kafka.common.metrics.Sensor.RecordingLevel
- 
the permanent and immutable id of an API--this can't change ever
- id - Variable in enum class 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 - Variable in enum class org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
- 
The permanent and immutable id for the used option.
- id - Variable in enum class org.apache.kafka.streams.errors.ProcessingExceptionHandler.ProcessingHandlerResponse
- 
The permanent and immutable id for the used option.
- id - Variable in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
- 
The permanent and immutable id for the used option.
- id - Variable in enum class org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
- 
The permanent and immutable id for the used option.
- id() - Method in enum class org.apache.kafka.clients.admin.AlterConfigOp.OpType
- id() - Method in enum class org.apache.kafka.clients.admin.EndpointType
- id() - Method in enum class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
- id() - Method in enum class org.apache.kafka.common.config.ConfigResource.Type
- id() - Method in enum class org.apache.kafka.common.IsolationLevel
- id() - Method in class org.apache.kafka.common.Node
- 
The node id of this node
- id() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentId
- id() - Method in enum class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
- id() - Method in enum class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
- id() - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask
- id() - Method in class org.apache.kafka.streams.processor.assignment.ProcessId
- id() - Method in interface org.apache.kafka.streams.processor.assignment.TaskInfo
- id() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
- id() - Method in interface org.apache.kafka.streams.TopologyDescription.Subtopology
- 
Internally assigned unique ID.
- ID_CONFIG - Static variable in class org.apache.kafka.connect.tools.SchemaSourceTask
- ID_CONFIG - Static variable in class org.apache.kafka.connect.tools.VerifiableSinkTask
- ID_CONFIG - Static variable in class org.apache.kafka.connect.tools.VerifiableSourceTask
- IDEMPOTENT_WRITE - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
- 
IDEMPOTENT_WRITE operation.
- identityAssignment(ApplicationState) - Static method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils
- 
Return a "no-op" assignment that just copies the previous assignment of tasks to KafkaStreams clients
- IdentityReplicationPolicy - Class in org.apache.kafka.connect.mirror
- 
Alternative implementation ofReplicationPolicythat does not rename remote topics.
- IdentityReplicationPolicy() - Constructor for class org.apache.kafka.connect.mirror.IdentityReplicationPolicy
- 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 Class in org.apache.kafka.common.errors
- IllegalGenerationException() - Constructor for exception class org.apache.kafka.common.errors.IllegalGenerationException
- IllegalGenerationException(String) - Constructor for exception class org.apache.kafka.common.errors.IllegalGenerationException
- IllegalGenerationException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.IllegalGenerationException
- IllegalGenerationException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.IllegalGenerationException
- IllegalSaslStateException - Exception Class in org.apache.kafka.common.errors
- 
This exception indicates unexpected requests prior to SASL authentication.
- IllegalSaslStateException(String) - Constructor for exception class org.apache.kafka.common.errors.IllegalSaslStateException
- IllegalSaslStateException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.IllegalSaslStateException
- IllegalWorkerStateException - Exception Class in org.apache.kafka.connect.errors
- 
Indicates that a method has been invoked illegally or at an invalid time by a connector or task.
- IllegalWorkerStateException(String) - Constructor for exception class org.apache.kafka.connect.errors.IllegalWorkerStateException
- IllegalWorkerStateException(String, Throwable) - Constructor for exception class org.apache.kafka.connect.errors.IllegalWorkerStateException
- IllegalWorkerStateException(Throwable) - Constructor for exception class org.apache.kafka.connect.errors.IllegalWorkerStateException
- Impact on ConsumerRebalanceListener - Search tag in class org.apache.kafka.clients.consumer.StickyAssignor
- Section
- importance - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
- in(String...) - Static method in class org.apache.kafka.common.config.ConfigDef.CaseInsensitiveValidString
- 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
- IN_MEMORY - Enum constant in enum class org.apache.kafka.streams.kstream.Materialized.StoreType
- IN_MEMORY - Static variable in class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers
- IN_MEMORY - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- inactivityGap() - Method in class org.apache.kafka.streams.kstream.SessionWindows
- 
Return the specified gap for the session windows in milliseconds.
- INCLUDE_CONFIG - Static variable in class org.apache.kafka.common.metrics.JmxReporter
- includeAuthorizedOperations() - Method in class org.apache.kafka.clients.admin.DescribeClassicGroupsOptions
- includeAuthorizedOperations() - Method in class org.apache.kafka.clients.admin.DescribeClusterOptions
- 
Specify if authorized operations should be included in the response.
- includeAuthorizedOperations() - Method in class org.apache.kafka.clients.admin.DescribeConsumerGroupsOptions
- includeAuthorizedOperations() - Method in class org.apache.kafka.clients.admin.DescribeShareGroupsOptions
- includeAuthorizedOperations() - Method in class org.apache.kafka.clients.admin.DescribeTopicsOptions
- includeAuthorizedOperations(boolean) - Method in class org.apache.kafka.clients.admin.DescribeClassicGroupsOptions
- includeAuthorizedOperations(boolean) - Method in class org.apache.kafka.clients.admin.DescribeClusterOptions
- includeAuthorizedOperations(boolean) - Method in class org.apache.kafka.clients.admin.DescribeConsumerGroupsOptions
- includeAuthorizedOperations(boolean) - Method in class org.apache.kafka.clients.admin.DescribeShareGroupsOptions
- includeAuthorizedOperations(boolean) - Method in class org.apache.kafka.clients.admin.DescribeTopicsOptions
- includeDocumentation() - Method in class org.apache.kafka.clients.admin.DescribeConfigsOptions
- 
Return true if config documentation should be returned in the response.
- includeDocumentation(boolean) - Method in class org.apache.kafka.clients.admin.DescribeConfigsOptions
- 
Set to true if config documentation should be returned in the response.
- includeFencedBrokers() - Method in class org.apache.kafka.clients.admin.DescribeClusterOptions
- 
Specify if fenced brokers should be included in the response.
- includeFencedBrokers(boolean) - Method in class org.apache.kafka.clients.admin.DescribeClusterOptions
- 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.
- InconsistentClusterIdException - Exception Class in org.apache.kafka.common.errors
- InconsistentClusterIdException(String) - Constructor for exception class org.apache.kafka.common.errors.InconsistentClusterIdException
- InconsistentClusterIdException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InconsistentClusterIdException
- InconsistentGroupProtocolException - Exception Class in org.apache.kafka.common.errors
- InconsistentGroupProtocolException(String) - Constructor for exception class org.apache.kafka.common.errors.InconsistentGroupProtocolException
- InconsistentGroupProtocolException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InconsistentGroupProtocolException
- InconsistentTopicIdException - Exception Class in org.apache.kafka.common.errors
- InconsistentTopicIdException(String) - Constructor for exception class org.apache.kafka.common.errors.InconsistentTopicIdException
- InconsistentVoterSetException - Exception Class in org.apache.kafka.common.errors
- InconsistentVoterSetException(String) - Constructor for exception class org.apache.kafka.common.errors.InconsistentVoterSetException
- InconsistentVoterSetException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InconsistentVoterSetException
- increaseTo(int) - Static method in class org.apache.kafka.clients.admin.NewPartitions
- 
Increase the partition count for a topic to the giventotalCount.
- increaseTo(int, List<List<Integer>>) - Static method in class org.apache.kafka.clients.admin.NewPartitions
- 
Increase the partition count for a topic to the giventotalCountassigning the new partitions according to the givennewAssignments.
- incrementalAlterConfigs(Map<ConfigResource, Collection<AlterConfigOp>>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Incrementally updates the configuration for the specified resources with default options.
- incrementalAlterConfigs(Map<ConfigResource, Collection<AlterConfigOp>>, AlterConfigsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Incrementally update the configuration for the specified resources.
- incrementalAlterConfigs(Map<ConfigResource, Collection<AlterConfigOp>>, AlterConfigsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- incrementalAlterConfigs(Map<ConfigResource, Collection<AlterConfigOp>>, AlterConfigsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- index() - Method in class org.apache.kafka.connect.data.Field
- 
Get the index of this field within the struct.
- INDEX_INTERVAL_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
- INDEX_INTERVAL_BYTES_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
- IneligibleReplicaException - Exception Class in org.apache.kafka.common.errors
- IneligibleReplicaException(String) - Constructor for exception class org.apache.kafka.common.errors.IneligibleReplicaException
- inferSchema(Object) - Static method in class org.apache.kafka.connect.data.Values
- 
If possible infer a schema for the given value.
- INFO - Enum constant in enum class org.apache.kafka.common.metrics.Sensor.RecordingLevel
- INFO_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
- 
TheINFOlevel designates informational messages that highlight normal Kafka events at a coarse-grained level
- inGroupStates(Set<GroupState>) - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsOptions
- 
If groupStates is set, only groups in these states will be returned by listGroups().
- inGroupStates(Set<GroupState>) - Method in class org.apache.kafka.clients.admin.ListGroupsOptions
- 
If groupStates is set, only groups in these states will be returned by listGroups().
- init(List<KafkaMetric>) - Method in class org.apache.kafka.common.metrics.JmxReporter
- init(List<KafkaMetric>) - Method in interface org.apache.kafka.common.metrics.MetricsReporter
- 
This is called when the reporter is first registered to initially register all existing metrics
- init(AccessTokenRetriever, AccessTokenValidator) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- init(CloseableVerificationKeyResolver, AccessTokenValidator) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallbackHandler
- init(FixedKeyProcessorContext<KIn, VOut>) - Method in class org.apache.kafka.streams.processor.api.ContextualFixedKeyProcessor
- init(FixedKeyProcessorContext<KIn, VOut>) - Method in interface org.apache.kafka.streams.processor.api.FixedKeyProcessor
- 
Initialize this processor with the given context.
- init(ProcessorContext<KOut, VOut>) - Method in class org.apache.kafka.streams.processor.api.ContextualProcessor
- init(ProcessorContext<KOut, VOut>) - Method in interface org.apache.kafka.streams.processor.api.Processor
- 
Initialize this processor with the given context.
- init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.Transformer
- 
Deprecated.Initialize this transformer.
- init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
- 
Deprecated.Initialize this transformer.
- init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKey
- 
Initialize this transformer.
- init(StateStoreContext, StateStore) - Method in interface org.apache.kafka.streams.processor.StateStore
- 
Initializes this state store.
- 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
- initialize(ConnectorContext) - Method in class org.apache.kafka.connect.connector.Connector
- 
Initialize this connector, using the provided ConnectorContext to notify the runtime of input configuration changes.
- initialize(ConnectorContext) - Method in class org.apache.kafka.connect.tools.MockSinkConnector
- initialize(ConnectorContext) - Method in class org.apache.kafka.connect.tools.MockSourceConnector
- initialize(ConnectorContext, List<Map<String, String>>) - Method in class org.apache.kafka.connect.connector.Connector
- 
Initialize this connector, using the provided ConnectorContext to notify the runtime of input configuration changes and using the provided set of Task configurations.
- initialize(ConnectorContext, List<Map<String, String>>) - Method in class org.apache.kafka.connect.tools.MockSinkConnector
- initialize(ConnectorContext, List<Map<String, String>>) - Method in class org.apache.kafka.connect.tools.MockSourceConnector
- initialize(SinkTaskContext) - Method in class org.apache.kafka.connect.sink.SinkTask
- 
Initialize the context of this task.
- initialize(SourceTaskContext) - Method in class org.apache.kafka.connect.source.SourceTask
- 
Initialize this SourceTask with the specified context object.
- Initializer<VAgg> - Interface in org.apache.kafka.streams.kstream
- 
TheInitializerinterface for creating an initial value in aggregations.
- initTransactionException - Variable in class org.apache.kafka.clients.producer.MockProducer
- initTransactions() - Method in class org.apache.kafka.clients.producer.KafkaProducer
- 
Needs to be called before any other methods when thetransactional.idis set in the configuration.
- initTransactions() - Method in class org.apache.kafka.clients.producer.MockProducer
- initTransactions() - Method in interface org.apache.kafka.clients.producer.Producer
- injectTimeoutException(int) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- injectTimeoutException(int) - Method in class org.apache.kafka.clients.producer.MockProducer
- InMemoryDslStoreSuppliers() - Constructor for class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers.InMemoryDslStoreSuppliers
- inMemoryKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
- 
Create an in-memoryKeyValueBytesStoreSupplier.
- inMemorySessionStore(String, Duration) - Static method in class org.apache.kafka.streams.state.Stores
- 
Create an in-memorySessionBytesStoreSupplier.
- inMemoryWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
- 
Create an in-memoryWindowBytesStoreSupplier.
- innerDeserializer() - Method in class org.apache.kafka.common.serialization.ListDeserializer
- inputExtensions() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
- INSTANCE - Static variable in exception class org.apache.kafka.common.errors.CoordinatorNotAvailableException
- INSTANCE - Static variable in exception class org.apache.kafka.common.errors.DisconnectException
- instanceId() - Method in interface org.apache.kafka.coordinator.group.api.assignor.MemberSubscription
- 
Gets the instance Id if present.
- inStates(Set<ConsumerGroupState>) - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsOptions
- 
Deprecated.Since 4.0. UseListConsumerGroupsOptions.inGroupStates(Set)instead.
- inStore(String) - Static method in class org.apache.kafka.streams.query.StateQueryRequest
- 
Specifies the name of the store to query.
- 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 - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigType
- INT - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Type
- 
Used for numerical values within the Java Integer range.
- int16() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- INT16 - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
- 
16-bit signed integer
- INT16_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- int32() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- INT32 - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
- 
32-bit signed integer
- INT32_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- int64() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- INT64 - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
- 
64-bit signed integer
- INT64_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- int8() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- INT8 - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
- 
8-bit signed integer
- INT8_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- Integer() - Static method in class org.apache.kafka.common.serialization.Serdes
- 
A serde for nullableIntegertype.
- IntegerDecoder - Class in org.apache.kafka.tools.api
- 
The integer decoder translates bytes into integers.
- IntegerDecoder() - Constructor for class org.apache.kafka.tools.api.IntegerDecoder
- 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
- interBrokerEndpoint() - Method in interface org.apache.kafka.server.authorizer.AuthorizerServerInfo
- 
Returns the inter-broker endpoint.
- 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 Interface in org.apache.kafka.common.annotation
- 
Compatibility may be broken at minor release (i.e.
- InterfaceStability.Stable - Annotation Interface 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 Interface in org.apache.kafka.common.annotation
- 
No guarantee is provided as to reliability or stability across any level of release granularity.
- INTERNAL_TASK_ASSIGNOR_CLASS - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- INTERNAL_TOPIC_SEPARATOR_ENABLED - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- INTERNAL_TOPIC_SEPARATOR_ENABLED_CONFIG - Static variable in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
- INTERNAL_TOPIC_SEPARATOR_ENABLED_DEFAULT - Static variable in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
- INTERNAL_TOPIC_SEPARATOR_ENABLED_DEFAULT - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- INTERNAL_TOPIC_SEPARATOR_ENABLED_DOC - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- internalConfig - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
- InternalConfig() - Constructor for class org.apache.kafka.streams.StreamsConfig.InternalConfig
- InternalConfig() - Constructor for class org.apache.kafka.streams.TopologyConfig.InternalConfig
- InternalFixedKeyRecordFactory - Class in org.apache.kafka.streams.processor.api
- internalTopics() - Method in class org.apache.kafka.common.Cluster
- InterruptException - Exception Class in org.apache.kafka.common.errors
- 
An unchecked wrapper for InterruptedException
- InterruptException(InterruptedException) - Constructor for exception class org.apache.kafka.common.errors.InterruptException
- InterruptException(String) - Constructor for exception class org.apache.kafka.common.errors.InterruptException
- InterruptException(String, InterruptedException) - Constructor for exception class org.apache.kafka.common.errors.InterruptException
- INTERVAL - Enum constant in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
- 
Transactions will be started and committed on a user-defined time interval.
- INVALID_STANDBY_TASK - Enum constant in enum class org.apache.kafka.streams.processor.assignment.TaskAssignor.AssignmentError
- InvalidCommitOffsetSizeException - Exception Class in org.apache.kafka.common.errors
- InvalidCommitOffsetSizeException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidCommitOffsetSizeException
- InvalidCommitOffsetSizeException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidCommitOffsetSizeException
- InvalidConfigurationException - Exception Class in org.apache.kafka.common.errors
- InvalidConfigurationException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidConfigurationException
- InvalidConfigurationException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidConfigurationException
- invalidExtensions() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
- InvalidFetchSessionEpochException - Exception Class in org.apache.kafka.common.errors
- InvalidFetchSessionEpochException() - Constructor for exception class org.apache.kafka.common.errors.InvalidFetchSessionEpochException
- InvalidFetchSessionEpochException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidFetchSessionEpochException
- InvalidFetchSizeException - Exception Class in org.apache.kafka.common.errors
- InvalidFetchSizeException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidFetchSizeException
- InvalidFetchSizeException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidFetchSizeException
- InvalidGroupIdException - Exception Class in org.apache.kafka.common.errors
- InvalidGroupIdException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidGroupIdException
- InvalidGroupIdException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidGroupIdException
- InvalidMetadataException - Exception Class in org.apache.kafka.common.errors
- 
An exception that may indicate the client's metadata is out of date
- InvalidOffsetException - Exception Class 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 Class 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 class org.apache.kafka.clients.consumer.InvalidOffsetException
- InvalidOffsetException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidOffsetException
- InvalidOffsetException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidOffsetException
- InvalidPartitionsException - Exception Class in org.apache.kafka.common.errors
- InvalidPartitionsException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidPartitionsException
- InvalidPartitionsException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidPartitionsException
- InvalidPidMappingException - Exception Class in org.apache.kafka.common.errors
- InvalidPidMappingException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidPidMappingException
- InvalidPrincipalTypeException - Exception Class in org.apache.kafka.common.errors
- InvalidPrincipalTypeException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidPrincipalTypeException
- InvalidPrincipalTypeException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidPrincipalTypeException
- InvalidProducerEpochException - Exception Class in org.apache.kafka.common.errors
- 
This exception indicates that the produce request sent to the partition leader contains a non-matching producer epoch.
- InvalidProducerEpochException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidProducerEpochException
- InvalidRecordException - Exception Class in org.apache.kafka.common
- InvalidRecordException(String) - Constructor for exception class org.apache.kafka.common.InvalidRecordException
- InvalidRecordException(String, Throwable) - Constructor for exception class org.apache.kafka.common.InvalidRecordException
- InvalidRecordStateException - Exception Class in org.apache.kafka.common.errors
- 
Thrown when the acknowledgement of delivery of a record could not be completed because the record state is invalid.
- InvalidRecordStateException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidRecordStateException
- InvalidRegistrationException - Exception Class in org.apache.kafka.common.errors
- 
Thrown when a broker registration request is considered invalid by the controller.
- InvalidRegistrationException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidRegistrationException
- InvalidRegularExpression - Exception Class in org.apache.kafka.common.errors
- 
Thrown when a regular expression received in a request is not valid.
- InvalidRegularExpression(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidRegularExpression
- InvalidReplicaAssignmentException - Exception Class in org.apache.kafka.common.errors
- InvalidReplicaAssignmentException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidReplicaAssignmentException
- InvalidReplicaAssignmentException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidReplicaAssignmentException
- InvalidReplicationFactorException - Exception Class in org.apache.kafka.common.errors
- InvalidReplicationFactorException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidReplicationFactorException
- InvalidReplicationFactorException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidReplicationFactorException
- InvalidRequestException - Exception Class in org.apache.kafka.common.errors
- 
Thrown when a request breaks basic wire protocol rules.
- InvalidRequestException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidRequestException
- InvalidRequestException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidRequestException
- InvalidRequiredAcksException - Exception Class in org.apache.kafka.common.errors
- InvalidRequiredAcksException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidRequiredAcksException
- InvalidSessionTimeoutException - Exception Class in org.apache.kafka.common.errors
- InvalidSessionTimeoutException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidSessionTimeoutException
- InvalidSessionTimeoutException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidSessionTimeoutException
- InvalidShareSessionEpochException - Exception Class in org.apache.kafka.common.errors
- 
Thrown when the share session epoch is invalid.
- InvalidShareSessionEpochException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidShareSessionEpochException
- InvalidStateStoreException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates that there was a problem when trying to access aStateStore.
- InvalidStateStoreException(String) - Constructor for exception class org.apache.kafka.streams.errors.InvalidStateStoreException
- InvalidStateStoreException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.InvalidStateStoreException
- InvalidStateStoreException(Throwable) - Constructor for exception class org.apache.kafka.streams.errors.InvalidStateStoreException
- InvalidStateStorePartitionException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates that the specific state store being queried viaStoreQueryParametersused a partitioning that is not assigned to this instance.
- InvalidStateStorePartitionException(String) - Constructor for exception class org.apache.kafka.streams.errors.InvalidStateStorePartitionException
- InvalidStateStorePartitionException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.InvalidStateStorePartitionException
- InvalidTimestampException - Exception Class in org.apache.kafka.common.errors
- 
Indicate the timestamp of a record is invalid.
- InvalidTimestampException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidTimestampException
- InvalidTimestampException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidTimestampException
- InvalidTopicException - Exception Class in org.apache.kafka.common.errors
- 
The client has attempted to perform an operation on an invalid topic.
- InvalidTopicException() - Constructor for exception class org.apache.kafka.common.errors.InvalidTopicException
- InvalidTopicException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidTopicException
- InvalidTopicException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidTopicException
- InvalidTopicException(String, Set<String>) - Constructor for exception class org.apache.kafka.common.errors.InvalidTopicException
- InvalidTopicException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidTopicException
- InvalidTopicException(Set<String>) - Constructor for exception class org.apache.kafka.common.errors.InvalidTopicException
- invalidTopics() - Method in class org.apache.kafka.common.Cluster
- invalidTopics() - Method in exception class org.apache.kafka.common.errors.InvalidTopicException
- InvalidTxnStateException - Exception Class in org.apache.kafka.common.errors
- InvalidTxnStateException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidTxnStateException
- InvalidTxnTimeoutException - Exception Class 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 class org.apache.kafka.common.errors.InvalidTxnTimeoutException
- InvalidTxnTimeoutException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidTxnTimeoutException
- InvalidUpdateVersionException - Exception Class in org.apache.kafka.common.errors
- InvalidUpdateVersionException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidUpdateVersionException
- InvalidUpdateVersionException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidUpdateVersionException
- InvalidVoterKeyException - Exception Class in org.apache.kafka.common.errors
- InvalidVoterKeyException(String) - Constructor for exception class org.apache.kafka.common.errors.InvalidVoterKeyException
- InvalidVoterKeyException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.InvalidVoterKeyException
- IP - Static variable in class org.apache.kafka.common.quota.ClientQuotaEntity
- IQ_CONSISTENCY_OFFSET_VECTOR_ENABLED - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- isAllPartitions() - Method in class org.apache.kafka.streams.query.StateQueryRequest
- 
Whether this request should fetch from all locally available partitions.
- 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.
- isChangelog() - Method in interface org.apache.kafka.streams.processor.assignment.TaskTopicPartition
- isCheckpointsTopic(String) - Method in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
- isCheckpointsTopic(String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
- 
Returns true if the topic is a checkpoints topic.
- isCollectExecutionInfo() - Method in class org.apache.kafka.streams.query.QueryConfig
- 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.
- isEmpty() - Method in class org.apache.kafka.connect.header.ConnectHeaders
- isEmpty() - Method in interface org.apache.kafka.connect.header.Headers
- 
Determine whether this object has no headers.
- isEmpty() - Method in class org.apache.kafka.streams.query.Position
- isEmpty() - Method in class org.apache.kafka.streams.TestOutputTopic
- 
Verify if the topic queue is empty.
- isFailure() - Method in interface org.apache.kafka.streams.query.QueryResult
- 
True iff the query execution failed.
- isFenced() - Method in class org.apache.kafka.common.Node
- 
Whether if this node is fenced
- isFuture() - Method in class org.apache.kafka.clients.admin.ReplicaInfo
- 
Whether this replica has been created by a AlterReplicaLogDirsRequest but not yet replaced the current replica on the broker.
- isHeartbeatsTopic(String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
- 
Returns true if the topic is a heartbeats topic
- 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.
- isInternalTopic(String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
- 
Returns true if the topic is considered an internal topic.
- isMeasurable() - Method in class org.apache.kafka.common.metrics.KafkaMetric
- 
The method determines if the metric value provider is of type Measurable.
- isMM2InternalTopic(String) - Method in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
- isMM2InternalTopic(String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
- 
Returns true if the topic is one of MirrorMaker internal topics.
- isNamedTopology() - Method in class org.apache.kafka.streams.TopologyConfig
- 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
- isolationLevel() - Method in class org.apache.kafka.clients.admin.ListOffsetsOptions
- IsolationLevel - Enum Class in org.apache.kafka.common
- isOpen() - Method in interface org.apache.kafka.streams.processor.StateStore
- 
Is this store open for reading and writing
- isOptional() - Method in class org.apache.kafka.connect.data.ConnectSchema
- isOptional() - Method in interface org.apache.kafka.connect.data.Schema
- isOptional() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- isPartitionAssigned(Uuid, int) - Method in interface org.apache.kafka.coordinator.group.api.assignor.GroupSpec
- isPaused() - Method in class org.apache.kafka.streams.KafkaStreams
- isPrimitive() - Method in enum class org.apache.kafka.connect.data.Schema.Type
- 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.
- isReady(TopicIdPartition) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
- 
Denotes whether the partition metadata is ready to serve.
- isRequireActive() - Method in class org.apache.kafka.streams.query.StateQueryRequest
- 
Whether this request requires the query to execute only on active partitions.
- isRunningOrRebalancing() - Method in enum class org.apache.kafka.streams.KafkaStreams.State
- isSensitive() - Method in class org.apache.kafka.clients.admin.ConfigEntry
- 
Return whether the config value is sensitive.
- isSensitive() - Method in enum class org.apache.kafka.common.config.ConfigDef.Type
- 
Whether this type contains sensitive data such as a password or key.
- isShuttingDown() - Method in enum class org.apache.kafka.streams.KafkaStreams.State
- isSimpleConsumerGroup() - Method in class org.apache.kafka.clients.admin.ClassicGroupDescription
- 
If the group is a simple consumer group or not.
- 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.
- isSimpleConsumerGroup() - Method in class org.apache.kafka.clients.admin.GroupListing
- 
If the group is a simple consumer group or not.
- isSkipCache() - Method in class org.apache.kafka.streams.query.KeyQuery
- 
The flag whether to skip the cache or not during query evaluation.
- isSkipCache() - Method in class org.apache.kafka.streams.query.TimestampedKeyQuery
- 
The flag whether to skip the cache or not during query evaluation.
- isSlidingWindow() - Method in class org.apache.kafka.streams.state.DslWindowParams
- isSource() - Method in interface org.apache.kafka.streams.processor.assignment.TaskTopicPartition
- isSpecific() - Method in enum class org.apache.kafka.common.resource.PatternType
- isStateful() - Method in interface org.apache.kafka.streams.processor.assignment.TaskInfo
- isSuccess() - Method in interface org.apache.kafka.streams.query.QueryResult
- 
True iff the query was successfully executed.
- issueTimestamp() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
- isTerminating() - Method in interface org.apache.kafka.server.telemetry.ClientTelemetryPayload
- 
Indicates whether the client is terminating and thus making its last metrics push.
- isTimestamped() - Method in class org.apache.kafka.streams.state.DslKeyValueParams
- isTimestamped() - Method in class org.apache.kafka.streams.state.DslWindowParams
- isTxnIdxEmpty() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- 
If true indicates that the transaction index is empty.
- isUnbounded() - Method in class org.apache.kafka.streams.query.PositionBound
- 
Returns true iff this object specifies that there is no position bound.
- 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 class org.apache.kafka.common.acl.AclOperation
- 
Return true if this operation is UNKNOWN.
- isUnknown() - Method in enum class org.apache.kafka.common.acl.AclPermissionType
- 
Return true if this permission type is UNKNOWN.
- isUnknown() - Method in enum class 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.ResourcePattern
- isUnknown() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
- isUnknown() - Method in enum class org.apache.kafka.common.resource.ResourceType
- 
Return whether this resource type is UNKNOWN.
- isUpperBound() - Method in class org.apache.kafka.common.metrics.Quota
- isValidEntityType(String) - Static method in class org.apache.kafka.common.quota.ClientQuotaEntity
- isValidTransition(RemoteLogSegmentState, RemoteLogSegmentState) - Static method in enum class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
- isValidTransition(RemotePartitionDeleteState, RemotePartitionDeleteState) - Static method in enum class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
- isValidTransition(KafkaStreams.State) - Method in enum class org.apache.kafka.streams.KafkaStreams.State
- iterations() - Method in class org.apache.kafka.clients.admin.ScramCredentialInfo
- 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
- iterator() - Method in class org.apache.kafka.connect.header.ConnectHeaders
J
- JmxReporter - Class in org.apache.kafka.common.metrics
- 
Register metrics in JMX as dynamic mbeans based on the metric names
- JmxReporter() - Constructor for class org.apache.kafka.common.metrics.JmxReporter
- join(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoiner<? super V, ? super GV, ? extends RV>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream withGlobalKTable's records using non-windowed inner equi join.
- join(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoiner<? super V, ? super GV, ? extends RV>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream withGlobalKTable's records using non-windowed inner equi join.
- join(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream withGlobalKTable's records using non-windowed inner equi join.
- join(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream withGlobalKTable's records using non-windowed inner equi join.
- join(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream with anotherKStream's records using windowed inner equi join with default serializers and deserializers.
- join(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream with anotherKStream's records using windowed inner equi join using theStreamJoinedinstance for configuration of thekey serde,this stream's value serde,the other stream's value serde, and used state stores.
- join(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream with anotherKStream's records using windowed inner equi join with default serializers and deserializers.
- join(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream with anotherKStream's records using windowed inner equi join using theStreamJoinedinstance for configuration of thekey serde,this stream's value serde,the other stream's value serde, and used state stores.
- join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTable's records using non-windowed inner equi join, with default serializers, deserializers, and state store.
- join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTable's records using non-windowed inner equi join, with theMaterializedinstance for configuration of thekey serde,the result table's value serde, andstate store.
- join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTable's records using non-windowed inner equi join, with default serializers, deserializers, and state store.
- join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTable's records using non-windowed inner equi join, with theMaterializedinstance for configuration of thekey serde,the result table's value serde, andstate store.
- join(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream withKTable's records using non-windowed inner equi join with default serializers and deserializers.
- join(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>, Joined<K, V, VT>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream withKTable's records using non-windowed inner equi join with default serializers and deserializers.
- join(KTable<K, VT>, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream withKTable's records using non-windowed inner equi join with default serializers and deserializers.
- join(KTable<K, VT>, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR>, Joined<K, V, VT>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream withKTable's records using non-windowed inner equi join with default serializers and deserializers.
- join(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTableusing non-windowed inner join.
- join(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTableusing non-windowed inner join.
- join(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTableusing non-windowed inner join, using theTableJoinedinstance for optional configurations includingpartitionerswhen the tables being joined use non-default partitioning, and also the base name for components of the join.
- join(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTableusing non-windowed inner join, using theTableJoinedinstance for optional configurations includingpartitionerswhen the tables being joined use non-default partitioning, and also the base name for components of the join.
- join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTableusing non-windowed inner join.
- join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTableusing non-windowed inner join.
- join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTableusing non-windowed inner join, using theTableJoinedinstance for optional configurations includingpartitionerswhen the tables being joined use non-default partitioning, and also the base name for components of the join.
- join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTableusing non-windowed inner join, using theTableJoinedinstance for optional configurations includingpartitionerswhen the tables being joined use non-default partitioning, and also the base name for components of the join.
- Joined<K,VLeft, - Class in org.apache.kafka.streams.kstreamVRight> 
- 
TheJoinedclass represents optional params that can be passed toKStream#join(KTable,...)andKStream#leftJoin(KTable,...)operations.
- JoinWindows - Class in org.apache.kafka.streams.kstream
- 
The window specifications used for joins.
K
- KafkaAdminClient - Class in org.apache.kafka.clients.admin
- 
The default implementation ofAdmin.
- KafkaClientSupplier - Interface in org.apache.kafka.streams
- 
KafkaClientSuppliercan be used to provide custom Kafka clients to aKafkaStreamsinstance.
- kafkaClusterId() - Method in interface org.apache.kafka.connect.health.ConnectClusterDetails
- 
Get the cluster ID of the Kafka cluster backing this Connect cluster.
- 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 valueDeserializer.
- KafkaConsumer(Properties) - Constructor for class org.apache.kafka.clients.consumer.KafkaConsumer
- 
A consumer is instantiated by providing aPropertiesobject as configuration.
- KafkaConsumer(Properties, Deserializer<K>, Deserializer<V>) - Constructor for class org.apache.kafka.clients.consumer.KafkaConsumer
- 
A consumer is instantiated by providing aPropertiesobject as configuration, and a key and a valueDeserializer.
- KafkaException - Exception Class in org.apache.kafka.common
- 
The base class of all other Kafka exceptions
- KafkaException() - Constructor for exception class org.apache.kafka.common.KafkaException
- KafkaException(String) - Constructor for exception class org.apache.kafka.common.KafkaException
- KafkaException(String, Throwable) - Constructor for exception class org.apache.kafka.common.KafkaException
- KafkaException(Throwable) - Constructor for exception class 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.
- KafkaMetric - Class in org.apache.kafka.common.metrics
- KafkaMetric(Object, MetricName, MetricValueProvider<?>, MetricConfig, Time) - Constructor for class org.apache.kafka.common.metrics.KafkaMetric
- 
Create a metric to monitor an object that implements MetricValueProvider.
- KafkaMetricsContext - Class in org.apache.kafka.common.metrics
- 
An implementation of MetricsContext, it encapsulates required metrics context properties for Kafka services and clients
- KafkaMetricsContext(String) - Constructor for class org.apache.kafka.common.metrics.KafkaMetricsContext
- 
Create a MetricsContext with namespace, no service or client properties
- KafkaMetricsContext(String, Map<String, ?>) - Constructor for class org.apache.kafka.common.metrics.KafkaMetricsContext
- 
Create a MetricsContext with namespace, service or client properties
- kafkaOffset() - Method in class org.apache.kafka.connect.sink.SinkRecord
- kafkaPartition() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- 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
- KafkaPrincipal(String, String, boolean) - 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 throughSslAuthenticationContextand SASL throughSaslAuthenticationContext.
- KafkaPrincipalSerde - Interface in org.apache.kafka.common.security.auth
- 
Serializer/Deserializer interface forKafkaPrincipalfor the purpose of inter-broker forwarding.
- 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 valueSerializer.
- 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 valueSerializer.
- KafkaShareConsumer<K,V> - Class in org.apache.kafka.clients.consumer
- 
A client that consumes records from a Kafka cluster using a share group.
- KafkaShareConsumer(Map<String, Object>) - Constructor for class org.apache.kafka.clients.consumer.KafkaShareConsumer
- 
A consumer is instantiated by providing a set of key-value pairs as configuration.
- KafkaShareConsumer(Map<String, Object>, Deserializer<K>, Deserializer<V>) - Constructor for class org.apache.kafka.clients.consumer.KafkaShareConsumer
- 
A consumer is instantiated by providing a set of key-value pairs as configuration, and a key and a valueDeserializer.
- KafkaShareConsumer(Properties) - Constructor for class org.apache.kafka.clients.consumer.KafkaShareConsumer
- 
A consumer is instantiated by providing aPropertiesobject as configuration.
- KafkaShareConsumer(Properties, Deserializer<K>, Deserializer<V>) - Constructor for class org.apache.kafka.clients.consumer.KafkaShareConsumer
- 
A consumer is instantiated by providing aPropertiesobject as configuration, and a key and a valueDeserializer.
- KafkaStorageException - Exception Class in org.apache.kafka.common.errors
- 
Miscellaneous disk-related IOException occurred when handling a request.
- KafkaStorageException() - Constructor for exception class org.apache.kafka.common.errors.KafkaStorageException
- KafkaStorageException(String) - Constructor for exception class org.apache.kafka.common.errors.KafkaStorageException
- KafkaStorageException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.KafkaStorageException
- KafkaStorageException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.KafkaStorageException
- KafkaStreams - Class in org.apache.kafka.streams
- 
A Kafka client that allows for performing continuous computation on input coming from one or more input topics and sends output to zero, one, or more output topics.
- KafkaStreams(Topology, Properties) - Constructor for class org.apache.kafka.streams.KafkaStreams
- 
Create aKafkaStreamsinstance.
- KafkaStreams(Topology, Properties, Time) - Constructor for class org.apache.kafka.streams.KafkaStreams
- 
Create aKafkaStreamsinstance.
- KafkaStreams(Topology, Properties, KafkaClientSupplier) - Constructor for class org.apache.kafka.streams.KafkaStreams
- 
Create aKafkaStreamsinstance.
- KafkaStreams(Topology, Properties, KafkaClientSupplier, Time) - Constructor for class org.apache.kafka.streams.KafkaStreams
- 
Create aKafkaStreamsinstance.
- KafkaStreams(Topology, StreamsConfig) - Constructor for class org.apache.kafka.streams.KafkaStreams
- 
Create aKafkaStreamsinstance.
- KafkaStreams(Topology, StreamsConfig, Time) - Constructor for class org.apache.kafka.streams.KafkaStreams
- 
Create aKafkaStreamsinstance.
- KafkaStreams(Topology, StreamsConfig, KafkaClientSupplier) - Constructor for class org.apache.kafka.streams.KafkaStreams
- 
Create aKafkaStreamsinstance.
- KafkaStreams.CloseOptions - Class in org.apache.kafka.streams
- 
Class that handles options passed in case ofKafkaStreamsinstance scale down
- KafkaStreams.State - Enum Class in org.apache.kafka.streams
- 
Kafka Streams states are the possible state that a Kafka Streams instance can be in.
- KafkaStreams.StateListener - Interface in org.apache.kafka.streams
- 
Listen toKafkaStreams.Statechange events.
- KafkaStreamsAssignment - Class in org.apache.kafka.streams.processor.assignment
- 
A simple container class for the assignor to return the desired placement of active and standby tasks on KafkaStreams clients.
- KafkaStreamsAssignment.AssignedTask - Class in org.apache.kafka.streams.processor.assignment
- KafkaStreamsAssignment.AssignedTask.Type - Enum Class in org.apache.kafka.streams.processor.assignment
- KafkaStreamsState - Interface in org.apache.kafka.streams.processor.assignment
- 
A read-only metadata class representing the current state of each KafkaStreams client with at least one StreamThread participating in this rebalance
- kafkaStreamsStates(boolean) - Method in interface org.apache.kafka.streams.processor.assignment.ApplicationState
- key - Variable in class org.apache.kafka.streams.KeyValue
- 
The key of the key-value pair.
- 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() - Method in class org.apache.kafka.common.quota.ClientQuotaAlteration.Op
- key() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- key() - Method in interface org.apache.kafka.connect.header.Header
- 
The header's key, which is not necessarily unique within the set of headers on a Kafka message.
- key() - Method in class org.apache.kafka.streams.kstream.Windowed
- 
Return the key of the window.
- key() - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
- 
The key of the record.
- key() - Method in class org.apache.kafka.streams.processor.api.Record
- 
The key of the record.
- key() - Method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
- 
The key that was specified for this query.
- key() - Method in class org.apache.kafka.streams.query.TimestampedKeyQuery
- 
Return the key that was specified for this query.
- key() - Method in class org.apache.kafka.streams.query.VersionedKeyQuery
- 
The key that was specified for this query.
- key() - Method in class org.apache.kafka.streams.test.TestRecord
- KEY - Enum constant in enum class org.apache.kafka.common.errors.RecordDeserializationException.DeserializationExceptionOrigin
- KEY - Enum constant in enum class org.apache.kafka.connect.storage.ConverterType
- KEY - Enum constant in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.SerializationExceptionOrigin
- 
Serialization exception occurred during serialization of the key.
- 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_SCHEMA - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
- KEY_SCHEMA - Static variable in class org.apache.kafka.connect.mirror.Heartbeat
- 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
- keyBuffer() - Method in exception class org.apache.kafka.common.errors.RecordDeserializationException
- keyDeserializer() - Method in class org.apache.kafka.streams.state.StateSerdes
- 
Return the key deserializer.
- keyFrom(byte[]) - Method in class org.apache.kafka.streams.state.StateSerdes
- 
Deserialize the key from raw bytes.
- KeyQuery<K,V> - Class in org.apache.kafka.streams.query
- 
Interactive query for retrieving a single record based on its key.
- KeyQueryMetadata - Class in org.apache.kafka.streams
- 
Represents all the metadata related to a key, where a particular key resides in aKafkaStreamsapplication.
- KeyQueryMetadata(HostInfo, Set<HostInfo>, int) - Constructor for class org.apache.kafka.streams.KeyQueryMetadata
- keySchema() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- keySchema() - Method in class org.apache.kafka.connect.data.ConnectSchema
- keySchema() - Method in interface org.apache.kafka.connect.data.Schema
- 
Get the key schema for this map schema.
- keySchema() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- keySerde() - Method in class org.apache.kafka.streams.kstream.Joined
- 
Deprecated.Since 4.0 and should not be used any longer.
- keySerde() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- keySerde() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
- 
Return the default key serde.
- keySerde() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- keySerde() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Return the default key serde.
- keySerde() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
- 
Returns the default key serde.
- keySerde() - Method in class org.apache.kafka.streams.state.StateSerdes
- 
Return the key serde.
- keySerde(Serde<K>) - Static method in class org.apache.kafka.streams.kstream.Grouped
- 
Create aGroupedinstance with the provided keySerde.
- keySerde(Serde<K>) - Static method in class org.apache.kafka.streams.kstream.Joined
- 
Create an instance ofJoinedwith a keySerde.
- keySerde(Serde<K>) - Static method in class org.apache.kafka.streams.kstream.Produced
- 
Create a Produced instance with provided keySerde.
- keySerializer() - Method in class org.apache.kafka.streams.state.StateSerdes
- 
Return the key serializer.
- keystore() - Method in interface org.apache.kafka.common.security.auth.SslEngineFactory
- 
Returns keystore configured for this factory.
- keyValue() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedForward
- 
Deprecated.The data forwarded.
- KeyValue<K,V> - Class in org.apache.kafka.streams
- 
A key-value pair defined for a single Kafka Streams record.
- KeyValue(K, V) - Constructor for class org.apache.kafka.streams.KeyValue
- 
Create a new key-value pair.
- KeyValueBytesStoreSupplier - Interface in org.apache.kafka.streams.state
- 
A store supplier that can be used to create one or moreKeyValueStore<Bytes, byte[]>instances of type <Bytes, byte[]>.
- KeyValueIterator<K,V> - Interface in org.apache.kafka.streams.state
- 
Iterator interface ofKeyValue.
- KeyValueMapper<K,V, - Interface in org.apache.kafka.streams.kstreamVR> 
- 
TheKeyValueMapperinterface for mapping akey-value pairto a new value of arbitrary type.
- keyValueStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
- 
AQueryableStoreTypethat acceptsReadOnlyKeyValueStore.
- keyValueStore(DslKeyValueParams) - Method in enum class org.apache.kafka.streams.kstream.Materialized.StoreType
- keyValueStore(DslKeyValueParams) - Method in class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers.InMemoryDslStoreSuppliers
- keyValueStore(DslKeyValueParams) - Method in class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers.RocksDBDslStoreSuppliers
- keyValueStore(DslKeyValueParams) - Method in interface org.apache.kafka.streams.state.DslStoreSuppliers
- KeyValueStore<K,V> - Interface in org.apache.kafka.streams.state
- 
A key-value store that supports put/get/delete and range queries.
- keyValueStoreBuilder(KeyValueBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
- 
Creates aStoreBuilderthat can be used to build aKeyValueStore.
- KGroupedStream<K,V> - Interface in org.apache.kafka.streams.kstream
- 
KGroupedStreamis an abstraction of a grouped record stream ofKeyValuepairs.
- KGroupedTable<K,V> - Interface in org.apache.kafka.streams.kstream
- 
KGroupedTableis an abstraction of a re-grouped changelog stream from a primary-keyed table, usually on a different grouping key than the original primary key.
- KStream<K,V> - Interface in org.apache.kafka.streams.kstream
- 
KStreamis an abstraction of a record stream ofKeyValuepairs, i.e., each record is an independent entity/event in the real world.
- KTable<K,V> - Interface in org.apache.kafka.streams.kstream
- 
KTableis an abstraction of a changelog stream from a primary-keyed table.
L
- lagFor(TaskId) - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- 
Returns the total lag across all logged stores in the task.
- LagInfo - Class in org.apache.kafka.streams
- 
Encapsulates information about lag, at a store partition replica (active or standby).
- lastCaughtUpTimestamp() - Method in class org.apache.kafka.clients.admin.QuorumInfo.ReplicaState
- 
Return the last millisecond timestamp at which this replica was known to be caught up with the leader.
- lastFetchTimestamp() - Method in class org.apache.kafka.clients.admin.QuorumInfo.ReplicaState
- 
Return the last millisecond timestamp that the leader received a fetch from this replica.
- lastHeader(String) - Method in interface org.apache.kafka.common.header.Headers
- 
Returns just one (the very last) header for the given key, if present.
- lastKnownElr() - Method in class org.apache.kafka.common.TopicPartitionInfo
- 
Return the last known eligible leader replicas of the partition.
- lastPollTimeout() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- lastSequence() - Method in class org.apache.kafka.clients.admin.ProducerState
- lastTimestamp() - Method in class org.apache.kafka.clients.admin.ProducerState
- lastWithName(String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- lastWithName(String) - Method in interface org.apache.kafka.connect.header.Headers
- 
Return the lastHeaderwith the specified key.
- latest() - Static method in class org.apache.kafka.clients.admin.OffsetSpec
- 
Used to retrieve the latest offset of a partition
- latest() - Static method in class org.apache.kafka.streams.AutoOffsetReset
- 
Creates anAutoOffsetResetinstance representing "latest".
- LATEST - Enum constant in enum class org.apache.kafka.clients.consumer.OffsetResetStrategy
- 
Deprecated.
- LATEST - Enum constant in enum class org.apache.kafka.streams.Topology.AutoOffsetReset
- 
Deprecated.
- LatestSpec() - Constructor for class org.apache.kafka.clients.admin.OffsetSpec.LatestSpec
- latestTiered() - Static method in class org.apache.kafka.clients.admin.OffsetSpec
- 
Used to retrieve the highest offset of data stored in remote storage.
- LatestTieredSpec() - Constructor for class org.apache.kafka.clients.admin.OffsetSpec.LatestTieredSpec
- 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.
- LEADER_EPOCH - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemoteStorageManager.IndexType
- 
Represents leader epoch index.
- leaderEpoch() - Method in class org.apache.kafka.clients.admin.ListOffsetsResult.ListOffsetsResultInfo
- leaderEpoch() - Method in class org.apache.kafka.clients.admin.QuorumInfo
- 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).
- leaderEpochIndex() - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
- leaderFor(TopicPartition) - Method in class org.apache.kafka.common.Cluster
- 
Get the current leader for the given topic-partition
- leaderId() - Method in class org.apache.kafka.clients.admin.QuorumInfo
- LeaderNotAvailableException - Exception Class 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 class org.apache.kafka.common.errors.LeaderNotAvailableException
- LeaderNotAvailableException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.LeaderNotAvailableException
- leaveGroup(boolean) - Method in class org.apache.kafka.streams.KafkaStreams.CloseOptions
- leftJoin(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoiner<? super V, ? super GV, ? extends RV>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream withGlobalKTable's records using non-windowed left equi join.
- leftJoin(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoiner<? super V, ? super GV, ? extends RV>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream withGlobalKTable's records using non-windowed left equi join.
- leftJoin(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream withGlobalKTable's records using non-windowed left equi join.
- leftJoin(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream withGlobalKTable's records using non-windowed left equi join.
- leftJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream with anotherKStream's records using windowed left equi join with default serializers and deserializers.
- leftJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream with anotherKStream's records using windowed left equi join using theStreamJoinedinstance for configuration of thekey serde,this stream's value serde,the other stream's value serde, and used state stores.
- leftJoin(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream with anotherKStream's records using windowed left equi join with default serializers and deserializers.
- leftJoin(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream with anotherKStream's records using windowed left equi join using theStreamJoinedinstance for configuration of thekey serde,this stream's value serde,the other stream's value serde, and used state stores.
- leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTable(left input) with anotherKTable's (right input) records using non-windowed left equi join, with default serializers, deserializers, and state store.
- leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTable(left input) with anotherKTable's (right input) records using non-windowed left equi join, with theMaterializedinstance for configuration of thekey serde,the result table's value serde, andstate store.
- leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTable(left input) with anotherKTable's (right input) records using non-windowed left equi join, with default serializers, deserializers, and state store.
- leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTable(left input) with anotherKTable's (right input) records using non-windowed left equi join, with theMaterializedinstance for configuration of thekey serde,the result table's value serde, andstate store.
- leftJoin(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream withKTable's records using non-windowed left equi join with default serializers and deserializers.
- leftJoin(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>, Joined<K, V, VT>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream withKTable's records using non-windowed left equi join with default serializers and deserializers.
- leftJoin(KTable<K, VT>, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream withKTable's records using non-windowed left equi join with default serializers and deserializers.
- leftJoin(KTable<K, VT>, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR>, Joined<K, V, VT>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream withKTable's records using non-windowed left equi join with default serializers and deserializers.
- leftJoin(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTableusing non-windowed left join.
- leftJoin(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTableusing non-windowed left join.
- leftJoin(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTableusing non-windowed left join, using theTableJoinedinstance for optional configurations includingpartitionerswhen the tables being joined use non-default partitioning, and also the base name for components of the join.
- leftJoin(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTableusing non-windowed left join, using theTableJoinedinstance for optional configurations includingpartitionerswhen the tables being joined use non-default partitioning, and also the base name for components of the join.
- leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTableusing non-windowed left join.
- leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTableusing non-windowed left join.
- leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTableusing non-windowed left join, using theTableJoinedinstance for optional configurations includingpartitionerswhen the tables being joined use non-default partitioning, and also the base name for components of the join.
- leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTablewith anotherKTableusing non-windowed left join, using theTableJoinedinstance for optional configurations includingpartitionerswhen the tables being joined use non-default partitioning, and also the base name for components of the join.
- 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
- LINEAR - Enum constant in enum class org.apache.kafka.common.metrics.stats.Percentiles.BucketSizing
- LinearBinScheme(int, double) - Constructor for class org.apache.kafka.common.metrics.stats.Histogram.LinearBinScheme
- 
Create a linear bin scheme with the specified number of bins and the maximum value to be counted in the bins.
- LINGER_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
linger.ms
- LIST - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigType
- LIST - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Type
- 
Used for list values.
- listClientMetricsResources() - Method in interface org.apache.kafka.clients.admin.Admin
- 
List the client metrics configuration resources available in the cluster with the default options.
- listClientMetricsResources(ListClientMetricsResourcesOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
List the client metrics configuration resources available in the cluster.
- listClientMetricsResources(ListClientMetricsResourcesOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- listClientMetricsResources(ListClientMetricsResourcesOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- ListClientMetricsResourcesOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.listClientMetricsResources().
- ListClientMetricsResourcesOptions() - Constructor for class org.apache.kafka.clients.admin.ListClientMetricsResourcesOptions
- ListClientMetricsResourcesResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.listClientMetricsResources()call.
- listConsumerGroupOffsets(String) - Method in interface org.apache.kafka.clients.admin.Admin
- 
List the consumer group offsets available in the cluster with the default options.
- listConsumerGroupOffsets(String, ListConsumerGroupOffsetsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
List the consumer group offsets available in the cluster.
- listConsumerGroupOffsets(Map<String, ListConsumerGroupOffsetsSpec>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
List the consumer group offsets available in the cluster for the specified groups with the default options.
- listConsumerGroupOffsets(Map<String, ListConsumerGroupOffsetsSpec>, ListConsumerGroupOffsetsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
List the consumer group offsets available in the cluster for the specified consumer groups.
- listConsumerGroupOffsets(Map<String, ListConsumerGroupOffsetsSpec>, ListConsumerGroupOffsetsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- listConsumerGroupOffsets(Map<String, ListConsumerGroupOffsetsSpec>, 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
- 
The result of theAdmin.listConsumerGroupOffsets(Map)andAdmin.listConsumerGroupOffsets(String)call.
- ListConsumerGroupOffsetsSpec - Class in org.apache.kafka.clients.admin
- 
Specification of consumer group offsets to list usingAdmin.listConsumerGroupOffsets(java.util.Map).
- ListConsumerGroupOffsetsSpec() - Constructor for class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsSpec
- listConsumerGroups() - Method in interface org.apache.kafka.clients.admin.Admin
- 
List the consumer groups available in the cluster with the default options.
- listConsumerGroups(ListConsumerGroupsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
List the consumer groups available in the cluster.
- listConsumerGroups(ListConsumerGroupsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- listConsumerGroups(ListConsumerGroupsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- ListConsumerGroupsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.listConsumerGroups().
- ListConsumerGroupsOptions() - Constructor for class org.apache.kafka.clients.admin.ListConsumerGroupsOptions
- ListConsumerGroupsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.listConsumerGroups()call.
- ListDeserializer<Inner> - Class in org.apache.kafka.common.serialization
- ListDeserializer() - Constructor for class org.apache.kafka.common.serialization.ListDeserializer
- ListDeserializer(Class<L>, Deserializer<Inner>) - Constructor for class org.apache.kafka.common.serialization.ListDeserializer
- listenerName() - Method in class org.apache.kafka.common.Endpoint
- 
Returns the listener name of this endpoint.
- 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
- listenerName() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
- 
Returns name of listener on which request was received.
- ListenerNotFoundException - Exception Class 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 class org.apache.kafka.common.errors.ListenerNotFoundException
- ListenerNotFoundException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.ListenerNotFoundException
- listGroups() - Method in interface org.apache.kafka.clients.admin.Admin
- 
List the groups available in the cluster with the default options.
- listGroups(ListGroupsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
List the groups available in the cluster.
- listGroups(ListGroupsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- listGroups(ListGroupsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- ListGroupsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.listGroups().
- ListGroupsOptions() - Constructor for class org.apache.kafka.clients.admin.ListGroupsOptions
- ListGroupsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.listGroups()call.
- 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.
- listOffsets(Map<TopicPartition, OffsetSpec>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
List offset for the specified partitions and OffsetSpec.
- listOffsets(Map<TopicPartition, OffsetSpec>, ListOffsetsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
List offset for the specified partitions.
- listOffsets(Map<TopicPartition, OffsetSpec>, ListOffsetsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- listOffsets(Map<TopicPartition, OffsetSpec>, ListOffsetsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- ListOffsetsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.listOffsets(Map).
- ListOffsetsOptions() - Constructor for class org.apache.kafka.clients.admin.ListOffsetsOptions
- ListOffsetsOptions(IsolationLevel) - Constructor for class org.apache.kafka.clients.admin.ListOffsetsOptions
- ListOffsetsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.listOffsets(Map)call.
- ListOffsetsResult(Map<TopicPartition, KafkaFuture<ListOffsetsResult.ListOffsetsResultInfo>>) - Constructor for class org.apache.kafka.clients.admin.ListOffsetsResult
- ListOffsetsResult.ListOffsetsResultInfo - Class in org.apache.kafka.clients.admin
- ListOffsetsResultInfo(long, long, Optional<Integer>) - Constructor for class org.apache.kafka.clients.admin.ListOffsetsResult.ListOffsetsResultInfo
- listPartitionReassignments() - Method in interface org.apache.kafka.clients.admin.Admin
- 
List all of the current partition reassignments This is a convenience method forAdmin.listPartitionReassignments(ListPartitionReassignmentsOptions)with default options.
- listPartitionReassignments(Optional<Set<TopicPartition>>, ListPartitionReassignmentsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- listPartitionReassignments(Optional<Set<TopicPartition>>, ListPartitionReassignmentsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- listPartitionReassignments(Optional<Set<TopicPartition>>, ListPartitionReassignmentsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- listPartitionReassignments(Set<TopicPartition>) - Method in interface org.apache.kafka.clients.admin.Admin
- 
List the current reassignments for the given partitions This is a convenience method forAdmin.listPartitionReassignments(Set, ListPartitionReassignmentsOptions)with default options.
- listPartitionReassignments(Set<TopicPartition>, ListPartitionReassignmentsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
List the current reassignments for the given partitions
- listPartitionReassignments(ListPartitionReassignmentsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
List all of the current partition reassignments
- ListPartitionReassignmentsOptions - Class in org.apache.kafka.clients.admin
- ListPartitionReassignmentsOptions() - Constructor for class org.apache.kafka.clients.admin.ListPartitionReassignmentsOptions
- ListPartitionReassignmentsResult - Class in org.apache.kafka.clients.admin
- listRemoteLogSegments(TopicIdPartition) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
- 
Returns all the remote log segment metadata of the given topicIdPartition.
- listRemoteLogSegments(TopicIdPartition, int) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
- 
Returns iterator of remote log segment metadata, sorted byRemoteLogSegmentMetadata.startOffset()in ascending order which contains the given leader epoch.
- ListSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.ListSerde
- ListSerde(Class<L>, Serde<Inner>) - Constructor for class org.apache.kafka.common.serialization.Serdes.ListSerde
- ListSerde(Class<L>, Serde<Inner>) - Static method in class org.apache.kafka.common.serialization.Serdes
- ListSerializer<Inner> - Class in org.apache.kafka.common.serialization
- ListSerializer() - Constructor for class org.apache.kafka.common.serialization.ListSerializer
- ListSerializer(Serializer<Inner>) - Constructor for class org.apache.kafka.common.serialization.ListSerializer
- listTopics() - Method in interface org.apache.kafka.clients.admin.Admin
- 
List the topics available in the cluster 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(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(ListTopicsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
List the topics available in the cluster.
- listTopics(ListTopicsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- listTopics(ListTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- ListTopicsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.listTopics().
- ListTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.ListTopicsOptions
- ListTopicsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.listTopics()call.
- listTransactions() - Method in interface org.apache.kafka.clients.admin.Admin
- 
List active transactions in the cluster.
- listTransactions(ListTransactionsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
List active transactions in the cluster.
- listTransactions(ListTransactionsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- listTransactions(ListTransactionsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- ListTransactionsOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.listTransactions().
- ListTransactionsOptions() - Constructor for class org.apache.kafka.clients.admin.ListTransactionsOptions
- ListTransactionsResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.listTransactions()call.
- LITERAL - Enum constant in enum class org.apache.kafka.common.resource.PatternType
- 
A literal resource name.
- LOCAL_LOG_RETENTION_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
- LOCAL_LOG_RETENTION_BYTES_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
- LOCAL_LOG_RETENTION_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
- LOCAL_LOG_RETENTION_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
- LockException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates that the state store directory lock could not be acquired because another thread holds the lock.
- LockException(String) - Constructor for exception class org.apache.kafka.streams.errors.LockException
- LockException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.LockException
- LockException(Throwable) - Constructor for exception class org.apache.kafka.streams.errors.LockException
- log - Static variable in interface org.apache.kafka.streams.kstream.EmitStrategy
- LOG - Static variable in interface org.apache.kafka.streams.state.RocksDBConfigSetter
- LOG_SUMMARY_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
log.summary.interval.ms
- LogAndContinueExceptionHandler - Class in org.apache.kafka.streams.errors
- 
Deserialization handler that logs a deserialization exception and then signals the processing pipeline to continue processing more records.
- LogAndContinueExceptionHandler() - Constructor for class org.apache.kafka.streams.errors.LogAndContinueExceptionHandler
- LogAndContinueProcessingExceptionHandler - Class in org.apache.kafka.streams.errors
- 
Processing exception handler that logs a processing exception and then signals the processing pipeline to continue processing more records.
- LogAndContinueProcessingExceptionHandler() - Constructor for class org.apache.kafka.streams.errors.LogAndContinueProcessingExceptionHandler
- LogAndFailExceptionHandler - Class in org.apache.kafka.streams.errors
- 
Deserialization handler that logs a deserialization exception and then signals the processing pipeline to stop processing more records and fail.
- LogAndFailExceptionHandler() - Constructor for class org.apache.kafka.streams.errors.LogAndFailExceptionHandler
- LogAndFailProcessingExceptionHandler - Class in org.apache.kafka.streams.errors
- 
Processing exception handler that logs a processing exception and then signals the processing pipeline to stop processing more records and fail.
- LogAndFailProcessingExceptionHandler() - Constructor for class org.apache.kafka.streams.errors.LogAndFailProcessingExceptionHandler
- LogAndSkipOnInvalidTimestamp - Class in org.apache.kafka.streams.processor
- 
Retrieves embedded metadata timestamps from Kafka messages.
- LogAndSkipOnInvalidTimestamp() - Constructor for class org.apache.kafka.streams.processor.LogAndSkipOnInvalidTimestamp
- logConfig() - Method in interface org.apache.kafka.streams.state.StoreBuilder
- 
Returns a Map containing any log configs that will be used when creating the changelog for theStateStore.
- LogDirDescription - Class in org.apache.kafka.clients.admin
- 
A description of a log directory on a particular broker.
- LogDirDescription(ApiException, Map<TopicPartition, ReplicaInfo>) - Constructor for class org.apache.kafka.clients.admin.LogDirDescription
- LogDirDescription(ApiException, Map<TopicPartition, ReplicaInfo>, long, long) - Constructor for class org.apache.kafka.clients.admin.LogDirDescription
- LogDirNotFoundException - Exception Class 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 class org.apache.kafka.common.errors.LogDirNotFoundException
- LogDirNotFoundException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.LogDirNotFoundException
- LogDirNotFoundException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.LogDirNotFoundException
- logEndOffset() - Method in class org.apache.kafka.clients.admin.QuorumInfo.ReplicaState
- 
Return the logEndOffset known by the leader for this replica.
- loggingEnabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
- LOGICAL_NAME - Static variable in class org.apache.kafka.connect.data.Date
- LOGICAL_NAME - Static variable in class org.apache.kafka.connect.data.Decimal
- LOGICAL_NAME - Static variable in class org.apache.kafka.connect.data.Time
- LOGICAL_NAME - Static variable in class org.apache.kafka.connect.data.Timestamp
- logIfAllowed() - Method in class org.apache.kafka.server.authorizer.Action
- 
Indicates if audit logs tracking ALLOWED access should include this action if result is ALLOWED.
- logIfDenied() - Method in class org.apache.kafka.server.authorizer.Action
- 
Indicates if audit logs tracking DENIED access should include this action if result is DENIED.
- 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.
- LogLevelConfig - Class in org.apache.kafka.common.config
- 
This class holds definitions for log level configurations related to Kafka's application logging.
- LogLevelConfig() - Constructor for class org.apache.kafka.common.config.LogLevelConfig
- 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
- logSegment() - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
- LogSegmentData - Class in org.apache.kafka.server.log.remote.storage
- 
This represents all the required data and indexes for a specific log segment that needs to be stored in the remote storage.
- LogSegmentData(Path, Path, Path, Optional<Path>, Path, ByteBuffer) - Constructor for class org.apache.kafka.server.log.remote.storage.LogSegmentData
- 
Creates a LogSegmentData instance with data and indexes.
- LogTruncationException - Exception Class in org.apache.kafka.clients.consumer
- 
In the event of an unclean leader election, the log will be truncated, previously committed data will be lost, and new data will be written over these offsets.
- LogTruncationException(String, Map<TopicPartition, Long>, Map<TopicPartition, OffsetAndMetadata>) - Constructor for exception class org.apache.kafka.clients.consumer.LogTruncationException
- LogTruncationException(Map<TopicPartition, Long>, Map<TopicPartition, OffsetAndMetadata>) - Constructor for exception class org.apache.kafka.clients.consumer.LogTruncationException
- logUnused() - Method in class org.apache.kafka.common.config.AbstractConfig
- 
Info level log for any unused configurations
- Long() - Static method in class org.apache.kafka.common.serialization.Serdes
- 
A serde for nullableLongtype.
- LONG - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigType
- LONG - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Type
- 
Used for numerical values within the Java Long range.
- LONG - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Width
- LongDecoder - Class in org.apache.kafka.tools.api
- 
The long decoder translates bytes into longs.
- LongDecoder() - Constructor for class org.apache.kafka.tools.api.LongDecoder
- 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 - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Importance
- lowerBound() - Method in class org.apache.kafka.streams.query.TimestampedRangeQuery
- 
The lower bound of the query, if specified.
- lowerBound(double) - Static method in class org.apache.kafka.common.metrics.Quota
- 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.
- lruMap(String, int) - Static method in class org.apache.kafka.streams.state.Stores
- 
Create a LRU MapKeyValueBytesStoreSupplier.
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
- main(String[]) - Static method in class org.apache.kafka.streams.StreamsConfig
- MAIN_CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Prefix used to overrideconsumerconfigs for the main consumer client from the general consumer client configs.
- mainConsumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
- 
Prefix a property withStreamsConfig.MAIN_CONSUMER_PREFIX.
- make(V, long) - Static method in class org.apache.kafka.streams.state.ValueAndTimestamp
- makeAllowNullable(V, long) - Static method in class org.apache.kafka.streams.state.ValueAndTimestamp
- 
Create a newValueAndTimestampinstance.
- Manual Offset Control - Search tag in class org.apache.kafka.clients.consumer.KafkaConsumer
- Section
- Manual Partition Assignment - Search tag in class org.apache.kafka.clients.consumer.KafkaConsumer
- Section
- map() - Method in class org.apache.kafka.common.security.auth.SaslExtensions
- 
Returns an immutable map of the extension names and their values
- map(Schema, Schema) - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- map(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Transform each record of the input stream into a new record in the output stream (both key and value type can be altered arbitrarily).
- map(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Transform each record of the input stream into a new record in the output stream (both key and value type can be altered arbitrarily).
- MAP - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
- 
A mapping from keys to values.
- mapValues(ValueMapper<? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Transform the value of each input record into a new value (with possible new type) of the output record.
- mapValues(ValueMapper<? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTableby transforming the value of each record in thisKTableinto a new value (with possibly a new type) in the newKTable, with default serializers, deserializers, and state store.
- mapValues(ValueMapper<? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTableby transforming the value of each record in thisKTableinto a new value (with possibly a new type) in the newKTable, with thekey serde,value serde, and the underlyingmaterialized state storageconfigured in theMaterializedinstance.
- mapValues(ValueMapper<? super V, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Transform the value of each input record into a new value (with possible new type) of the output record.
- mapValues(ValueMapper<? super V, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTableby transforming the value of each record in thisKTableinto a new value (with possibly a new type) in the newKTable, with default serializers, deserializers, and state store.
- mapValues(ValueMapper<? super V, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTableby transforming the value of each record in thisKTableinto a new value (with possibly a new type) in the newKTable, with thekey serde,value serde, and the underlyingmaterialized state storageconfigured in theMaterializedinstance.
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Transform the value of each input record into a new value (with possible new type) of the output record.
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTableby transforming the value of each record in thisKTableinto a new value (with possibly a new type) in the newKTable, with default serializers, deserializers, and state store.
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTableby transforming the value of each record in thisKTableinto a new value (with possibly a new type) in the newKTable, with thekey serde,value serde, and the underlyingmaterialized state storageconfigured in theMaterializedinstance.
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Transform the value of each input record into a new value (with possible new type) of the output record.
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTableby transforming the value of each record in thisKTableinto a new value (with possibly a new type) in the newKTable, with default serializers, deserializers, and state store.
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTableby transforming the value of each record in thisKTableinto a new value (with possibly a new type) in the newKTable, with thekey serde,value serde, and the underlyingmaterialized state storageconfigured in theMaterializedinstance.
- match() - Method in class org.apache.kafka.common.quota.ClientQuotaFilterComponent
- MATCH - Enum constant in enum class 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(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.ResourcePatternFilter
- Materialized<K,V, - Class in org.apache.kafka.streams.kstreamS> 
- 
Used to describe how aStateStoreshould be materialized.
- Materialized.StoreType - Enum Class in org.apache.kafka.streams.kstream
- Max - Class in org.apache.kafka.common.metrics.stats
- 
ASampledStatthat gives the max over its samples.
- Max() - Constructor for class org.apache.kafka.common.metrics.stats.Max
- MAX_BLOCK_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
max.block.ms
- MAX_COMPACTION_LAG_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
- MAX_COMPACTION_LAG_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
- 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_RACK_AWARE_ASSIGNMENT_TAG_KEY_LENGTH - Static variable in class org.apache.kafka.streams.StreamsConfig
- MAX_RACK_AWARE_ASSIGNMENT_TAG_LIST_SIZE - Static variable in class org.apache.kafka.streams.StreamsConfig
- MAX_RACK_AWARE_ASSIGNMENT_TAG_VALUE_LENGTH - Static variable in class org.apache.kafka.streams.StreamsConfig
- MAX_RECORDING_LEVEL_KEY - Static variable in enum class org.apache.kafka.common.metrics.Sensor.RecordingLevel
- MAX_REQUEST_SIZE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
max.request.size
- MAX_TASK_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
max.task.idle.ms
- MAX_TASK_IDLE_MS_DISABLED - Static variable in class org.apache.kafka.streams.StreamsConfig
- MAX_TASK_IDLE_MS_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- MAX_WARMUP_REPLICAS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
max.warmup.replicas
- maxBufferedSize - Variable in class org.apache.kafka.streams.TopologyConfig
- maxBufferedSize - Variable in class org.apache.kafka.streams.TopologyConfig.TaskConfig
- maxBytes(long) - Static method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
- 
Create a size-constrained buffer in terms of the maximum number of bytes it will use.
- maxlifeTimeMs() - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
- 
Deprecated.Since 4.0 and should not be used any longer.
- maxlifeTimeMs(long) - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
- 
Deprecated.Since 4.0 and should not be used any longer.
- maxLifetimeMs() - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
- maxLifetimeMs(long) - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
- maxRecords(long) - Static method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
- 
Create a size-constrained buffer in terms of the maximum number of keys it will store.
- maxTaskIdleMs - Variable in class org.apache.kafka.streams.TopologyConfig
- maxTaskIdleMs - Variable in class org.apache.kafka.streams.TopologyConfig.TaskConfig
- maxTimestamp() - Static method in class org.apache.kafka.clients.admin.OffsetSpec
- 
Used to retrieve the offset with the largest timestamp of a partition as message timestamps can be specified client side this may not match the log end offset returned by LatestSpec
- maxTimestamp() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
- maxTimestampMs() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- MaxTimestampSpec() - Constructor for class org.apache.kafka.clients.admin.OffsetSpec.MaxTimestampSpec
- maxVersion() - Method in class org.apache.kafka.clients.admin.SupportedVersionRange
- maxVersionLevel() - Method in class org.apache.kafka.clients.admin.FeatureUpdate
- maxVersionLevel() - Method in class org.apache.kafka.clients.admin.FinalizedVersionRange
- maxWarmupReplicas() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- 
The maximum warmup replicas as configured viaStreamsConfig.MAX_WARMUP_REPLICAS_CONFIG
- measurable() - Method in class org.apache.kafka.common.metrics.KafkaMetric
- 
Get the underlying metric provider, which should be aMeasurable
- Measurable - Interface in org.apache.kafka.common.metrics
- 
A measurable quantity that can be registered as a metric
- MeasurableStat - Interface in org.apache.kafka.common.metrics
- 
A MeasurableStat is aStatthat is alsoMeasurable(i.e.
- measure(MetricConfig, long) - Method in interface org.apache.kafka.common.metrics.Measurable
- 
Measure this quantity and return the result as a double
- measure(MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.CumulativeSum
- measure(MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.Rate
- measure(MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
- measure(MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.TokenBucket
- measure(MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.Value
- mechanism() - Method in class org.apache.kafka.clients.admin.ScramCredentialInfo
- mechanism() - Method in class org.apache.kafka.clients.admin.UserScramCredentialDeletion
- mechanismName() - Method in enum class org.apache.kafka.clients.admin.ScramMechanism
- MEDIUM - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Importance
- MEDIUM - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Width
- memberAssignment(String) - Method in interface org.apache.kafka.coordinator.group.api.assignor.GroupSpec
- 
Gets the current assignment of the member.
- MemberAssignment - Class in org.apache.kafka.clients.admin
- 
A description of the assignments of a specific group member.
- MemberAssignment - Interface in org.apache.kafka.coordinator.group.api.assignor
- 
The partition assignment for a consumer 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 member in the cluster.
- MemberDescription(String, String, String, MemberAssignment) - Constructor for class org.apache.kafka.clients.admin.MemberDescription
- 
Deprecated.
- MemberDescription(String, Optional<String>, String, String, MemberAssignment) - Constructor for class org.apache.kafka.clients.admin.MemberDescription
- 
Deprecated.
- MemberDescription(String, Optional<String>, String, String, MemberAssignment, Optional<MemberAssignment>) - Constructor for class org.apache.kafka.clients.admin.MemberDescription
- 
Deprecated.
- MemberDescription(String, Optional<String>, String, String, MemberAssignment, Optional<MemberAssignment>, Optional<Integer>, Optional<Boolean>) - Constructor for class org.apache.kafka.clients.admin.MemberDescription
- memberEpoch() - Method in class org.apache.kafka.clients.admin.MemberDescription
- 
The epoch of the group member.
- memberId() - Method in class org.apache.kafka.clients.consumer.ConsumerGroupMetadata
- MemberIdRequiredException - Exception Class in org.apache.kafka.common.errors
- MemberIdRequiredException(String) - Constructor for exception class org.apache.kafka.common.errors.MemberIdRequiredException
- MemberIdRequiredException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.MemberIdRequiredException
- memberIds() - Method in interface org.apache.kafka.coordinator.group.api.assignor.GroupSpec
- memberResult(MemberToRemove) - Method in class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupResult
- 
Returns the selected member future.
- members() - Method in class org.apache.kafka.clients.admin.ClassicGroupDescription
- 
A list of the members of the classic group.
- members() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
- 
A list of the members of the consumer group.
- members() - Method in class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupOptions
- members() - Method in class org.apache.kafka.clients.admin.ShareGroupDescription
- 
A list of the members of the share group.
- members() - Method in class org.apache.kafka.coordinator.group.api.assignor.GroupAssignment
- memberSubscription(String) - Method in interface org.apache.kafka.coordinator.group.api.assignor.GroupSpec
- 
Gets the member subscription specification for a member.
- MemberSubscription - Interface in org.apache.kafka.coordinator.group.api.assignor
- 
Interface representing the subscription metadata for a group member.
- MemberToRemove - Class in org.apache.kafka.clients.admin
- 
A struct containing information about the member to be removed.
- MemberToRemove(String) - Constructor for class org.apache.kafka.clients.admin.MemberToRemove
- merge(KStream<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Merge this stream and the given stream into one larger stream.
- merge(KStream<K, V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Merge this stream and the given stream into one larger stream.
- merge(Position) - Method in class org.apache.kafka.streams.query.Position
- 
Merges the provided Position into the current instance.
- MERGE_REPARTITION_TOPICS - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"topology.optimization"for enabling the specific optimization that merges duplicated repartition topics.
- Merger<K,V> - Interface in org.apache.kafka.streams.kstream
- 
The interface for merging aggregate values forSessionWindowswith the given key.
- MESSAGE_DOWNCONVERSION_ENABLE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
- 
Deprecated.down-conversion is not possible in Apache Kafka 4.0 and newer, hence this configuration is a no-op, and it is deprecated for removal in Apache Kafka 5.0.
- MESSAGE_DOWNCONVERSION_ENABLE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
- 
Deprecated.
- MESSAGE_TIMESTAMP_AFTER_MAX_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
- MESSAGE_TIMESTAMP_AFTER_MAX_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
- MESSAGE_TIMESTAMP_BEFORE_MAX_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
- MESSAGE_TIMESTAMP_BEFORE_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
- MessageFormatter - Interface in org.apache.kafka.common
- 
This interface allows to define Formatters that can be used to parse and format records read by a Consumer instance for display.
- metadata() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
- metadata() - Method in class org.apache.kafka.connect.mirror.Checkpoint
- METADATA_KEY - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
- 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
- METADATA_MAX_AGE_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
metadata.max.age.ms
- METADATA_MAX_IDLE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
metadata.max.idle.ms
- METADATA_RECOVERY_REBOOTSTRAP_TRIGGER_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- METADATA_RECOVERY_REBOOTSTRAP_TRIGGER_MS_DOC - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- METADATA_RECOVERY_STRATEGY_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- METADATA_RECOVERY_STRATEGY_DOC - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- METADATA_TOPIC_ID - Static variable in class org.apache.kafka.common.Uuid
- 
A UUID for the metadata topic in KRaft mode.
- metadataForAllStreamsClients() - Method in class org.apache.kafka.streams.KafkaStreams
- 
Find all currently runningKafkaStreamsinstances (potentially remotely) that use the sameapplication IDas this instance (i.e., all instances that belong to the same Kafka Streams application) and returnStreamsMetadatafor each discovered instance.
- metadataForLocalThreads() - Method in class org.apache.kafka.streams.KafkaStreams
- 
Returns runtime information about the local threads of thisKafkaStreamsinstance.
- Meter - Class in org.apache.kafka.common.metrics.stats
- 
A compound stat that includes a rate metric and a cumulative total metric.
- Meter(TimeUnit, MetricName, MetricName) - Constructor for class org.apache.kafka.common.metrics.stats.Meter
- 
Construct a Meter with provided time unit
- Meter(TimeUnit, SampledStat, MetricName, MetricName) - Constructor for class org.apache.kafka.common.metrics.stats.Meter
- 
Construct a Meter with provided time unit
- Meter(MetricName, MetricName) - Constructor for class org.apache.kafka.common.metrics.stats.Meter
- 
Construct a Meter with seconds as time unit
- Meter(SampledStat, MetricName, MetricName) - Constructor for class org.apache.kafka.common.metrics.stats.Meter
- 
Construct a Meter with seconds as time unit
- metric() - Method in exception class org.apache.kafka.common.metrics.QuotaViolationException
- metric(MetricName) - Method in class org.apache.kafka.common.metrics.Metrics
- 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
- METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
metric.reporters
- metricChange(KafkaMetric) - Method in class org.apache.kafka.common.metrics.JmxReporter
- metricChange(KafkaMetric) - Method in interface org.apache.kafka.common.metrics.MetricsReporter
- 
This is called whenever a metric is updated or added
- MetricConfig - Class in org.apache.kafka.common.metrics
- 
Configuration values for metrics
- MetricConfig() - Constructor for class org.apache.kafka.common.metrics.MetricConfig
- metricInstance(MetricNameTemplate, String...) - Method in class org.apache.kafka.common.metrics.Metrics
- metricInstance(MetricNameTemplate, Map<String, String>) - Method in class org.apache.kafka.common.metrics.Metrics
- metricName() - Method in interface org.apache.kafka.common.Metric
- 
A name for this metric
- metricName() - Method in class org.apache.kafka.common.metrics.KafkaMetric
- 
Get the metric name
- metricName(String, String) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Create a MetricName with the given name, group and default tags specified in the metric configuration.
- metricName(String, String, String) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Create a MetricName with the given name, group, description, and default tags specified in the metric configuration.
- metricName(String, String, String, String...) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Create a MetricName with the given name, group, description, and keyValue as tags, plus default tags specified in the metric configuration.
- metricName(String, String, String, Map<String, String>) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Create a MetricName with the given name, group, description and tags, plus default tags specified in the metric configuration.
- metricName(String, String, Map<String, String>) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Create a MetricName with the given name, group and tags, plus default tags specified in the metric configuration.
- MetricName - Class in org.apache.kafka.common
- 
TheMetricNameclass 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 methodMetrics.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.
- metricRemoval(KafkaMetric) - Method in class org.apache.kafka.common.metrics.JmxReporter
- metricRemoval(KafkaMetric) - Method in interface org.apache.kafka.common.metrics.MetricsReporter
- 
This is called whenever a metric is removed
- metrics() - Method in interface org.apache.kafka.clients.admin.Admin
- 
Get the metrics kept by the adminClient
- metrics() - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- 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
- 
Get the metrics kept by the consumer
- metrics() - Method in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- 
Get the metrics kept by the consumer
- metrics() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- metrics() - Method in class org.apache.kafka.clients.consumer.MockShareConsumer
- metrics() - Method in interface org.apache.kafka.clients.consumer.ShareConsumer
- metrics() - Method in class org.apache.kafka.clients.producer.KafkaProducer
- 
Get the full set of internal metrics maintained by the producer.
- metrics() - Method in class org.apache.kafka.clients.producer.MockProducer
- metrics() - Method in interface org.apache.kafka.clients.producer.Producer
- metrics() - Method in class org.apache.kafka.common.metrics.Metrics
- 
Get all the metrics currently maintained indexed by metricName
- metrics() - Method in class org.apache.kafka.streams.KafkaStreams
- 
Get read-only handle on global metrics registry, including streams client's own metrics plus its embedded producer, consumer and admin clients' metrics.
- metrics() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- metrics() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
- 
Return Metrics instance.
- metrics() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- metrics() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Return Metrics instance.
- metrics() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
- 
Returns Metrics instance.
- metrics() - Method in interface org.apache.kafka.streams.StreamsMetrics
- 
Get read-only handle on global metrics registry.
- metrics() - Method in class org.apache.kafka.streams.TopologyTestDriver
- 
Get read-only handle on global metrics registry.
- Metrics - Class in org.apache.kafka.common.metrics
- 
A registry of sensors and metrics.
- Metrics() - Constructor for class org.apache.kafka.common.metrics.Metrics
- 
Create a metrics repository with no metric reporters and default configuration.
- Metrics(MetricConfig) - Constructor for class org.apache.kafka.common.metrics.Metrics
- 
Create a metrics repository with no reporters and the given default config.
- Metrics(MetricConfig, List<MetricsReporter>, Time) - Constructor for class org.apache.kafka.common.metrics.Metrics
- 
Create a metrics repository with a default config and the given metric reporters.
- Metrics(MetricConfig, List<MetricsReporter>, Time, boolean) - Constructor for class org.apache.kafka.common.metrics.Metrics
- 
Create a metrics repository with a default config, given metric reporters and the ability to expire eligible sensors
- Metrics(MetricConfig, List<MetricsReporter>, Time, boolean, MetricsContext) - Constructor for class org.apache.kafka.common.metrics.Metrics
- 
Create a metrics repository with a default config, given metric reporters, the ability to expire eligible sensors and MetricContext
- Metrics(MetricConfig, List<MetricsReporter>, Time, MetricsContext) - Constructor for class org.apache.kafka.common.metrics.Metrics
- 
Create a metrics repository with a default config, metric reporters and metric context Expiration of Sensors is disabled.
- Metrics(MetricConfig, Time) - Constructor for class org.apache.kafka.common.metrics.Metrics
- 
Create a metrics repository with no metric reporters and the given default configuration.
- Metrics(Time) - Constructor for class org.apache.kafka.common.metrics.Metrics
- 
Create a metrics repository with no metric reporters and default configuration.
- METRICS_CONFIG_PREFIX - Static variable in class org.apache.kafka.common.metrics.JmxReporter
- METRICS_LATEST - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"built.in.metrics.version"for the latest built-in metrics version.
- 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_NUM_SAMPLES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
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_RECORDING_LEVEL_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
metrics.record.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
- METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
metrics.sample.window.ms
- MetricsContext - Interface in org.apache.kafka.common.metrics
- 
MetricsContext encapsulates additional contextLabels about metrics exposed via aMetricsReporter
- MetricsReporter - Interface in org.apache.kafka.common.metrics
- 
A plugin interface to allow things to listen as new metrics are created so they can be reported.
- metricsScope() - Method in interface org.apache.kafka.streams.state.StoreSupplier
- 
Return a String that is used as the scope for metrics recorded by Metered stores.
- metricValue() - Method in interface org.apache.kafka.common.Metric
- 
The value of the metric, which may be measurable or a non-measurable gauge
- metricValue() - Method in class org.apache.kafka.common.metrics.KafkaMetric
- 
Take the metric and return the value, which could be aMeasurableor aGauge
- MetricValueProvider<T> - Interface in org.apache.kafka.common.metrics
- 
Super-interface forMeasurableorGaugethat provides metric values.
- MIGRATED - Enum constant in enum class org.apache.kafka.streams.processor.StandbyUpdateListener.SuspendReason
- Min - Class in org.apache.kafka.common.metrics.stats
- 
ASampledStatthat gives the min over its samples.
- Min() - Constructor for class org.apache.kafka.common.metrics.stats.Min
- 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
- minVersion() - Method in class org.apache.kafka.clients.admin.SupportedVersionRange
- minVersionLevel() - Method in class org.apache.kafka.clients.admin.FinalizedVersionRange
- MirrorClient - Class in org.apache.kafka.connect.mirror
- 
Client to interact with MirrorMaker internal topics (checkpoints, heartbeats) on a given cluster.
- MirrorClient(Map<String, Object>) - Constructor for class org.apache.kafka.connect.mirror.MirrorClient
- MirrorClient(MirrorClientConfig) - Constructor for class org.apache.kafka.connect.mirror.MirrorClient
- MirrorClientConfig - Class in org.apache.kafka.connect.mirror
- 
Configuration required forMirrorClientto talk to a given target cluster.
- MismatchedEndpointTypeException - Exception Class in org.apache.kafka.common.errors
- MismatchedEndpointTypeException(String) - Constructor for exception class org.apache.kafka.common.errors.MismatchedEndpointTypeException
- MISSING_PROCESS_ID - Enum constant in enum class org.apache.kafka.streams.processor.assignment.TaskAssignor.AssignmentError
- MissingSourceTopicException - Exception Class in org.apache.kafka.streams.errors
- MissingSourceTopicException(String) - Constructor for exception class org.apache.kafka.streams.errors.MissingSourceTopicException
- MOCK_MODE_KEY - Static variable in class org.apache.kafka.connect.tools.MockConnector
- MockConnector - Class in org.apache.kafka.connect.tools
- 
This connector provides support for mocking certain connector behaviors.
- MockConnector() - Constructor for class org.apache.kafka.connect.tools.MockConnector
- MockConsumer<K,V> - Class in org.apache.kafka.clients.consumer
- 
A mock of theConsumerinterface you can use for testing code that uses Kafka.
- MockConsumer(String) - Constructor for class org.apache.kafka.clients.consumer.MockConsumer
- 
A mock consumer is instantiated by providing ConsumerConfig.AUTO_OFFSET_RESET_CONFIG value as the input.
- MockConsumer(OffsetResetStrategy) - Constructor for class org.apache.kafka.clients.consumer.MockConsumer
- 
Deprecated.Since 4.0. UseMockConsumer(String)instead.
- MockProcessorContext<KForward,VForward> - Class in org.apache.kafka.streams.processor.api
- 
MockProcessorContextis a mock ofProcessorContextfor users to test theirProcessorimplementations.
- MockProcessorContext - Class in org.apache.kafka.streams.processor
- 
Deprecated.Since 4.0. UseMockProcessorContextinstead.
- MockProcessorContext() - Constructor for class org.apache.kafka.streams.processor.api.MockProcessorContext
- MockProcessorContext() - Constructor for class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- MockProcessorContext(Properties) - Constructor for class org.apache.kafka.streams.processor.api.MockProcessorContext
- MockProcessorContext(Properties) - Constructor for class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- MockProcessorContext(Properties, TaskId, File) - Constructor for class org.apache.kafka.streams.processor.api.MockProcessorContext
- 
Create aMockProcessorContextwith a specified taskId and null stateDir.
- MockProcessorContext(Properties, TaskId, File) - Constructor for class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.Create aMockProcessorContextwith a specified taskId and null stateDir.
- MockProcessorContext.CapturedForward<K,V> - Class in org.apache.kafka.streams.processor.api
- MockProcessorContext.CapturedForward - Class in org.apache.kafka.streams.processor
- 
Deprecated.
- MockProcessorContext.CapturedPunctuator - Class in org.apache.kafka.streams.processor.api
- 
MockProcessorContext.CapturedPunctuatorholds captured punctuators, along with their scheduling information.
- MockProcessorContext.CapturedPunctuator - Class in org.apache.kafka.streams.processor
- 
Deprecated.MockProcessorContext.CapturedPunctuatorholds captured punctuators, along with their scheduling information.
- MockProducer<K,V> - Class in org.apache.kafka.clients.producer
- 
A mock of the producer interface you can use for testing code that uses Kafka.
- 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(Cluster, boolean, Partitioner, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.MockProducer
- 
Create a mock producer
- MockShareConsumer<K,V> - Class in org.apache.kafka.clients.consumer
- 
A mock of theShareConsumerinterface you can use for testing code that uses Kafka.
- MockShareConsumer() - Constructor for class org.apache.kafka.clients.consumer.MockShareConsumer
- MockSinkConnector - Class in org.apache.kafka.connect.tools
- 
Mock sink implementation which delegates toMockConnector.
- MockSinkConnector() - Constructor for class org.apache.kafka.connect.tools.MockSinkConnector
- MockSinkTask - Class in org.apache.kafka.connect.tools
- 
Task implementation forMockSinkConnector.
- MockSinkTask() - Constructor for class org.apache.kafka.connect.tools.MockSinkTask
- MockSourceConnector - Class in org.apache.kafka.connect.tools
- 
Mock source implementation which delegates toMockConnector.
- MockSourceConnector() - Constructor for class org.apache.kafka.connect.tools.MockSourceConnector
- MockSourceTask - Class in org.apache.kafka.connect.tools
- 
Task implementation forMockSourceConnector.
- MockSourceTask() - Constructor for class org.apache.kafka.connect.tools.MockSourceTask
- MULTIPLE_SCHEMA_CONFIG - Static variable in class org.apache.kafka.connect.tools.SchemaSourceTask
- Multithreaded Processing - Search tag in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- Section
- Multi-threaded Processing - Search tag in class org.apache.kafka.clients.consumer.KafkaConsumer
- Section
- MultiVersionedKeyQuery<K,V> - Class in org.apache.kafka.streams.query
- 
Interactive query for retrieving a set of records with the same specified key and different timestamps within the specified time range.
N
- name - Variable in enum class org.apache.kafka.clients.consumer.GroupProtocol
- 
String representation of the group protocol.
- name - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
- name - Variable in enum class org.apache.kafka.common.metrics.Sensor.RecordingLevel
- 
an english description of the api--this is for debugging and can change
- name - Variable in enum class org.apache.kafka.common.security.auth.SecurityProtocol
- 
Name of the security protocol.
- name - Variable in enum class org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
- 
An english description for the used option.
- name - Variable in enum class org.apache.kafka.streams.errors.ProcessingExceptionHandler.ProcessingHandlerResponse
- 
An english description for the used option.
- name - Variable in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
- 
An english description for the used option.
- name - Variable in enum class org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
- 
An english description for the used option.
- name() - Method in class org.apache.kafka.clients.admin.ClientMetricsResourceListing
- 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.RaftVoterEndpoint
- 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.admin.UserScramCredentialsDescription
- name() - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
- 
Unique name for this assignor (e.g.
- name() - Method in class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
- 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.metrics.CompoundStat.NamedMeasurable
- name() - Method in class org.apache.kafka.common.metrics.Sensor
- 
The name this sensor is registered with.
- name() - Method in class org.apache.kafka.common.metrics.stats.Frequency
- 
Get the name of this metric.
- name() - Method in class org.apache.kafka.common.metrics.stats.Percentile
- name() - Method in class org.apache.kafka.common.resource.Resource
- 
Return the resource name.
- name() - Method in class org.apache.kafka.common.resource.ResourcePattern
- name() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
- name() - Method in class org.apache.kafka.connect.data.ConnectSchema
- name() - Method in class org.apache.kafka.connect.data.Field
- 
Get the name of this field.
- name() - Method in interface org.apache.kafka.connect.data.Schema
- name() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- name() - Method in class org.apache.kafka.connect.health.ConnectorHealth
- 
Provides the name of the connector.
- name() - Method in interface org.apache.kafka.coordinator.group.api.assignor.PartitionAssignor
- 
Unique name for this assignor.
- name() - Method in interface org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntity
- 
Returns the name of this entity.
- name() - Method in interface org.apache.kafka.streams.processor.StateStore
- 
The name of this store.
- name() - Method in class org.apache.kafka.streams.state.DslKeyValueParams
- name() - Method in class org.apache.kafka.streams.state.DslSessionParams
- name() - Method in class org.apache.kafka.streams.state.DslWindowParams
- name() - Method in interface org.apache.kafka.streams.state.StoreBuilder
- 
Return the name of this state store builder.
- name() - Method in interface org.apache.kafka.streams.state.StoreSupplier
- 
Return the name of this state store supplier.
- name() - Method in interface org.apache.kafka.streams.TopologyDescription.Node
- 
The name of the node.
- name(String) - Method in class org.apache.kafka.connect.data.SchemaBuilder
- 
Set the name of this schema.
- NAME_CONFIG - Static variable in class org.apache.kafka.connect.tools.SchemaSourceTask
- NAME_CONFIG - Static variable in class org.apache.kafka.connect.tools.VerifiableSinkTask
- NAME_CONFIG - Static variable in class org.apache.kafka.connect.tools.VerifiableSourceTask
- Named - Class in org.apache.kafka.streams.kstream
- NAMED_TOPOLOGY_DELIMITER - Static variable in class org.apache.kafka.streams.processor.TaskId
- NamedMeasurable(MetricName, Measurable) - Constructor for class org.apache.kafka.common.metrics.CompoundStat.NamedMeasurable
- 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 class org.apache.kafka.common.security.auth.SecurityProtocol
- NAMESPACE - Static variable in interface org.apache.kafka.common.metrics.MetricsContext
- 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 Class in org.apache.kafka.common.errors
- 
A misc.
- NetworkException() - Constructor for exception class org.apache.kafka.common.errors.NetworkException
- NetworkException(String) - Constructor for exception class org.apache.kafka.common.errors.NetworkException
- NetworkException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.NetworkException
- NetworkException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.NetworkException
- newConfigDef() - Static method in class org.apache.kafka.connect.storage.ConverterConfig
- 
Create a newConfigDefinstance containing the configurations defined by ConverterConfig.
- NewLeaderElectedException - Exception Class in org.apache.kafka.common.errors
- NewLeaderElectedException(String) - Constructor for exception class org.apache.kafka.common.errors.NewLeaderElectedException
- NewPartitionReassignment - Class in org.apache.kafka.clients.admin
- 
A new partition reassignment, which can be applied viaAdmin.alterPartitionReassignments(Map, AlterPartitionReassignmentsOptions).
- NewPartitionReassignment(List<Integer>) - Constructor for class org.apache.kafka.clients.admin.NewPartitionReassignment
- NewPartitions - Class in org.apache.kafka.clients.admin
- 
Describes new partitions for a particular topic in a call toAdmin.createPartitions(Map).
- newRecord(String, Integer, Schema, Object, Schema, Object, Long) - Method in class org.apache.kafka.connect.connector.ConnectRecord
- 
Create a new record of the same type as itself, with the specified parameter values.
- newRecord(String, Integer, Schema, Object, Schema, Object, Long) - Method in class org.apache.kafka.connect.sink.SinkRecord
- newRecord(String, Integer, Schema, Object, Schema, Object, Long) - Method in class org.apache.kafka.connect.source.SourceRecord
- newRecord(String, Integer, Schema, Object, Schema, Object, Long, Iterable<Header>) - Method in class org.apache.kafka.connect.connector.ConnectRecord
- 
Create a new record of the same type as itself, with the specified parameter values.
- newRecord(String, Integer, Schema, Object, Schema, Object, Long, Iterable<Header>) - Method in class org.apache.kafka.connect.sink.SinkRecord
- newRecord(String, Integer, Schema, Object, Schema, Object, Long, Iterable<Header>) - Method in class org.apache.kafka.connect.source.SourceRecord
- NewTopic - Class in org.apache.kafka.clients.admin
- 
A new topic to be created viaAdmin.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.
- NewTopic(String, Optional<Integer>, Optional<Short>) - Constructor for class org.apache.kafka.clients.admin.NewTopic
- 
A new topic that optionally defaultsnumPartitionsandreplicationFactorto the broker configurations fornum.partitionsanddefault.replication.factorrespectively.
- nextOffsets() - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
- 
Get the next offsets and metadata corresponding to all topic partitions for which the position have been advanced in this poll call
- nextSegmentWithTxnIndex(TopicIdPartition, int, long) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
- 
Returns the next segment metadata that contains the aborted transaction entries for the given topic partition, epoch and offset.
- 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_OPTIMIZATION - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"topology.optimization"for disabling topology optimization
- 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
- Node(int, String, int, String, boolean) - 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 the node is not online or does not exist)
- noDefaultBranch() - Method in interface org.apache.kafka.streams.kstream.BranchedKStream
- 
Finalize the construction of branches without forming a default branch.
- nodeId() - Method in class org.apache.kafka.clients.admin.QuorumInfo.Node
- nodeIfOnline(TopicPartition, int) - Method in class org.apache.kafka.common.Cluster
- 
Get the node by node id if the replica for the given partition is online
- 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.clients.admin.QuorumInfo
- nodes() - Method in class org.apache.kafka.common.Cluster
- nodes() - Method in interface org.apache.kafka.streams.TopologyDescription.Subtopology
- 
All nodes of this sub-topology.
- NON_RECONFIGURABLE_CONFIGS - Static variable in class org.apache.kafka.common.config.SslConfigs
- none() - Static method in class org.apache.kafka.streams.AutoOffsetReset
- 
Creates anAutoOffsetResetinstance representing "none".
- NONE - Enum constant in enum class org.apache.kafka.clients.consumer.OffsetResetStrategy
- 
Deprecated.
- NONE - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Width
- NONE - Enum constant in enum class org.apache.kafka.common.config.SslClientAuth
- NONE - Enum constant in enum class org.apache.kafka.streams.processor.assignment.TaskAssignor.AssignmentError
- 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
- nonInternalValues() - Method in class org.apache.kafka.common.config.AbstractConfig
- NonNullValidator() - Constructor for class org.apache.kafka.common.config.ConfigDef.NonNullValidator
- noNode() - Static method in class org.apache.kafka.common.Node
- NoOffsetForPartitionException - Exception Class 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 class org.apache.kafka.clients.consumer.NoOffsetForPartitionException
- NoOffsetForPartitionException(TopicPartition) - Constructor for exception class org.apache.kafka.clients.consumer.NoOffsetForPartitionException
- NoReassignmentInProgressException - Exception Class in org.apache.kafka.common.errors
- 
Thrown if a reassignment cannot be cancelled because none is in progress.
- NoReassignmentInProgressException(String) - Constructor for exception class org.apache.kafka.common.errors.NoReassignmentInProgressException
- NoReassignmentInProgressException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.NoReassignmentInProgressException
- NOT_ACTIVE - Enum constant in enum class org.apache.kafka.streams.query.FailureReason
- 
The query required to execute on an active task (viaStateQueryRequest.requireActive()), but while executing the query, the task was either a Standby task, or it was an Active task not in the RUNNING state.
- NOT_AVAILABLE - Static variable in class org.apache.kafka.streams.KeyQueryMetadata
- 
Sentinel to indicate that the KeyQueryMetadata is currently unavailable.
- NOT_PRESENT - Enum constant in enum class org.apache.kafka.streams.query.FailureReason
- 
Failure indicating that the requested store partition is not present on the local KafkaStreams instance.
- NOT_RUNNING - Enum constant in enum class org.apache.kafka.streams.KafkaStreams.State
- NOT_UP_TO_BOUND - Enum constant in enum class org.apache.kafka.streams.query.FailureReason
- 
Failure indicating that the store partition is not (yet) up to the desired bound.
- NotControllerException - Exception Class in org.apache.kafka.common.errors
- NotControllerException(String) - Constructor for exception class org.apache.kafka.common.errors.NotControllerException
- NotControllerException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.NotControllerException
- NotCoordinatorException - Exception Class 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 class org.apache.kafka.common.errors.NotCoordinatorException
- NotCoordinatorException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.NotCoordinatorException
- NotEnoughReplicasAfterAppendException - Exception Class 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 class org.apache.kafka.common.errors.NotEnoughReplicasAfterAppendException
- NotEnoughReplicasException - Exception Class in org.apache.kafka.common.errors
- 
Number of insync replicas for the partition is lower than min.insync.replicas
- NotEnoughReplicasException() - Constructor for exception class org.apache.kafka.common.errors.NotEnoughReplicasException
- NotEnoughReplicasException(String) - Constructor for exception class org.apache.kafka.common.errors.NotEnoughReplicasException
- NotEnoughReplicasException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.NotEnoughReplicasException
- NotEnoughReplicasException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.NotEnoughReplicasException
- NotFoundException - Exception Class in org.apache.kafka.connect.errors
- 
Indicates that an operation attempted to modify or delete a connector or task that is not present on the worker.
- NotFoundException(String) - Constructor for exception class org.apache.kafka.connect.errors.NotFoundException
- NotFoundException(String, Throwable) - Constructor for exception class org.apache.kafka.connect.errors.NotFoundException
- NotFoundException(Throwable) - Constructor for exception class org.apache.kafka.connect.errors.NotFoundException
- NotLeaderOrFollowerException - Exception Class in org.apache.kafka.common.errors
- 
Broker returns this error if a request could not be processed because the broker is not the leader or follower for a topic partition.
- NotLeaderOrFollowerException() - Constructor for exception class org.apache.kafka.common.errors.NotLeaderOrFollowerException
- NotLeaderOrFollowerException(String) - Constructor for exception class org.apache.kafka.common.errors.NotLeaderOrFollowerException
- NotLeaderOrFollowerException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.NotLeaderOrFollowerException
- NotLeaderOrFollowerException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.NotLeaderOrFollowerException
- notUpToBound(Position, PositionBound, Integer) - Static method in interface org.apache.kafka.streams.query.QueryResult
- 
Static factory method to create a failed query result object to indicate that the store has not yet caught up to the requested position bound.
- NULL - Static variable in class org.apache.kafka.connect.data.SchemaAndValue
- NULL_SIZE - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecord
- NUM_MSGS_CONFIG - Static variable in class org.apache.kafka.connect.tools.SchemaSourceTask
- NUM_STANDBY_REPLICAS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
num.standby.replicas
- NUM_STREAM_THREADS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
num.stream.threads
- numberOfPartitions(int) - Static method in class org.apache.kafka.streams.kstream.Repartitioned
- 
Create aRepartitionedinstance with provided number of partitions for repartition topic.
- numPartitions() - Method in class org.apache.kafka.clients.admin.CreateTopicsResult.TopicMetadataAndConfig
- 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.
- numPartitions(String) - Method in class org.apache.kafka.clients.admin.CreateTopicsResult
- 
Returns a future that provides number of partitions in the topic when the request completes.
- numPartitions(Uuid) - Method in interface org.apache.kafka.coordinator.group.api.assignor.SubscribedTopicDescriber
- 
The number of partitions for the given topic Id.
- numProcessingThreads() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- 
Returns the number of processing threads available to work on tasks for this KafkaStreams client, which represents its overall capacity for work relative to other KafkaStreams clients.
- numStandbyReplicas() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- 
The number of standby replicas as configured viaStreamsConfig.NUM_STANDBY_REPLICAS_CONFIG
O
- 1. One Consumer Per Thread - Search tag in class org.apache.kafka.clients.consumer.KafkaConsumer
- Section
- 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
- 
ACallbackfor use by theSaslServerimplementation when it needs to validate the SASL extensions for the OAUTHBEARER mechanism Callback handlers should use theOAuthBearerExtensionsValidatorCallback.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
- OAuthBearerLoginCallbackHandler - Class in org.apache.kafka.common.security.oauthbearer
- 
OAuthBearerLoginCallbackHandleris anAuthenticateCallbackHandlerthat acceptsOAuthBearerTokenCallbackandSaslExtensionsCallbackcallbacks to perform the steps to request a JWT from an OAuth/OIDC provider using theclientcredentials.
- OAuthBearerLoginCallbackHandler() - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- OAuthBearerLoginModule - Class in org.apache.kafka.common.security.oauthbearer
- 
TheLoginModulefor the SASL/OAUTHBEARER mechanism.
- OAuthBearerLoginModule() - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
- OAuthBearerToken - Interface in org.apache.kafka.common.security.oauthbearer
- 
Theb64tokenvalue 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
- 
ACallbackfor use by theSaslClientandLoginimplementations 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
- 
ACallbackfor use by theSaslServerimplementation 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
- OAuthBearerValidatorCallbackHandler - Class in org.apache.kafka.common.security.oauthbearer
- 
OAuthBearerValidatorCallbackHandleris anAuthenticateCallbackHandlerthat acceptsOAuthBearerValidatorCallbackandOAuthBearerExtensionsValidatorCallbackcallbacks to implement OAuth/OIDC validation.
- OAuthBearerValidatorCallbackHandler() - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallbackHandler
- observers() - Method in class org.apache.kafka.clients.admin.QuorumInfo
- of() - Static method in class org.apache.kafka.streams.kstream.UnlimitedWindows
- 
Return an unlimited window starting at timestamp zero.
- of(String) - Static method in enum class org.apache.kafka.clients.consumer.GroupProtocol
- 
Case-insensitive group protocol lookup by string name.
- of(Duration) - Static method in class org.apache.kafka.streams.kstream.JoinWindows
- 
Deprecated.Since 3.0. UseJoinWindows.ofTimeDifferenceWithNoGrace(Duration)} instead.
- of(ConfigDef.Validator...) - Static method in class org.apache.kafka.common.config.ConfigDef.CompositeValidator
- of(ApplicationState) - Static method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils.RackAwareOptimizationParams
- 
Return a new config object with no overrides and the tasksToOptimize initialized to the set of all tasks in the given ApplicationState
- of(ProcessId, Set<KafkaStreamsAssignment.AssignedTask>) - Static method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment
- 
Construct an instance of KafkaStreamsAssignment with this processId and the given set of assigned tasks.
- of(StreamsConfig) - Static method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- ofDefaultEntity(String) - Static method in class org.apache.kafka.common.quota.ClientQuotaFilterComponent
- 
Constructs and returns a filter component that matches the built-in default entity name for the entity type.
- ofEntity(String, String) - Static method in class org.apache.kafka.common.quota.ClientQuotaFilterComponent
- 
Constructs and returns a filter component that exactly matches the provided entity name for the entity type.
- ofEntityType(String) - Static method in class org.apache.kafka.common.quota.ClientQuotaFilterComponent
- 
Constructs and returns a filter component that matches any specified name for the entity type.
- 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.admin.ListOffsetsResult.ListOffsetsResultInfo
- 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.
- offset() - Method in exception class org.apache.kafka.common.errors.RecordDeserializationException
- offset() - Method in interface org.apache.kafka.streams.errors.ErrorHandlerContext
- 
Return the offset of the current input record; could be-1if it is not available.
- offset() - Method in interface org.apache.kafka.streams.processor.api.RecordMetadata
- 
Return the offset of the current input record; could be-1if it is not available.
- offset() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- offset() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Return the offset of the current input record; could be-1if it is not available.
- offset() - Method in interface org.apache.kafka.streams.processor.RecordContext
- 
Return the offset of the current input record; could be-1if it is not available.
- offset(Map<String, T>) - Method in interface org.apache.kafka.connect.storage.OffsetStorageReader
- 
Get the offset for the specified partition.
- offset(Map<TopicPartition, Long>) - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
- 
Reset the consumer offsets for the given topic partitions.
- offset(TopicPartition, long) - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
- 
Reset the consumer offsets for the given topic partition.
- OFFSET - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemoteStorageManager.IndexType
- 
Represents offset index.
- offsetAndMetadata() - Method in class org.apache.kafka.connect.mirror.Checkpoint
- 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 throughKafkaConsumer.
- OffsetAndMetadata(long, String) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndMetadata
- 
Construct a new OffsetAndMetadata object for committing throughKafkaConsumer.
- OffsetAndMetadata(long, Optional<Integer>, String) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndMetadata
- 
Construct a new OffsetAndMetadata object for committing throughKafkaConsumer.
- 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.
- offsetIndex() - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
- offsetLag() - Method in class org.apache.kafka.clients.admin.ReplicaInfo
- 
The lag of the log's LEO with respect to the partition's high watermark (if it is the current log for the partition) or the current replica's LEO (if it is the future log for the partition).
- offsetLag() - Method in class org.apache.kafka.streams.LagInfo
- 
Get the measured lag between current and end offset positions, for this store partition replica
- OffsetMetadataTooLarge - Exception Class 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 class org.apache.kafka.common.errors.OffsetMetadataTooLarge
- OffsetMetadataTooLarge(String) - Constructor for exception class org.apache.kafka.common.errors.OffsetMetadataTooLarge
- OffsetMetadataTooLarge(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.OffsetMetadataTooLarge
- OffsetMetadataTooLarge(Throwable) - Constructor for exception class org.apache.kafka.common.errors.OffsetMetadataTooLarge
- OffsetMovedToTieredStorageException - Exception Class in org.apache.kafka.common.errors
- OffsetMovedToTieredStorageException(String) - Constructor for exception class org.apache.kafka.common.errors.OffsetMovedToTieredStorageException
- OffsetMovedToTieredStorageException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.OffsetMovedToTieredStorageException
- OffsetNotAvailableException - Exception Class in org.apache.kafka.common.errors
- 
Indicates that the leader is not able to guarantee monotonically increasing offsets due to the high watermark lagging behind the epoch start offset after a recent leader election
- OffsetNotAvailableException(String) - Constructor for exception class org.apache.kafka.common.errors.OffsetNotAvailableException
- OffsetOutOfRangeException - Exception Class 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 Class 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 class org.apache.kafka.common.errors.OffsetOutOfRangeException
- OffsetOutOfRangeException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.OffsetOutOfRangeException
- OffsetOutOfRangeException(String, Map<TopicPartition, Long>) - Constructor for exception class org.apache.kafka.clients.consumer.OffsetOutOfRangeException
- OffsetOutOfRangeException(Map<TopicPartition, Long>) - Constructor for exception class org.apache.kafka.clients.consumer.OffsetOutOfRangeException
- offsetOutOfRangePartitions() - Method in exception class org.apache.kafka.clients.consumer.OffsetOutOfRangeException
- 
Get a map of the topic partitions and the respective out-of-range fetch offsets.
- OffsetResetStrategy - Enum Class in org.apache.kafka.clients.consumer
- 
Deprecated.Since 4.0. UseAutoOffsetResetStrategyinstead.
- offsets(Collection<Map<String, T>>) - Method in interface org.apache.kafka.connect.storage.OffsetStorageReader
- 
Get a set of offsets for the specified partition identifiers.
- Offsets and Consumer Position - Search tag in class org.apache.kafka.clients.consumer.KafkaConsumer
- Section
- 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
- OffsetSpec - Class in org.apache.kafka.clients.admin
- 
This class allows to specify the desired offsets when usingKafkaAdminClient.listOffsets(Map, ListOffsetsOptions)
- OffsetSpec() - Constructor for class org.apache.kafka.clients.admin.OffsetSpec
- OffsetSpec.EarliestLocalSpec - Class in org.apache.kafka.clients.admin
- OffsetSpec.EarliestSpec - Class in org.apache.kafka.clients.admin
- OffsetSpec.LatestSpec - Class in org.apache.kafka.clients.admin
- OffsetSpec.LatestTieredSpec - Class in org.apache.kafka.clients.admin
- OffsetSpec.MaxTimestampSpec - Class in org.apache.kafka.clients.admin
- OffsetSpec.TimestampSpec - Class in org.apache.kafka.clients.admin
- offsetStorageReader() - Method in interface org.apache.kafka.connect.source.SourceConnectorContext
- 
Returns theOffsetStorageReaderfor this SourceConnectorContext.
- offsetStorageReader() - Method in interface org.apache.kafka.connect.source.SourceTaskContext
- 
Get the OffsetStorageReader for this SourceTask.
- OffsetStorageReader - Interface in org.apache.kafka.connect.storage
- 
OffsetStorageReader provides access to the offset storage used by sources.
- offsetSyncsTopic(String) - Method in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
- offsetSyncsTopic(String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
- 
Returns the name of the offset-syncs topic for given cluster alias.
- ofInactivityGapAndGrace(Duration, Duration) - Static method in class org.apache.kafka.streams.kstream.SessionWindows
- 
Creates a new window specification with the specified inactivity gap.
- ofInactivityGapWithNoGrace(Duration) - Static method in class org.apache.kafka.streams.kstream.SessionWindows
- 
Creates a new window specification with the specified inactivity gap.
- ofSizeAndGrace(Duration, Duration) - Static method in class org.apache.kafka.streams.kstream.TimeWindows
- 
Return a window definition with the given window size, and with the advance interval being equal to the window size.
- ofSizeWithNoGrace(Duration) - Static method in class org.apache.kafka.streams.kstream.TimeWindows
- 
Return a window definition with the given window size, and with the advance interval being equal to the window size.
- ofTimeDifferenceAndGrace(Duration, Duration) - Static method in class org.apache.kafka.streams.kstream.JoinWindows
- 
Specifies that records of the same key are joinable if their timestamps are withintimeDifference, i.e., the timestamp of a record from the secondary stream is maxtimeDifferencebefore or after the timestamp of the record from the primary stream.
- ofTimeDifferenceAndGrace(Duration, Duration) - Static method in class org.apache.kafka.streams.kstream.SlidingWindows
- 
Return a window definition with the window size based on the given maximum time difference (inclusive) between records in the same window and given window grace period.
- ofTimeDifferenceWithNoGrace(Duration) - Static method in class org.apache.kafka.streams.kstream.JoinWindows
- 
Specifies that records of the same key are joinable if their timestamps are withintimeDifference, i.e., the timestamp of a record from the secondary stream is maxtimeDifferencebefore or after the timestamp of the record from the primary stream.
- ofTimeDifferenceWithNoGrace(Duration) - Static method in class org.apache.kafka.streams.kstream.SlidingWindows
- 
Return a window definition with the window size based on the given maximum time difference (inclusive) between records in the same window and given window grace period.
- ofTopicIds(Collection<Uuid>) - Static method in class org.apache.kafka.common.TopicCollection
- ofTopicNames(Collection<String>) - Static method in class org.apache.kafka.common.TopicCollection
- oldest(long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
- ON_WINDOW_CLOSE - Enum constant in enum class org.apache.kafka.streams.kstream.EmitStrategy.StrategyType
- ON_WINDOW_UPDATE - Enum constant in enum class org.apache.kafka.streams.kstream.EmitStrategy.StrategyType
- 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(ConsumerPartitionAssignor.Assignment, ConsumerGroupMetadata) - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
- 
Callback which is invoked when a group member receives its assignment from the leader.
- onAssignment(ConsumerPartitionAssignor.Assignment, ConsumerGroupMetadata) - Method in class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
- onAssignment(ConsumerPartitionAssignor.Assignment, ConsumerGroupMetadata) - Method in class org.apache.kafka.clients.consumer.StickyAssignor
- onAssignmentComputed(ConsumerPartitionAssignor.GroupAssignment, ConsumerPartitionAssignor.GroupSubscription, TaskAssignor.AssignmentError) - Method in interface org.apache.kafka.streams.processor.assignment.TaskAssignor
- 
This callback can be used to observe the final assignment returned to the brokers and check for any errors that were detected while processing the returned assignment.
- onBatchLoaded(TopicPartition, String, TaskId, long, long, long) - Method in interface org.apache.kafka.streams.processor.StandbyUpdateListener
- 
Method called after loading a batch of records.
- onBatchRestored(TopicPartition, String, long, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
- 
Method called after restoring a batch of records.
- onChange(String, ConfigData) - Method in interface org.apache.kafka.common.config.ConfigChangeCallback
- 
Performs an action when configuration data changes.
- onChange(KafkaStreams.State, KafkaStreams.State) - Method in interface org.apache.kafka.streams.KafkaStreams.StateListener
- 
Called when state changes.
- onCommit() - Method in interface org.apache.kafka.streams.processor.CommitCallback
- onCommit(Map<TopicPartition, OffsetAndMetadata>) - Method in interface org.apache.kafka.clients.consumer.ConsumerInterceptor
- 
This is called when offsets get committed.
- onComplete(Map<TopicIdPartition, Set<Long>>, Exception) - Method in interface org.apache.kafka.clients.consumer.AcknowledgementCommitCallback
- 
A callback method the user can implement to provide asynchronous handling of acknowledgement completion.
- 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 byKafkaConsumer.poll(java.time.Duration)
- ONE_UUID - Static variable in class org.apache.kafka.common.Uuid
- 
A reserved UUID.
- ONGOING - Enum constant in enum class org.apache.kafka.clients.admin.TransactionState
- onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.FailOnInvalidTimestamp
- 
Raises an exception on every call.
- onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.LogAndSkipOnInvalidTimestamp
- 
Writes a log WARN message when the extracted timestamp is invalid (negative) but returns the invalid timestamp as-is, which ultimately causes the record to be skipped and not to be processed.
- onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.UsePartitionTimeOnInvalidTimestamp
- 
Returns the current stream-time as new timestamp for the record.
- onPartitionLeadershipChanges(Set<TopicIdPartition>, Set<TopicIdPartition>) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
- 
This method is invoked only when there are changes in leadership of the topic partitions that this broker is responsible for.
- 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.
- onPartitionsLost(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.ConsumerRebalanceListener
- 
A callback method you can implement to provide handling of cleaning up resources for partitions that have already been reassigned to other consumers.
- 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.
- onRestoreEnd(TopicPartition, String, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
- 
Method called when restoring theStateStoreis complete.
- onRestoreStart(TopicPartition, String, long, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
- 
Method called at the very beginning ofStateStorerestoration.
- onRestoreSuspended(TopicPartition, String, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
- 
Method called when restoring theStateStoreis suspended due to the task being migrated out of the host.
- onSend(ProducerRecord<K, V>) - Method in interface org.apache.kafka.clients.producer.ProducerInterceptor
- 
This is called fromKafkaProducer.send(ProducerRecord)andKafkaProducer.send(ProducerRecord, Callback)methods, before key and value get serialized and partition is assigned (if partition is not specified in ProducerRecord).
- onStopPartitions(Set<TopicIdPartition>) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
- 
This method is invoked only when the topic partitions are stopped on this broker.
- onUpdate(ClusterResource) - Method in interface org.apache.kafka.common.ClusterResourceListener
- 
A callback method that a user can implement to get updates forClusterResource.
- onUpdateStart(TopicPartition, String, long) - Method in interface org.apache.kafka.streams.processor.StandbyUpdateListener
- 
A callback that will be invoked after registering the changelogs for each state store in a standby task.
- onUpdateSuspended(TopicPartition, String, long, long, StandbyUpdateListener.SuspendReason) - Method in interface org.apache.kafka.streams.processor.StandbyUpdateListener
- 
This method is called when the corresponding standby task stops updating, for the provided reason.
- onWindowClose() - Static method in interface org.apache.kafka.streams.kstream.EmitStrategy
- 
This strategy indicates that the aggregated result for a window will only be emitted when the window closes instead of when there's an update to the window.
- onWindowUpdate() - Static method in interface org.apache.kafka.streams.kstream.EmitStrategy
- 
This strategy indicates that the aggregated result for a window will be emitted every time when there's an update to the window instead of when the window closes.
- Op(String, Double) - Constructor for class org.apache.kafka.common.quota.ClientQuotaAlteration.Op
- open(Collection<TopicPartition>) - Method in class org.apache.kafka.connect.sink.SinkTask
- 
The SinkTask uses this method to create writers for newly assigned partitions in case of partition rebalance.
- 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.
- operation() - Method in class org.apache.kafka.server.authorizer.Action
- OperationNotAttemptedException - Exception Class in org.apache.kafka.common.errors
- 
Indicates that the broker did not attempt to execute this operation.
- OperationNotAttemptedException(String) - Constructor for exception class org.apache.kafka.common.errors.OperationNotAttemptedException
- ops() - Method in class org.apache.kafka.common.quota.ClientQuotaAlteration
- OPTIMIZE - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"topology.optimization"for enabling topology optimization
- optimizeRackAwareActiveTasks(TaskAssignmentUtils.RackAwareOptimizationParams, Map<ProcessId, KafkaStreamsAssignment>) - Static method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils
- 
Optimize active task assignment for rack awareness.
- optimizeRackAwareStandbyTasks(TaskAssignmentUtils.RackAwareOptimizationParams, Map<ProcessId, KafkaStreamsAssignment>) - Static method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils
- 
Optimize standby task assignment for rack awareness.
- optional() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- 
Set this schema as optional.
- OPTIONAL_BOOLEAN_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- OPTIONAL_BYTES_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- OPTIONAL_FLOAT32_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- OPTIONAL_FLOAT64_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- OPTIONAL_INT16_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- OPTIONAL_INT32_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- OPTIONAL_INT64_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- OPTIONAL_INT8_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- OPTIONAL_STRING_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- opType() - Method in class org.apache.kafka.clients.admin.AlterConfigOp
- orderInGroup - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
- org.apache.kafka.clients.admin - package org.apache.kafka.clients.admin
- 
Provides a Kafka client for performing administrative operations (such as creating topics and configuring brokers) on a Kafka cluster.
- org.apache.kafka.clients.consumer - package org.apache.kafka.clients.consumer
- 
Provides a Kafka client for consuming records from topics and/or partitions in a Kafka cluster.
- org.apache.kafka.clients.producer - package org.apache.kafka.clients.producer
- 
Provides a Kafka client for producing records to topics and/or partitions in a Kafka cluster.
- org.apache.kafka.common - package org.apache.kafka.common
- 
Provides shared functionality for Kafka clients and servers.
- org.apache.kafka.common.acl - package org.apache.kafka.common.acl
- 
Provides classes representing Access Control Lists for authorization of clients
- org.apache.kafka.common.annotation - package org.apache.kafka.common.annotation
- 
Provides annotations used on Kafka APIs.
- org.apache.kafka.common.config - package org.apache.kafka.common.config
- 
Provides common mechanisms for defining, parsing, validating, and documenting user-configurable parameters.
- org.apache.kafka.common.config.provider - package org.apache.kafka.common.config.provider
- 
Provides a pluggable interface and some implementations for late-binding in configuration values.
- org.apache.kafka.common.errors - package org.apache.kafka.common.errors
- 
Provides common exception classes.
- org.apache.kafka.common.header - package org.apache.kafka.common.header
- 
Provides API for application-defined metadata attached to Kafka records.
- org.apache.kafka.common.metrics - package org.apache.kafka.common.metrics
- 
Provides the API used by Kafka clients to emit metrics which are then exposed using the *MetricsReporterinterface.
- org.apache.kafka.common.metrics.stats - package org.apache.kafka.common.metrics.stats
- 
Provides methods of statistically aggregating metrics upon emission.
- org.apache.kafka.common.quota - package org.apache.kafka.common.quota
- 
Provides mechanisms for enforcing resource quotas.
- org.apache.kafka.common.resource - package org.apache.kafka.common.resource
- 
Provides client handles representing logical resources in a Kafka cluster.
- org.apache.kafka.common.security.auth - package org.apache.kafka.common.security.auth
- 
Provides pluggable interfaces for implementing Kafka authentication mechanisms.
- org.apache.kafka.common.security.oauthbearer - package org.apache.kafka.common.security.oauthbearer
- 
Provides aLoginModulefor using OAuth Bearer Token authentication with Kafka clusters.
- org.apache.kafka.common.security.plain - package org.apache.kafka.common.security.plain
- 
Provides implementation to use plaintext credentials authentication for securing Kafka clusters.
- org.apache.kafka.common.security.scram - package org.apache.kafka.common.security.scram
- 
Provides adaptor to use the Salted Challenge Response Authentication Mechanism for securing Kafka clusters.
- org.apache.kafka.common.security.token.delegation - package org.apache.kafka.common.security.token.delegation
- 
Provides mechanism for delegating authorization to a distinct Principal for securing Kafka clusters.
- org.apache.kafka.common.serialization - package org.apache.kafka.common.serialization
- 
Provides interface and some implementations of serialization/deserialization routines for various objects.
- org.apache.kafka.connect.components - package org.apache.kafka.connect.components
- 
Provides common interfaces used to describe pluggable components.
- org.apache.kafka.connect.connector - package org.apache.kafka.connect.connector
- 
Provides interfaces for Connector and Task implementations.
- org.apache.kafka.connect.connector.policy - package org.apache.kafka.connect.connector.policy
- 
Provides pluggable interfaces for policies controlling how users can configure connectors.
- org.apache.kafka.connect.data - package org.apache.kafka.connect.data
- 
Provides classes for representing data and schemas handled by Connect.
- org.apache.kafka.connect.errors - package org.apache.kafka.connect.errors
- 
Provides common exception classes for Connect, used by the framework and plugins to communicate failures.
- org.apache.kafka.connect.header - package org.apache.kafka.connect.header
- 
Provides an API for application-defined metadata attached to Connect records.
- org.apache.kafka.connect.health - package org.apache.kafka.connect.health
- 
Provides an API for describing the state of a running Connect cluster toConnectRestExtensioninstances.
- org.apache.kafka.connect.mirror - package org.apache.kafka.connect.mirror
- 
Provides APIs for the MirrorMaker connectors and utilities to manage MirrorMaker resources.
- org.apache.kafka.connect.rest - package org.apache.kafka.connect.rest
- 
Provides a pluggable interface for altering the behavior of the Connect REST API.
- org.apache.kafka.connect.sink - package org.apache.kafka.connect.sink
- 
Provides an API for implementing sink connectors which write Kafka records to external applications.
- org.apache.kafka.connect.source - package org.apache.kafka.connect.source
- 
Provides an API for implementing source connectors which read data from external applications into Kafka.
- org.apache.kafka.connect.storage - package org.apache.kafka.connect.storage
- 
Provides pluggable interfaces and some implementations for (de)serializing data to and from Kafka
- org.apache.kafka.connect.tools - package org.apache.kafka.connect.tools
- 
Provides source and sink connector implementations used for testing
- org.apache.kafka.connect.transforms - package org.apache.kafka.connect.transforms
- 
Provides a pluggable interface for altering data which is being moved by Connect.
- org.apache.kafka.connect.transforms.predicates - package org.apache.kafka.connect.transforms.predicates
- 
Provides a pluggable interface for describing when aTransformationshould be applied to a record.
- org.apache.kafka.connect.util - package org.apache.kafka.connect.util
- 
Provides common utilities that can be used in component implementations.
- org.apache.kafka.coordinator.group.api.assignor - package org.apache.kafka.coordinator.group.api.assignor
- 
Provides the core functionality and metadata management for consumer group partition assignment.
- org.apache.kafka.server.authorizer - package org.apache.kafka.server.authorizer
- 
Provides pluggable interface for performing authorization on a Kafka server.
- org.apache.kafka.server.log.remote.storage - package org.apache.kafka.server.log.remote.storage
- 
Provides a pluggable API for defining remote storage and retrieval of Kafka log segments.
- org.apache.kafka.server.policy - package org.apache.kafka.server.policy
- 
Provides pluggable interfaces for expressing policies on topics and configs.
- org.apache.kafka.server.quota - package org.apache.kafka.server.quota
- 
Provides pluggable interface for enforcing client quotas from a Kafka server.
- org.apache.kafka.server.telemetry - package org.apache.kafka.server.telemetry
- 
Provides pluggable interface for capturing client telemetry metrics.
- org.apache.kafka.streams - package org.apache.kafka.streams
- 
Provides the Kafka Streams library for building streaming data applications.
- org.apache.kafka.streams.errors - package org.apache.kafka.streams.errors
- 
Provides common exception classes for Streams applications.
- org.apache.kafka.streams.kstream - package org.apache.kafka.streams.kstream
- org.apache.kafka.streams.processor - package org.apache.kafka.streams.processor
- 
Provides a low-level programming model (Processor API, aka, PAPI) to express a (stateful) data flow computation over input topics.
- org.apache.kafka.streams.processor.api - package org.apache.kafka.streams.processor.api
- 
Provides a low-level programming model (Processor API, aka, PAPI) to express a (stateful) data flow computation over input topics.
- org.apache.kafka.streams.processor.assignment - package org.apache.kafka.streams.processor.assignment
- 
Provides classes and interfaces used to manage and assign tasks within Kafka Streams applications.
- org.apache.kafka.streams.processor.assignment.assignors - package org.apache.kafka.streams.processor.assignment.assignors
- 
Provides classes for assigning tasks to stream threads.
- org.apache.kafka.streams.query - package org.apache.kafka.streams.query
- 
Provides a query API (aka Interactive Queries) over state stores, for extracting data from a stateful Kafka Streams application.
- org.apache.kafka.streams.state - package org.apache.kafka.streams.state
- 
Provides interfaces for managing the intermediate state of a stateful streams application.
- org.apache.kafka.streams.test - package org.apache.kafka.streams.test
- 
Provides classes for testing Kafka Streams applications with mocked inputs.
- org.apache.kafka.tools.api - package org.apache.kafka.tools.api
- 
Provides interfaces for writing plugins of kafka tools
- origin() - Method in exception class org.apache.kafka.common.errors.RecordDeserializationException
- originalKafkaOffset() - Method in class org.apache.kafka.connect.sink.SinkRecord
- 
Get the original offset for this sink record, before anytransformationswere applied.
- originalKafkaPartition() - Method in class org.apache.kafka.connect.sink.SinkRecord
- 
Get the original topic partition for this sink record, before anytransformationswere applied.
- originals() - Method in class org.apache.kafka.common.config.AbstractConfig
- originals(Map<String, Object>) - 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.
- originalTopic() - Method in class org.apache.kafka.connect.sink.SinkRecord
- 
Get the original topic for this sink record, before anytransformationswere applied.
- originalTopic(String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
- 
Returns the name of the original topic, which may have been replicated multiple hops.
- otherValueSerde() - Method in class org.apache.kafka.streams.kstream.Joined
- 
Deprecated.Since 4.0 and should not be used any longer.
- otherValueSerde(Serde<VRight>) - Static method in class org.apache.kafka.streams.kstream.Joined
- 
Create an instance ofJoinedwith aother valueSerde.
- outerJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream with anotherKStream's records using windowed outer equi join with default serializers and deserializers.
- outerJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream with anotherKStream's records using windowed outer equi join using theStreamJoinedinstance for configuration of thekey serde,this stream's value serde,the other stream's value serde, and used state stores.
- outerJoin(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream with anotherKStream's records using windowed outer equi join with default serializers and deserializers.
- outerJoin(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Join records of this stream with anotherKStream's records using windowed outer equi join using theStreamJoinedinstance for configuration of thekey serde,this stream's value serde,the other stream's value serde, and used state stores.
- outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTable(left input) with anotherKTable's (right input) records using non-windowed outer equi join, with default serializers, deserializers, and state store.
- outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTable(left input) with anotherKTable's (right input) records using non-windowed outer equi join, with theMaterializedinstance for configuration of thekey serde,the result table's value serde, andstate store.
- outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTable(left input) with anotherKTable's (right input) records using non-windowed outer equi join, with default serializers, deserializers, and state store.
- outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Join records of thisKTable(left input) with anotherKTable's (right input) records using non-windowed outer equi join, with theMaterializedinstance for configuration of thekey serde,the result table's value serde, andstate store.
- OutOfOrderSequenceException - Exception Class 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 class org.apache.kafka.common.errors.OutOfOrderSequenceException
- overlap(Window) - Method in class org.apache.kafka.streams.kstream.Window
- 
Check if the given window overlaps with this window.
- ownedPartitions() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
- owner() - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
- owner() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
- owner(KafkaPrincipal) - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
- 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
- pair(K, V) - Static method in class org.apache.kafka.streams.KeyValue
- 
Create a new key-value pair.
- parameter(String, String) - Method in class org.apache.kafka.connect.data.SchemaBuilder
- 
Set a schema parameter.
- parameters() - Method in class org.apache.kafka.connect.data.ConnectSchema
- parameters() - Method in interface org.apache.kafka.connect.data.Schema
- 
Get a map of schema parameters.
- parameters() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- parameters(Map<String, String>) - Method in class org.apache.kafka.connect.data.SchemaBuilder
- 
Set schema parameters.
- parse(String) - Static method in enum class org.apache.kafka.clients.admin.TransactionState
- parse(String) - Static method in enum class org.apache.kafka.common.ClassicGroupState
- 
Case-insensitive classic group state lookup by string name.
- parse(String) - Static method in enum class org.apache.kafka.common.ConsumerGroupState
- 
Deprecated.Case-insensitive consumer group state lookup by string name.
- parse(String) - Static method in enum class org.apache.kafka.common.GroupState
- 
Case-insensitive group state lookup by string name.
- parse(String) - Static method in enum class org.apache.kafka.common.GroupType
- 
Parse a string into a consumer group type, in a case-insensitive manner.
- parse(String) - Static method in class org.apache.kafka.streams.processor.TaskId
- parse(Map<?, ?>) - Method in class org.apache.kafka.common.config.ConfigDef
- 
Parse and validate configs against this configuration definition.
- parseStoreType() - Method in class org.apache.kafka.streams.TopologyConfig
- 
Deprecated.
- parseString(String) - Static method in class org.apache.kafka.connect.data.Values
- 
Parse the specified string representation of a value into its schema and value.
- 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 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.TopicIdPartition
- 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() - Method in interface org.apache.kafka.streams.errors.ErrorHandlerContext
- 
Return the partition ID of the current input record; could be-1if it is not available.
- partition() - Method in class org.apache.kafka.streams.KeyQueryMetadata
- 
Get the store partition corresponding to the key.
- partition() - Method in interface org.apache.kafka.streams.processor.api.RecordMetadata
- 
Return the partition id of the current input record; could be-1if it is not available.
- partition() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- partition() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Return the partition id of the current input record; could be-1if it is not available.
- partition() - Method in interface org.apache.kafka.streams.processor.RecordContext
- 
Return the partition id of the current input record; could be-1if it is not available.
- partition() - Method in class org.apache.kafka.streams.processor.TaskId
- partition() - Method in class org.apache.kafka.streams.StoreQueryParameters
- 
Get the store partition that will be queried.
- partition(String, Object, byte[], Object, byte[], Cluster) - Method in interface org.apache.kafka.clients.producer.Partitioner
- 
Compute the partition for the given record.
- partition(String, Object, byte[], Object, byte[], Cluster) - Method in class org.apache.kafka.clients.producer.RoundRobinPartitioner
- 
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
- PARTITION_COUNT_CONFIG - Static variable in class org.apache.kafka.connect.tools.SchemaSourceTask
- PARTITION_KEY - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
- partitionAssignor() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
- 
The consumer group partition assignor.
- PartitionAssignor - Interface in org.apache.kafka.coordinator.group.api.assignor
- 
Server-side partition assignor used by the GroupCoordinator.
- PartitionAssignorException - Exception Class in org.apache.kafka.coordinator.group.api.assignor
- 
Exception thrown byPartitionAssignor.assign(GroupSpec, SubscribedTopicDescriber)}.
- PartitionAssignorException(String) - Constructor for exception class org.apache.kafka.coordinator.group.api.assignor.PartitionAssignorException
- PartitionAssignorException(String, Throwable) - Constructor for exception class org.apache.kafka.coordinator.group.api.assignor.PartitionAssignorException
- 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
- PARTITIONER_ADPATIVE_PARTITIONING_ENABLE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
partitioner.adaptive.partitioning.enable
- PARTITIONER_AVAILABILITY_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
partitioner.availability.timeout.ms
- PARTITIONER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
partitioner.class
- PARTITIONER_IGNORE_KEYS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
partitioner.ignore.keys
- 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
- PartitionProducerState(List<ProducerState>) - Constructor for class org.apache.kafka.clients.admin.DescribeProducersResult.PartitionProducerState
- PartitionReassignment - Class in org.apache.kafka.clients.admin
- 
A partition reassignment, which has been listed viaAdmin.listPartitionReassignments().
- PartitionReassignment(List<Integer>, List<Integer>, List<Integer>) - Constructor for class org.apache.kafka.clients.admin.PartitionReassignment
- partitionResult(TopicPartition) - Method in class org.apache.kafka.clients.admin.AlterConsumerGroupOffsetsResult
- 
Return a future which can be used to check the result for a given partition.
- partitionResult(TopicPartition) - Method in class org.apache.kafka.clients.admin.DeleteConsumerGroupOffsetsResult
- 
Return a future which can be used to check the result for a given partition.
- partitionResult(TopicPartition) - Method in class org.apache.kafka.clients.admin.DescribeProducersResult
- partitionResult(TopicPartition) - Method in class org.apache.kafka.clients.admin.ListOffsetsResult
- 
Return a future which can be used to check the result for a given partition.
- partitions() - Method in class org.apache.kafka.clients.admin.ElectLeadersResult
- 
Get a future for the topic partitions for which a leader election was attempted.
- 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.ConsumerPartitionAssignor.Assignment
- 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 class org.apache.kafka.clients.consumer.InvalidOffsetException
- partitions() - Method in exception class org.apache.kafka.clients.consumer.NoOffsetForPartitionException
- 
returns all partitions for which no offsets are defined.
- partitions() - Method in exception class org.apache.kafka.clients.consumer.OffsetOutOfRangeException
- partitions() - Method in interface org.apache.kafka.coordinator.group.api.assignor.MemberAssignment
- partitions(String, K, V, int) - Method in interface org.apache.kafka.streams.processor.StreamPartitioner
- 
Determine the number(s) of the partition(s) to which a record with the given key and value should be sent, for the given topic and current partition count
- 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
- partitionsForException - Variable in class org.apache.kafka.clients.producer.MockProducer
- 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
- partitionSizeLimitPerResponse() - Method in class org.apache.kafka.clients.admin.DescribeTopicsOptions
- partitionSizeLimitPerResponse(int) - Method in class org.apache.kafka.clients.admin.DescribeTopicsOptions
- partitionsToOffsetAndMetadata() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsResult
- 
Return a future which yields a map of topic partitions to OffsetAndMetadata objects.
- partitionsToOffsetAndMetadata(String) - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsResult
- 
Return a future which yields a map of topic partitions to OffsetAndMetadata objects for the specified group.
- password() - Method in class org.apache.kafka.clients.admin.UserScramCredentialUpsertion
- password() - Method in class org.apache.kafka.common.security.plain.PlainAuthenticateCallback
- 
Returns the password provided by the client during SASL/PLAIN authentication
- PASSWORD - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigType
- PASSWORD - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Type
- 
Used for string values containing sensitive data such as a password or key.
- pattern() - Method in class org.apache.kafka.clients.consumer.SubscriptionPattern
- 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 Class in org.apache.kafka.common.resource
- 
Resource pattern type.
- pause() - Method in class org.apache.kafka.streams.KafkaStreams
- 
This method pauses processing for the KafkaStreams instance.
- 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.connect.sink.SinkTaskContext
- 
Pause consumption of messages from the specified TopicPartitions.
- 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 toKafkaConsumer.pause(Collection).
- paused() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- peek(ForeachAction<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Perform an action on each record ofKStream.
- peek(ForeachAction<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Perform an action on each record ofKStream.
- peekNextKey() - Method in interface org.apache.kafka.streams.state.KeyValueIterator
- 
Peek at the next key without advancing the iterator
- PENDING_ERROR - Enum constant in enum class org.apache.kafka.streams.KafkaStreams.State
- PENDING_SHUTDOWN - Enum constant in enum class org.apache.kafka.streams.KafkaStreams.State
- percentile() - Method in class org.apache.kafka.common.metrics.stats.Percentile
- Percentile - Class in org.apache.kafka.common.metrics.stats
- Percentile(MetricName, double) - Constructor for class org.apache.kafka.common.metrics.stats.Percentile
- Percentiles - Class in org.apache.kafka.common.metrics.stats
- 
A compound stat that reports one or more percentiles
- Percentiles(int, double, double, Percentiles.BucketSizing, Percentile...) - Constructor for class org.apache.kafka.common.metrics.stats.Percentiles
- Percentiles(int, double, Percentiles.BucketSizing, Percentile...) - Constructor for class org.apache.kafka.common.metrics.stats.Percentiles
- Percentiles.BucketSizing - Enum Class in org.apache.kafka.common.metrics.stats
- 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.
- Per-record acknowledgement (explicit acknowledgement) - Search tag in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- Section
- Per-record acknowledgement, ending processing of the batch on an error (explicit acknowledgement) - Search tag in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- Section
- persistent() - Method in interface org.apache.kafka.streams.processor.StateStore
- 
Return if the storage is persistent or not.
- persistentKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
- 
Create a persistentKeyValueBytesStoreSupplier.
- persistentSessionStore(String, Duration) - Static method in class org.apache.kafka.streams.state.Stores
- 
Create a persistentSessionBytesStoreSupplier.
- persistentTimestampedKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
- 
Create a persistentKeyValueBytesStoreSupplier.
- persistentTimestampedWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
- 
Create a persistentWindowBytesStoreSupplier.
- persistentVersionedKeyValueStore(String, Duration) - Static method in class org.apache.kafka.streams.state.Stores
- 
Create a persistent versioned key-value storeVersionedBytesStoreSupplier.
- persistentVersionedKeyValueStore(String, Duration, Duration) - Static method in class org.apache.kafka.streams.state.Stores
- 
Create a persistent versioned key-value storeVersionedBytesStoreSupplier.
- persistentWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
- 
Create a persistentWindowBytesStoreSupplier.
- pipeInput(K, V) - Method in class org.apache.kafka.streams.TestInputTopic
- 
Send an input record with the given key and value on the topic and then commit the records.
- pipeInput(K, V, long) - Method in class org.apache.kafka.streams.TestInputTopic
- 
Send an input record with the given key, value and timestamp on the topic and then commit the records.
- pipeInput(K, V, Instant) - Method in class org.apache.kafka.streams.TestInputTopic
- 
Send an input record with the given key, value and timestamp on the topic and then commit the records.
- pipeInput(TestRecord<K, V>) - Method in class org.apache.kafka.streams.TestInputTopic
- 
Send an input record with the given record on the topic and then commit the records.
- pipeInput(V) - Method in class org.apache.kafka.streams.TestInputTopic
- 
Send an input record with the given value on the topic and then commit the records.
- pipeInput(V, Instant) - Method in class org.apache.kafka.streams.TestInputTopic
- 
Send an input record with the given value and timestamp on the topic and then commit the records.
- pipeKeyValueList(List<KeyValue<K, V>>) - Method in class org.apache.kafka.streams.TestInputTopic
- 
Send input records with the given KeyValue list on the topic then commit each record individually.
- pipeKeyValueList(List<KeyValue<K, V>>, Instant, Duration) - Method in class org.apache.kafka.streams.TestInputTopic
- 
Send input records with the givenKeyValuelist on the topic then commit each record individually.
- pipeRecordList(List<? extends TestRecord<K, V>>) - Method in class org.apache.kafka.streams.TestInputTopic
- 
Send input records with the given KeyValue list on the topic then commit each record individually.
- pipeValueList(List<V>) - Method in class org.apache.kafka.streams.TestInputTopic
- 
Send input records with the given value list on the topic then commit each record individually.
- pipeValueList(List<V>, Instant, Duration) - Method in class org.apache.kafka.streams.TestInputTopic
- 
Send input records with the given value list on the topic then commit each record individually.
- 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 - Enum constant in enum class 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 Class 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 class org.apache.kafka.common.errors.PolicyViolationException
- PolicyViolationException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.PolicyViolationException
- poll() - Method in class org.apache.kafka.connect.source.SourceTask
- 
Poll this source task for new records.
- poll() - Method in class org.apache.kafka.connect.tools.MockSourceTask
- poll() - Method in class org.apache.kafka.connect.tools.SchemaSourceTask
- poll() - Method in class org.apache.kafka.connect.tools.VerifiableSourceTask
- 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.KafkaShareConsumer
- 
Fetch data for the topics specified usingKafkaShareConsumer.subscribe(Collection).
- poll(Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- poll(Duration) - Method in class org.apache.kafka.clients.consumer.MockShareConsumer
- poll(Duration) - Method in interface org.apache.kafka.clients.consumer.ShareConsumer
- POLL - Enum constant in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
- 
A new transaction will be started and committed for every batch of records returned bySourceTask.poll().
- POLL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
poll.ms
- port() - Method in class org.apache.kafka.clients.admin.RaftVoterEndpoint
- port() - Method in class org.apache.kafka.common.Endpoint
- 
Returns the port to which the listener is bound.
- port() - Method in class org.apache.kafka.common.Node
- 
The port for this node
- port() - Method in class org.apache.kafka.streams.state.HostInfo
- port() - Method in interface org.apache.kafka.streams.StreamsMetadata
- 
Port on which the Streams client listens.
- position() - Method in class org.apache.kafka.streams.query.PositionBound
- 
Returns the specific position of this bound.
- 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
- Position - Class in org.apache.kafka.streams.query
- 
A representation of a position vector with respect to a set of topic partitions.
- PositionBound - Class in org.apache.kafka.streams.query
- 
A class bounding the processing statePositionduring queries.
- PositionOutOfRangeException - Exception Class in org.apache.kafka.common.errors
- PositionOutOfRangeException(String) - Constructor for exception class org.apache.kafka.common.errors.PositionOutOfRangeException
- PositionOutOfRangeException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.PositionOutOfRangeException
- PREALLOCATE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
- PREALLOCATE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
- preCommit(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.apache.kafka.connect.sink.SinkTask
- 
Pre-commit hook invoked prior to an offset commit.
- predecessors() - Method in interface org.apache.kafka.streams.TopologyDescription.Node
- 
The predecessors of this node within a sub-topology.
- Predicate<R> - Interface in org.apache.kafka.connect.transforms.predicates
- 
A predicate on records.
- Predicate<K,V> - Interface in org.apache.kafka.streams.kstream
- 
ThePredicateinterface represents a predicate (boolean-valued function) of aKeyValuepair.
- PREFERRED - Enum constant in enum class org.apache.kafka.common.ElectionType
- PreferredLeaderNotAvailableException - Exception Class in org.apache.kafka.common.errors
- PreferredLeaderNotAvailableException(String) - Constructor for exception class org.apache.kafka.common.errors.PreferredLeaderNotAvailableException
- PreferredLeaderNotAvailableException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.PreferredLeaderNotAvailableException
- PREFIXED - Enum constant in enum class org.apache.kafka.common.resource.PatternType
- 
A prefixed resource name.
- prefixScan(P, PS) - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
- 
Return an iterator over all keys with the specified prefix.
- PREPARE_ABORT - Enum constant in enum class org.apache.kafka.clients.admin.TransactionState
- PREPARE_COMMIT - Enum constant in enum class org.apache.kafka.clients.admin.TransactionState
- PREPARE_EPOCH_FENCE - Enum constant in enum class org.apache.kafka.clients.admin.TransactionState
- PREPARING_REBALANCE - Enum constant in enum class org.apache.kafka.common.ClassicGroupState
- PREPARING_REBALANCE - Enum constant in enum class org.apache.kafka.common.ConsumerGroupState
- 
Deprecated.
- PREPARING_REBALANCE - Enum constant in enum class org.apache.kafka.common.GroupState
- previousActiveTasks() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- previousStandbyTasks() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- prevTasksByLag(String) - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- 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() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
- 
Returns authenticated principal for the connection on which request was received.
- PrincipalDeserializationException - Exception Class in org.apache.kafka.common.errors
- 
Exception used to indicate a kafka principal deserialization failure during request forwarding.
- PrincipalDeserializationException(String) - Constructor for exception class org.apache.kafka.common.errors.PrincipalDeserializationException
- PrincipalDeserializationException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.PrincipalDeserializationException
- principalName() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
- 
The name of the principal to which this credential applies
- print(Printed<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Print the records of this KStream using the options provided byPrintedNote that this is mainly for debugging/testing purposes, and it will try to flush on each record print.
- Printed<K,V> - Class in org.apache.kafka.streams.kstream
- 
An object to define the options used when printing aKStream.
- PROBING_REBALANCE_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
probing.rebalance.interval.ms
- probingRebalanceIntervalMs() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- 
The probing rebalance interval in milliseconds as configured viaStreamsConfig.PROBING_REBALANCE_INTERVAL_MS_CONFIG
- process(FixedKeyRecord<KIn, VIn>) - Method in interface org.apache.kafka.streams.processor.api.FixedKeyProcessor
- 
Process the record.
- process(ProcessorSupplier<? super K, ? super V, KOut, VOut>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Process all records in this stream, one record at a time, by applying aProcessor(provided by the givenProcessorSupplier).
- process(ProcessorSupplier<? super K, ? super V, KOut, VOut>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Process all records in this stream, one record at a time, by applying aProcessor(provided by the givenProcessorSupplier).
- process(Record<K, V>) - Method in class org.apache.kafka.streams.kstream.ForeachProcessor
- 
Deprecated.
- process(Record<KIn, VIn>) - Method in interface org.apache.kafka.streams.processor.api.Processor
- 
Process the record.
- processId() - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment
- processId() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- ProcessId - Class in org.apache.kafka.streams.processor.assignment
- 
A simple wrapper around UUID that abstracts a Process ID
- ProcessId(UUID) - Constructor for class org.apache.kafka.streams.processor.assignment.ProcessId
- PROCESSING_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
processing.exception.handler
- PROCESSING_EXCEPTION_HANDLER_CLASS_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- PROCESSING_GUARANTEE_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
processing.guarantee
- PROCESSING_THREADS_ENABLED - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- ProcessingContext - Interface in org.apache.kafka.streams.processor.api
- 
Processor context interface.
- processingExceptionHandler - Variable in class org.apache.kafka.streams.TopologyConfig.TaskConfig
- processingExceptionHandler() - Method in class org.apache.kafka.streams.StreamsConfig
- ProcessingExceptionHandler - Interface in org.apache.kafka.streams.errors
- 
An interface that allows user code to inspect a record that has failed processing
- ProcessingExceptionHandler.ProcessingHandlerResponse - Enum Class in org.apache.kafka.streams.errors
- processingExceptionHandlerSupplier - Variable in class org.apache.kafka.streams.TopologyConfig
- Processing messages - Search tag in class org.apache.kafka.streams.TestInputTopic
- Section
- Processing messages - Search tag in class org.apache.kafka.streams.TopologyTestDriver
- Section
- Processing records - Search tag in class org.apache.kafka.streams.TestOutputTopic
- Section
- processingThreadsEnabled(Map<String, Object>) - Static method in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- processor() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
- 
The processor node maintaining the global store.
- Processor<KIn,VIn, - Interface in org.apache.kafka.streams.processor.apiKOut, VOut> 
- 
A processor of key-value pair records.
- PROCESSOR_WRAPPER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
processor.wrapper.class
- ProcessorContext<KForward,VForward> - Interface in org.apache.kafka.streams.processor.api
- 
Processor context interface forRecord.
- ProcessorContext - Interface in org.apache.kafka.streams.processor
- 
Processor context interface.
- processorNodeId() - Method in interface org.apache.kafka.streams.errors.ErrorHandlerContext
- 
Return the current processor node ID.
- Processor state - Search tag in class org.apache.kafka.streams.TopologyTestDriver
- Section
- ProcessorStateException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates a processor state operation (e.g.
- ProcessorStateException(String) - Constructor for exception class org.apache.kafka.streams.errors.ProcessorStateException
- ProcessorStateException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.ProcessorStateException
- ProcessorStateException(Throwable) - Constructor for exception class org.apache.kafka.streams.errors.ProcessorStateException
- ProcessorSupplier<KIn,VIn, - Interface in org.apache.kafka.streams.processor.apiKOut, VOut> 
- 
A processor supplier that can create one or moreProcessorinstances.
- ProcessorWrapper - Interface in org.apache.kafka.streams.processor.api
- 
Wrapper class that can be used to inject custom wrappers around the processors of their application topology.
- processValues(FixedKeyProcessorSupplier<? super K, ? super V, VOut>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Process all records in this stream, one record at a time, by applying aFixedKeyProcessor(provided by the givenFixedKeyProcessorSupplier).
- processValues(FixedKeyProcessorSupplier<? super K, ? super V, VOut>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Process all records in this stream, one record at a time, by applying aFixedKeyProcessor(provided by the givenFixedKeyProcessorSupplier).
- PRODUCE - Enum constant in enum class org.apache.kafka.server.quota.ClientQuotaType
- Produced<K,V> - Class in org.apache.kafka.streams.kstream
- 
This class is used to provide the optional parameters when producing to new topics usingKStream.to(String, Produced).
- producedTopicNames() - Method in class org.apache.kafka.streams.TopologyTestDriver
- 
Get all the names of all the topics to which records have been produced during the test run.
- Producer<K,V> - Interface in org.apache.kafka.clients.producer
- 
The interface for theKafkaProducer
- PRODUCER - Enum constant in enum class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
- PRODUCER_CLIENT_PREFIX - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- PRODUCER_METRIC_GROUP_NAME - Static variable in class org.apache.kafka.clients.producer.KafkaProducer
- PRODUCER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Prefix used to isolateproducerconfigs from other client configs.
- PRODUCER_SNAPSHOT - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemoteStorageManager.IndexType
- 
Represents producer snapshot index.
- producerClientIds() - Method in interface org.apache.kafka.streams.ThreadMetadata
- 
Client IDs of the Kafka producers used by the stream thread.
- producerConfig() - Method in class org.apache.kafka.connect.mirror.MirrorClientConfig
- 
Sub-config for Producer clients.
- 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
- producerEpoch() - Method in class org.apache.kafka.clients.admin.AbortTransactionSpec
- producerEpoch() - Method in class org.apache.kafka.clients.admin.ProducerState
- producerEpoch() - Method in class org.apache.kafka.clients.admin.TransactionDescription
- ProducerFencedException - Exception Class in org.apache.kafka.common.errors
- 
This fatal exception indicates that another producer with the sametransactional.idhas been started.
- ProducerFencedException(String) - Constructor for exception class org.apache.kafka.common.errors.ProducerFencedException
- producerId() - Method in class org.apache.kafka.clients.admin.AbortTransactionSpec
- producerId() - Method in class org.apache.kafka.clients.admin.ProducerState
- producerId() - Method in class org.apache.kafka.clients.admin.TransactionDescription
- producerId() - Method in class org.apache.kafka.clients.admin.TransactionListing
- producerId(String) - Method in class org.apache.kafka.clients.admin.FenceProducersResult
- 
Returns a future that provides the producer ID generated while initializing the given transaction when the request completes.
- producerInstanceIds() - Method in interface org.apache.kafka.streams.ClientInstanceIds
- 
Returns theclient instance idof the producers.
- 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.
- producerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
- 
Prefix a property withStreamsConfig.PRODUCER_PREFIX.
- 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
- producerSnapshotIndex() - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
- ProducerState - Class in org.apache.kafka.clients.admin
- ProducerState(long, int, int, long, OptionalInt, OptionalLong) - Constructor for class org.apache.kafka.clients.admin.ProducerState
- PRODUCTION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
production.exception.handler
- productionExceptionHandler() - Method in class org.apache.kafka.streams.StreamsConfig
- ProductionExceptionHandler - Interface in org.apache.kafka.streams.errors
- 
Interface that specifies how an exception when attempting to produce a result to Kafka should be handled.
- ProductionExceptionHandler.ProductionExceptionHandlerResponse - Enum Class in org.apache.kafka.streams.errors
- ProductionExceptionHandler.SerializationExceptionOrigin - Enum Class in org.apache.kafka.streams.errors
- project(Schema, Object, Schema) - Static method in class org.apache.kafka.connect.data.SchemaProjector
- 
This method projects a value between compatible schemas and throws exceptions when non-compatible schemas are provided
- PROMOTED - Enum constant in enum class org.apache.kafka.streams.processor.StandbyUpdateListener.SuspendReason
- protocol() - Method in class org.apache.kafka.clients.admin.ClassicGroupDescription
- 
The group protocol type.
- protocol() - Method in class org.apache.kafka.clients.admin.GroupListing
- 
The protocol of the group.
- protocolData() - Method in class org.apache.kafka.clients.admin.ClassicGroupDescription
- 
The group protocol data.
- punctuate(long) - Method in interface org.apache.kafka.streams.processor.Punctuator
- 
Perform the scheduled periodic operation.
- PunctuationType - Enum Class in org.apache.kafka.streams.processor
- 
Controls what notion of time is used for punctuation scheduled viaschedule: STREAM_TIME - uses "stream time", which is advanced by the processing of messages in accordance with the timestamp as extracted by theTimestampExtractorin use.
- Punctuator - Interface in org.apache.kafka.streams.processor
- 
A functional interface used as an argument toProcessorContext.schedule(Duration, PunctuationType, Punctuator).
- put(String, Object) - Method in class org.apache.kafka.connect.data.Struct
- 
Set the value of a field.
- put(Collection<SinkRecord>) - Method in class org.apache.kafka.connect.sink.SinkTask
- 
Put the records in the sink.
- put(Collection<SinkRecord>) - Method in class org.apache.kafka.connect.tools.MockSinkTask
- put(Collection<SinkRecord>) - Method in class org.apache.kafka.connect.tools.VerifiableSinkTask
- put(K, V) - Method in interface org.apache.kafka.streams.state.KeyValueStore
- 
Update the value associated with this key.
- put(K, V, long) - Method in interface org.apache.kafka.streams.state.VersionedKeyValueStore
- 
Add a new record version associated with the specified key and timestamp.
- put(K, V, long) - Method in interface org.apache.kafka.streams.state.WindowStore
- 
Put a key-value pair into the window with given window start timestamp
- put(Bytes, byte[], long) - Method in interface org.apache.kafka.streams.state.VersionedBytesStore
- 
The analog ofVersionedKeyValueStore.put(Object, Object, long).
- put(Field, Object) - Method in class org.apache.kafka.connect.data.Struct
- 
Set the value of a field.
- put(Windowed<K>, AGG) - Method in interface org.apache.kafka.streams.state.SessionStore
- 
Write the aggregated value for the provided key to the store
- PUT_RETURN_CODE_NOT_PUT - Static variable in interface org.apache.kafka.streams.state.VersionedKeyValueStore
- PUT_RETURN_CODE_VALID_TO_UNDEFINED - Static variable in interface org.apache.kafka.streams.state.VersionedKeyValueStore
- putAll(List<KeyValue<K, V>>) - Method in interface org.apache.kafka.streams.state.KeyValueStore
- 
Update all the given key/value pairs.
- putIfAbsent(K, V) - Method in interface org.apache.kafka.streams.state.KeyValueStore
- 
Update the value associated with this key, unless a value is already associated with the key.
- putRemotePartitionDeleteMetadata(RemotePartitionDeleteMetadata) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
- 
This method is used to update the metadata about remote partition delete event asynchronously.
Q
- query(Query<R>, PositionBound, QueryConfig) - Method in interface org.apache.kafka.streams.processor.StateStore
- 
Execute a query.
- query(StateQueryRequest<R>) - Method in class org.apache.kafka.streams.KafkaStreams
- 
Run an interactive query against a state store.
- Query<R> - Interface in org.apache.kafka.streams.query
- 
Marker interface that all interactive queries must implement (seeKafkaStreams.query(StateQueryRequest)).
- queryableStoreName() - Method in interface org.apache.kafka.streams.kstream.GlobalKTable
- 
Get the name of the local state store that can be used to query thisGlobalKTable.
- queryableStoreName() - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Get the name of the local state store used that can be used to query thisKTable.
- queryableStoreType() - Method in class org.apache.kafka.streams.StoreQueryParameters
- 
Get the queryable store type for which key is queried by the user.
- QueryableStoreType<T> - Interface in org.apache.kafka.streams.state
- 
Used to enable querying of customStateStoretypes via theKafkaStreamsAPI.
- QueryableStoreTypes - Class in org.apache.kafka.streams.state
- 
Provides access to theQueryableStoreTypes provided withKafkaStreams.
- QueryableStoreTypes() - Constructor for class org.apache.kafka.streams.state.QueryableStoreTypes
- QueryableStoreTypes.KeyValueStoreType<K,V> - Class in org.apache.kafka.streams.state
- QueryableStoreTypes.SessionStoreType<K,V> - Class in org.apache.kafka.streams.state
- QueryableStoreTypes.WindowStoreType<K,V> - Class in org.apache.kafka.streams.state
- QueryConfig - Class in org.apache.kafka.streams.query
- 
Runtime configuration parameters
- QueryConfig(boolean) - Constructor for class org.apache.kafka.streams.query.QueryConfig
- queryMetadataForKey(String, K, Serializer<K>) - Method in class org.apache.kafka.streams.KafkaStreams
- 
Finds the metadata containing the active hosts and standby hosts where the key being queried would reside.
- queryMetadataForKey(String, K, StreamPartitioner<? super K, ?>) - Method in class org.apache.kafka.streams.KafkaStreams
- 
Finds the metadata containing the active hosts and standby hosts where the key being queried would reside.
- QueryResult<R> - Interface in org.apache.kafka.streams.query
- 
Container for a single partition's result when executing aStateQueryRequest.
- quorumInfo() - Method in class org.apache.kafka.clients.admin.DescribeMetadataQuorumResult
- 
Returns a future containing the QuorumInfo
- QuorumInfo - Class in org.apache.kafka.clients.admin
- 
This class is used to describe the state of the quorum received in DescribeQuorumResponse.
- QuorumInfo.Node - Class in org.apache.kafka.clients.admin
- QuorumInfo.ReplicaState - Class in org.apache.kafka.clients.admin
- quota() - Method in class org.apache.kafka.common.metrics.MetricConfig
- quota(Quota) - Method in class org.apache.kafka.common.metrics.MetricConfig
- Quota - Class in org.apache.kafka.common.metrics
- 
An upper or lower bound for metrics
- Quota(double, boolean) - Constructor for class org.apache.kafka.common.metrics.Quota
- 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.
- QuotaViolationException - Exception Class in org.apache.kafka.common.metrics
- 
Thrown when a sensor records a value that causes a metric to go outside the bounds configured as its quota
- QuotaViolationException(KafkaMetric, double, double) - Constructor for exception class org.apache.kafka.common.metrics.QuotaViolationException
R
- rack() - Method in class org.apache.kafka.common.Node
- 
The rack for this node
- RACK_AWARE_ASSIGNMENT_NON_OVERLAP_COST_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
rack.aware.assignment.non_overlap_cost
- RACK_AWARE_ASSIGNMENT_NON_OVERLAP_COST_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- RACK_AWARE_ASSIGNMENT_STRATEGY_BALANCE_SUBTOPOLOGY - Static variable in class org.apache.kafka.streams.StreamsConfig
- RACK_AWARE_ASSIGNMENT_STRATEGY_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
rack.aware.assignment.strategy
- RACK_AWARE_ASSIGNMENT_STRATEGY_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- RACK_AWARE_ASSIGNMENT_STRATEGY_MIN_TRAFFIC - Static variable in class org.apache.kafka.streams.StreamsConfig
- RACK_AWARE_ASSIGNMENT_STRATEGY_NONE - Static variable in class org.apache.kafka.streams.StreamsConfig
- RACK_AWARE_ASSIGNMENT_TAGS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
rack.aware.assignment.tags
- RACK_AWARE_ASSIGNMENT_TRAFFIC_COST_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
rack.aware.assignment.traffic_cost
- RACK_AWARE_ASSIGNMENT_TRAFFIC_COST_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- rackAwareAssignmentStrategy() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- 
The rack-aware assignment strategy as configured viaStreamsConfig.RACK_AWARE_ASSIGNMENT_STRATEGY_CONFIG
- rackAwareAssignmentTags() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- 
The rack-aware assignment tags as configured viaStreamsConfig.RACK_AWARE_ASSIGNMENT_TAGS_CONFIG
- rackAwareNonOverlapCost() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- 
The rack-aware assignment non-overlap cost as configured viaStreamsConfig.RACK_AWARE_ASSIGNMENT_NON_OVERLAP_COST_CONFIG
- rackAwareTrafficCost() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- 
The rack-aware assignment traffic cost as configured viaStreamsConfig.RACK_AWARE_ASSIGNMENT_TRAFFIC_COST_CONFIG
- rackId() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
- rackId() - Method in interface org.apache.kafka.coordinator.group.api.assignor.MemberSubscription
- 
Gets the rack Id if present.
- rackId() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- rackIds() - Method in interface org.apache.kafka.streams.processor.assignment.TaskTopicPartition
- racksForPartition(Uuid, int) - Method in interface org.apache.kafka.coordinator.group.api.assignor.SubscribedTopicDescriber
- 
Returns all the available racks associated with the replicas of the given partition.
- RaftVoterEndpoint - Class in org.apache.kafka.clients.admin
- 
An endpoint for a raft quorum voter.
- RaftVoterEndpoint(String, String, int) - Constructor for class org.apache.kafka.clients.admin.RaftVoterEndpoint
- 
Create an endpoint for a metadata quorum voter.
- raiseError(Exception) - Method in interface org.apache.kafka.connect.connector.ConnectorContext
- 
Raise an unrecoverable exception to the Connect framework.
- randomProcessId() - Static method in class org.apache.kafka.streams.processor.assignment.ProcessId
- randomUuid() - Static method in class org.apache.kafka.common.Uuid
- 
Static factory to retrieve a type 4 (pseudo randomly generated) UUID.
- range(K, K) - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
- 
Get an iterator over a given range of keys.
- RANGE_ASSIGNOR_NAME - Static variable in class org.apache.kafka.clients.consumer.RangeAssignor
- RangeAssignor - Class in org.apache.kafka.clients.consumer
- 
The range assignor works on a per-topic basis.
- RangeAssignor() - Constructor for class org.apache.kafka.clients.consumer.RangeAssignor
- RangeQuery<K,V> - Class in org.apache.kafka.streams.query
- 
Interactive query for issuing range queries and scans over KeyValue stores.
- Rate - Class in org.apache.kafka.common.metrics.stats
- 
The rate of the given quantity.
- Rate() - Constructor for class org.apache.kafka.common.metrics.stats.Rate
- Rate(TimeUnit) - Constructor for class org.apache.kafka.common.metrics.stats.Rate
- Rate(TimeUnit, SampledStat) - Constructor for class org.apache.kafka.common.metrics.stats.Rate
- Rate(SampledStat) - Constructor for class org.apache.kafka.common.metrics.stats.Rate
- rawKey(K) - Method in class org.apache.kafka.streams.state.StateSerdes
- 
Serialize the given key.
- rawValue(V) - Method in class org.apache.kafka.streams.state.StateSerdes
- 
Serialize the given value.
- READ - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
- 
READ operation.
- READ_COMMITTED - Enum constant in enum class org.apache.kafka.common.IsolationLevel
- READ_UNCOMMITTED - Enum constant in enum class org.apache.kafka.common.IsolationLevel
- Reading Transactional Messages - Search tag in class org.apache.kafka.clients.consumer.KafkaConsumer
- Section
- Reading Transactional Records - Search tag in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- Section
- readKeyValue() - Method in class org.apache.kafka.streams.TestOutputTopic
- 
Read one record from the output topic and return its key and value as pair.
- readKeyValuesToList() - Method in class org.apache.kafka.streams.TestOutputTopic
- 
Read all KeyValues from topic to List.
- readKeyValuesToMap() - Method in class org.apache.kafka.streams.TestOutputTopic
- 
Read output to map.
- ReadOnlyKeyValueStore<K,V> - Interface in org.apache.kafka.streams.state
- 
A key-value store that only supports read operations.
- ReadOnlySessionStore<K,AGG> - Interface in org.apache.kafka.streams.state
- 
A session store that only supports read operations.
- ReadOnlyWindowStore<K,V> - Interface in org.apache.kafka.streams.state
- 
A window store that only supports read operations.
- readRecord() - Method in class org.apache.kafka.streams.TestOutputTopic
- 
Read one Record from output topic.
- readRecords(InputStream) - Method in interface org.apache.kafka.tools.api.RecordReader
- 
read byte array from input stream and then generate an iterator of producer record
- readRecordsToList() - Method in class org.apache.kafka.streams.TestOutputTopic
- 
Read output to List.
- readValue() - Method in class org.apache.kafka.streams.TestOutputTopic
- 
Read one record from the output topic and return record's value.
- readValuesToList() - Method in class org.apache.kafka.streams.TestOutputTopic
- 
Read all values from topic to List.
- reason() - Method in class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupOptions
- reason(String) - Method in class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupOptions
- 
Sets an optional reason.
- ReassignmentInProgressException - Exception Class 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 class org.apache.kafka.common.errors.ReassignmentInProgressException
- ReassignmentInProgressException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.ReassignmentInProgressException
- reassignments() - Method in class org.apache.kafka.clients.admin.ListPartitionReassignmentsResult
- 
Return a future which yields a map containing each partition's reassignments
- rebalance(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- 
Simulate a rebalance event.
- RebalanceInProgressException - Exception Class in org.apache.kafka.common.errors
- RebalanceInProgressException() - Constructor for exception class org.apache.kafka.common.errors.RebalanceInProgressException
- RebalanceInProgressException(String) - Constructor for exception class org.apache.kafka.common.errors.RebalanceInProgressException
- RebalanceInProgressException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.RebalanceInProgressException
- RebalanceInProgressException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.RebalanceInProgressException
- REBALANCING - Enum constant in enum class org.apache.kafka.streams.KafkaStreams.State
- RebootstrapRequiredException - Exception Class in org.apache.kafka.common.errors
- RebootstrapRequiredException(String) - Constructor for exception class org.apache.kafka.common.errors.RebootstrapRequiredException
- RebootstrapRequiredException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.RebootstrapRequiredException
- 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
- RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
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
- RECONCILING - Enum constant in enum class org.apache.kafka.common.ConsumerGroupState
- 
Deprecated.
- RECONCILING - Enum constant in enum class org.apache.kafka.common.GroupState
- 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
- RECONFIGURABLE_CONFIGS - Static variable in class org.apache.kafka.common.metrics.JmxReporter
- reconfigurableConfigs() - Method in class org.apache.kafka.common.metrics.JmxReporter
- reconfigurableConfigs() - Method in interface org.apache.kafka.common.metrics.MetricsReporter
- reconfigurableConfigs() - Method in interface org.apache.kafka.common.Reconfigurable
- 
Returns the names of configs that may be reconfigured.
- reconfigurableConfigs() - Method in interface org.apache.kafka.common.security.auth.SslEngineFactory
- 
Returns the names of configs that may be reconfigured.
- reconfigure(Map<String, ?>) - Method in class org.apache.kafka.common.metrics.JmxReporter
- reconfigure(Map<String, ?>) - Method in interface org.apache.kafka.common.metrics.MetricsReporter
- reconfigure(Map<String, ?>) - Method in interface org.apache.kafka.common.Reconfigurable
- 
Reconfigures this instance with the given key-value pairs.
- reconfigure(Map<String, String>) - Method in class org.apache.kafka.connect.connector.Connector
- 
Reconfigure this Connector.
- reconfigure(Map<String, String>) - Method in class org.apache.kafka.connect.tools.MockSinkConnector
- reconfigure(Map<String, String>) - Method in class org.apache.kafka.connect.tools.MockSourceConnector
- 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_MAX_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
reconnect.backoff.max
- 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
- RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
reconnect.backoff.ms
- record() - Method in class org.apache.kafka.common.metrics.Sensor
- 
Record an occurrence, this is just short-hand forrecord(1.0)
- record() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedForward
- 
The record that was forwarded.
- record(double) - Method in class org.apache.kafka.common.metrics.Sensor
- 
Record a value with this sensor
- record(double) - Method in class org.apache.kafka.common.metrics.stats.Histogram
- record(double, long) - Method in class org.apache.kafka.common.metrics.Sensor
- 
Record a value at a known time.
- record(double, long, boolean) - Method in class org.apache.kafka.common.metrics.Sensor
- 
Record a value at a known time.
- record(MetricConfig, double, long) - Method in interface org.apache.kafka.common.metrics.Stat
- 
Record the given value
- record(MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.CumulativeCount
- record(MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.CumulativeSum
- record(MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Meter
- record(MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Rate
- record(MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
- record(MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.TokenBucket
- record(MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Value
- Record<K,V> - Class in org.apache.kafka.streams.processor.api
- 
A data class representing an incoming record for processing in aProcessoror a record to forward to downstream processors viaProcessorContext.
- Record(K, V, long) - Constructor for class org.apache.kafka.streams.processor.api.Record
- 
Convenience constructor in case you do not wish to specify any headers.
- Record(K, V, long, Headers) - Constructor for class org.apache.kafka.streams.processor.api.Record
- 
The full constructor, specifying all the attributes of the record.
- RecordBatchTooLargeException - Exception Class in org.apache.kafka.common.errors
- 
This record batch is larger than the maximum allowable size
- RecordBatchTooLargeException() - Constructor for exception class org.apache.kafka.common.errors.RecordBatchTooLargeException
- RecordBatchTooLargeException(String) - Constructor for exception class org.apache.kafka.common.errors.RecordBatchTooLargeException
- RecordBatchTooLargeException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.RecordBatchTooLargeException
- RecordBatchTooLargeException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.RecordBatchTooLargeException
- recordCollector() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- recordCollector() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- RecordContext - Interface in org.apache.kafka.streams.processor
- 
The context associated with the current record being processed by aProcessor
- Record Delivery and Acknowledgement - Search tag in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- Section
- RecordDeserializationException - Exception Class in org.apache.kafka.common.errors
- 
This exception is raised for any error that occurs while deserializing records received by the consumer using the configuredDeserializer.
- RecordDeserializationException(RecordDeserializationException.DeserializationExceptionOrigin, TopicPartition, long, long, TimestampType, ByteBuffer, ByteBuffer, Headers, String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.RecordDeserializationException
- RecordDeserializationException(TopicPartition, long, String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.RecordDeserializationException
- RecordDeserializationException.DeserializationExceptionOrigin - Enum Class in org.apache.kafka.common.errors
- recordLevel() - Method in class org.apache.kafka.common.metrics.MetricConfig
- recordLevel(Sensor.RecordingLevel) - Method in class org.apache.kafka.common.metrics.MetricConfig
- recordMetadata() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- recordMetadata() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
- 
Return the metadata of the current record if available.
- recordMetadata() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
- 
Return the metadata of the current topic/partition/offset if available.
- RecordMetadata - Class in org.apache.kafka.clients.producer
- 
The metadata for a record that has been acknowledged by the server
- RecordMetadata - Interface in org.apache.kafka.streams.processor.api
- RecordMetadata(TopicPartition, long, int, long, int, int) - Constructor for class org.apache.kafka.clients.producer.RecordMetadata
- 
Creates a new instance with the provided parameters.
- RecordReader - Interface in org.apache.kafka.tools.api
- 
Typical implementations of this interface convert data from an `InputStream` received via `readRecords` into a iterator of `ProducerRecord` instance.
- 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 toAdmin.deleteRecords(Map)
- RecordTooLargeException - Exception Class in org.apache.kafka.common.errors
- 
This record is larger than the maximum allowable size
- RecordTooLargeException() - Constructor for exception class org.apache.kafka.common.errors.RecordTooLargeException
- RecordTooLargeException(String) - Constructor for exception class org.apache.kafka.common.errors.RecordTooLargeException
- RecordTooLargeException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.RecordTooLargeException
- RecordTooLargeException(String, Map<TopicPartition, Long>) - Constructor for exception class org.apache.kafka.common.errors.RecordTooLargeException
- RecordTooLargeException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.RecordTooLargeException
- recordTooLargePartitions() - Method in exception class org.apache.kafka.common.errors.RecordTooLargeException
- reduce(Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
- 
Combine the values of records in this stream by the grouped key.
- reduce(Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
- 
Combine the values of records in this stream by the grouped key and defined sessions.
- reduce(Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
- 
Combine the values of records in this stream by the grouped key and defined windows.
- reduce(Reducer<V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
- 
Combine the value of records in this stream by the grouped key.
- reduce(Reducer<V>, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
- 
Combine the values of records in this stream by the grouped key and defined sessions.
- reduce(Reducer<V>, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
- 
Combine the values of records in this stream by the grouped key and defined windows.
- reduce(Reducer<V>, Named) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
- 
Combine the values of records in this stream by the grouped key and defined sessions.
- reduce(Reducer<V>, Named) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
- 
Combine the values of records in this stream by the grouped key and defined windows.
- reduce(Reducer<V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
- 
Combine the value of records in this stream by the grouped key.
- reduce(Reducer<V>, Named, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
- 
Combine the values of records in this stream by the grouped key and defined sessions.
- reduce(Reducer<V>, Named, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
- 
Combine the values of records in this stream by the grouped key and defined windows.
- reduce(Reducer<V>, Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- reduce(Reducer<V>, Reducer<V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- reduce(Reducer<V>, Reducer<V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- Reducer<V> - Interface in org.apache.kafka.streams.kstream
- 
TheReducerinterface for combining two values of the same type into a new value.
- REFERENCE_CONTAINER_PARTITION_ASSIGNOR - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- register(ConnectRestExtensionContext) - Method in interface org.apache.kafka.connect.rest.ConnectRestExtension
- 
ConnectRestExtension implementations can register custom JAX-RS resources via this method.
- register(StateStore, StateRestoreCallback) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- register(StateStore, StateRestoreCallback) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Register and possibly restores the specified storage engine.
- register(StateStore, StateRestoreCallback) - Method in interface org.apache.kafka.streams.processor.StateStoreContext
- 
Registers and possibly restores the specified storage engine.
- register(StateStore, StateRestoreCallback, CommitCallback) - Method in interface org.apache.kafka.streams.processor.StateStoreContext
- 
Registers and possibly restores the specified storage engine.
- registerMetricForSubscription(KafkaMetric) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Add the provided application metric for subscription.
- registerMetricForSubscription(KafkaMetric) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- registerMetricForSubscription(KafkaMetric) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- registerMetricForSubscription(KafkaMetric) - Method in interface org.apache.kafka.clients.consumer.Consumer
- registerMetricForSubscription(KafkaMetric) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
- 
Add the provided application metric for subscription.
- registerMetricForSubscription(KafkaMetric) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- registerMetricForSubscription(KafkaMetric) - Method in class org.apache.kafka.clients.producer.KafkaProducer
- 
Add the provided application metric for subscription.
- registerMetricForSubscription(KafkaMetric) - Method in class org.apache.kafka.clients.producer.MockProducer
- registerMetricForSubscription(KafkaMetric) - Method in interface org.apache.kafka.clients.producer.Producer
- REJECT - Enum constant in enum class org.apache.kafka.clients.consumer.AcknowledgeType
- 
The record was not consumed successfully.
- Relation to CompletionStage - Search tag in class org.apache.kafka.common.KafkaFuture
- Section
- RELEASE - Enum constant in enum class org.apache.kafka.clients.consumer.AcknowledgeType
- 
The record was not consumed successfully.
- REMOTE_COPY_BYTES_PER_SEC_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- REMOTE_COPY_LAG_BYTES_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- REMOTE_COPY_LAG_SEGMENTS_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- REMOTE_COPY_REQUESTS_PER_SEC_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- REMOTE_DELETE_LAG_BYTES_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- REMOTE_DELETE_LAG_SEGMENTS_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- REMOTE_DELETE_REQUESTS_PER_SEC_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- REMOTE_FETCH_BYTES_PER_SEC_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- REMOTE_FETCH_REQUESTS_PER_SEC_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- REMOTE_LOG_COPY_DISABLE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
- REMOTE_LOG_COPY_DISABLE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
- REMOTE_LOG_DELETE_ON_DISABLE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
- REMOTE_LOG_DELETE_ON_DISABLE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
- REMOTE_LOG_MANAGER_TASKS_AVG_IDLE_PERCENT_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- REMOTE_LOG_METADATA_COUNT_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- REMOTE_LOG_READER_AVG_IDLE_PERCENT_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- REMOTE_LOG_READER_FETCH_RATE_AND_TIME_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- REMOTE_LOG_READER_TASK_QUEUE_SIZE_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- REMOTE_LOG_SIZE_BYTES_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- REMOTE_LOG_SIZE_COMPUTATION_TIME_METRIC - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- REMOTE_LOG_STORAGE_ENABLE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
- REMOTE_LOG_STORAGE_ENABLE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
- REMOTE_STORAGE_THREAD_POOL_METRICS - Static variable in class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- RemoteClusterUtils - Class in org.apache.kafka.connect.mirror
- 
Convenience tool for multi-cluster environments.
- remoteConsumerOffsets(String, String, Duration) - Method in class org.apache.kafka.connect.mirror.MirrorClient
- 
Translates a remote consumer group's offsets into corresponding local offsets.
- RemoteLogMetadata - Class in org.apache.kafka.server.log.remote.storage
- 
Base class for remote log metadata objects likeRemoteLogSegmentMetadata,RemoteLogSegmentMetadataUpdate, andRemotePartitionDeleteMetadata.
- RemoteLogMetadataManager - Interface in org.apache.kafka.server.log.remote.storage
- 
This interface provides storing and fetching remote log segment metadata with strongly consistent semantics.
- remoteLogSegmentId() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- remoteLogSegmentId() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
- RemoteLogSegmentId - Class in org.apache.kafka.server.log.remote.storage
- 
This class represents a universally unique identifier associated to a topic partition's log segment.
- RemoteLogSegmentId(TopicIdPartition, Uuid) - Constructor for class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentId
- remoteLogSegmentMetadata(TopicIdPartition, int, long) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
- 
ReturnsRemoteLogSegmentMetadataif it exists for the given topic partition containing the offset with the given leader-epoch for the offset, else returnsOptional.empty().
- RemoteLogSegmentMetadata - Class in org.apache.kafka.server.log.remote.storage
- 
It describes the metadata about a topic partition's remote log segment in the remote storage.
- RemoteLogSegmentMetadata(RemoteLogSegmentId, long, long, long, int, long, int, Map<Integer, Long>) - Constructor for class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- 
Creates an instance with the given metadata of remote log segment and its state asRemoteLogSegmentState.COPY_SEGMENT_STARTED.
- RemoteLogSegmentMetadata(RemoteLogSegmentId, long, long, long, int, long, int, Map<Integer, Long>, boolean) - Constructor for class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- 
Creates an instance with the given metadata of remote log segment and its state asRemoteLogSegmentState.COPY_SEGMENT_STARTED.
- RemoteLogSegmentMetadata(RemoteLogSegmentId, long, long, long, int, long, int, Optional<RemoteLogSegmentMetadata.CustomMetadata>, RemoteLogSegmentState, Map<Integer, Long>) - Constructor for class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- 
Creates an instance with the given metadata of remote log segment.
- RemoteLogSegmentMetadata(RemoteLogSegmentId, long, long, long, int, long, int, Optional<RemoteLogSegmentMetadata.CustomMetadata>, RemoteLogSegmentState, Map<Integer, Long>, boolean) - Constructor for class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- 
Creates an instance with the given metadata of remote log segment.
- RemoteLogSegmentMetadata.CustomMetadata - Class in org.apache.kafka.server.log.remote.storage
- 
Custom metadata from aRemoteStorageManagerplugin.
- RemoteLogSegmentMetadataUpdate - Class in org.apache.kafka.server.log.remote.storage
- 
It describes the metadata update about the log segment in the remote storage.
- RemoteLogSegmentMetadataUpdate(RemoteLogSegmentId, long, Optional<RemoteLogSegmentMetadata.CustomMetadata>, RemoteLogSegmentState, int) - Constructor for class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
- RemoteLogSegmentState - Enum Class in org.apache.kafka.server.log.remote.storage
- 
This enum indicates the state of the remote log segment.
- remoteLogSize(TopicIdPartition, int) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
- 
Returns total size of the log for the given leader epoch in remote storage.
- RemotePartitionDeleteMetadata - Class in org.apache.kafka.server.log.remote.storage
- 
This class represents the metadata about the remote partition.
- RemotePartitionDeleteMetadata(TopicIdPartition, RemotePartitionDeleteState, long, int) - Constructor for class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteMetadata
- 
Creates an instance of this class with the given metadata.
- RemotePartitionDeleteState - Enum Class in org.apache.kafka.server.log.remote.storage
- 
This enum indicates the deletion state of the remote topic partition.
- RemoteResourceNotFoundException - Exception Class in org.apache.kafka.server.log.remote.storage
- 
Exception thrown when a resource is not found on the remote storage.
- RemoteResourceNotFoundException(String) - Constructor for exception class org.apache.kafka.server.log.remote.storage.RemoteResourceNotFoundException
- RemoteResourceNotFoundException(String, Throwable) - Constructor for exception class org.apache.kafka.server.log.remote.storage.RemoteResourceNotFoundException
- RemoteResourceNotFoundException(Throwable) - Constructor for exception class org.apache.kafka.server.log.remote.storage.RemoteResourceNotFoundException
- RemoteStorageException - Exception Class in org.apache.kafka.server.log.remote.storage
- 
Exception thrown when there is a remote storage error.
- RemoteStorageException(String) - Constructor for exception class org.apache.kafka.server.log.remote.storage.RemoteStorageException
- RemoteStorageException(String, Throwable) - Constructor for exception class org.apache.kafka.server.log.remote.storage.RemoteStorageException
- RemoteStorageException(Throwable) - Constructor for exception class org.apache.kafka.server.log.remote.storage.RemoteStorageException
- RemoteStorageManager - Interface in org.apache.kafka.server.log.remote.storage
- 
This interface provides the lifecycle of remote log segments that includes copy, fetch, and delete from remote storage.
- RemoteStorageManager.IndexType - Enum Class in org.apache.kafka.server.log.remote.storage
- 
Type of the index file.
- RemoteStorageMetrics - Class in org.apache.kafka.server.log.remote.storage
- 
This class contains the metrics related to tiered storage feature, which is to have a centralized place to store them, so that we can verify all of them easily.
- RemoteStorageMetrics() - Constructor for class org.apache.kafka.server.log.remote.storage.RemoteStorageMetrics
- remoteTopics() - Method in class org.apache.kafka.connect.mirror.MirrorClient
- 
Finds all remote topics on this cluster.
- remoteTopics(String) - Method in class org.apache.kafka.connect.mirror.MirrorClient
- 
Finds all remote topics that have been replicated directly from the given source cluster.
- remove(String) - Method in interface org.apache.kafka.common.header.Headers
- 
Removes all headers for the given key returning if the operation succeeded.
- remove(String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- remove(String) - Method in interface org.apache.kafka.connect.header.Headers
- remove(Windowed<K>) - Method in interface org.apache.kafka.streams.state.SessionStore
- 
Remove the session aggregated with providedWindowedkey from the store
- removeAll() - Method in class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupOptions
- removeMembersFromConsumerGroup(String, RemoveMembersFromConsumerGroupOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Remove members from the consumer group by given member identities.
- removeMembersFromConsumerGroup(String, RemoveMembersFromConsumerGroupOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- removeMembersFromConsumerGroup(String, RemoveMembersFromConsumerGroupOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- RemoveMembersFromConsumerGroupOptions - Class in org.apache.kafka.clients.admin
- RemoveMembersFromConsumerGroupOptions() - Constructor for class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupOptions
- RemoveMembersFromConsumerGroupOptions(Collection<MemberToRemove>) - Constructor for class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupOptions
- RemoveMembersFromConsumerGroupResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.removeMembersFromConsumerGroup(String, RemoveMembersFromConsumerGroupOptions)call.
- removeMetric(MetricName) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Remove a metric if it exists and return it.
- 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 the quorum.
- removeRaftVoter(int, Uuid) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Remove a voter node from the KRaft metadata quorum.
- removeRaftVoter(int, Uuid, RemoveRaftVoterOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Remove a voter node from the KRaft metadata quorum.
- removeRaftVoter(int, Uuid, RemoveRaftVoterOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- removeRaftVoter(int, Uuid, RemoveRaftVoterOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- RemoveRaftVoterOptions - Class in org.apache.kafka.clients.admin
- RemoveRaftVoterOptions() - Constructor for class org.apache.kafka.clients.admin.RemoveRaftVoterOptions
- RemoveRaftVoterResult - Class in org.apache.kafka.clients.admin
- removeReporter(MetricsReporter) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Remove a MetricReporter
- removeSensor(String) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Remove a sensor (if it exists), associated metrics and its children.
- removeSensor(Sensor) - Method in interface org.apache.kafka.streams.StreamsMetrics
- 
Remove a sensor.
- removeStreamThread() - Method in class org.apache.kafka.streams.KafkaStreams
- 
Removes one stream thread out of the running stream threads from this Kafka Streams client.
- removeStreamThread(Duration) - Method in class org.apache.kafka.streams.KafkaStreams
- 
Removes one stream thread out of the running stream threads from this Kafka Streams client.
- removeTask(KafkaStreamsAssignment.AssignedTask) - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment
- removingReplicas() - Method in class org.apache.kafka.clients.admin.PartitionReassignment
- 
The brokers that we are removing this partition from as part of a reassignment.
- rename(String) - Method in interface org.apache.kafka.connect.header.Header
- 
Return a newHeaderobject that has the same schema and value but with the supplied key.
- renewDelegationToken(byte[]) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Renew a Delegation Token.
- renewDelegationToken(byte[], RenewDelegationTokenOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Renew a Delegation Token.
- renewDelegationToken(byte[], RenewDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- 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
- 
The result of theKafkaAdminClient.expireDelegationToken(byte[], ExpireDelegationTokenOptions)call.
- 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
- repartition() - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Materialize this stream to an auto-generated repartition topic and create a newKStreamfrom the auto-generated topic using default serializers, deserializers, and producer's default partitioning strategy.
- repartition(Repartitioned<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Materialize this stream to an auto-generated repartition topic and create a newKStreamfrom the auto-generated topic usingkey serde,value serde,StreamPartitioner, number of partitions, and topic name part as defined byRepartitioned.
- REPARTITION_PURGE_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
repartition.purge.interval.ms
- Repartitioned<K,V> - Class in org.apache.kafka.streams.kstream
- 
This class is used to provide the optional parameters for internal repartition topics.
- REPLACE_THREAD - Enum constant in enum class org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
- 
Replace the failed thread with a new one.
- replicaDirectoryId() - Method in class org.apache.kafka.clients.admin.QuorumInfo.ReplicaState
- 
Return the directory id of the replica if configured, or Uuid.ZERO_UUID if not.
- replicaId() - Method in class org.apache.kafka.clients.admin.QuorumInfo.ReplicaState
- 
Return the ID for this replica.
- ReplicaInfo - Class in org.apache.kafka.clients.admin
- 
A description of a replica on a particular broker.
- ReplicaInfo(long, long, boolean) - Constructor for class org.apache.kafka.clients.admin.ReplicaInfo
- replicaInfos() - Method in class org.apache.kafka.clients.admin.LogDirDescription
- 
A map from topic partition to replica information for that partition in this log directory.
- ReplicaNotAvailableException - Exception Class in org.apache.kafka.common.errors
- 
The replica is not available for the requested topic partition.
- ReplicaNotAvailableException(String) - Constructor for exception class org.apache.kafka.common.errors.ReplicaNotAvailableException
- ReplicaNotAvailableException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.ReplicaNotAvailableException
- ReplicaNotAvailableException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.ReplicaNotAvailableException
- replicas() - Method in class org.apache.kafka.clients.admin.PartitionReassignment
- 
The brokers which this partition currently resides on.
- 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.
- REPLICATION_FACTOR_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
replication.factor
- REPLICATION_POLICY_CLASS - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- REPLICATION_POLICY_CLASS_DEFAULT - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- REPLICATION_POLICY_SEPARATOR - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- REPLICATION_POLICY_SEPARATOR_DEFAULT - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- replicationFactor() - Method in class org.apache.kafka.clients.admin.CreateTopicsResult.TopicMetadataAndConfig
- 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.
- replicationFactor(String) - Method in class org.apache.kafka.clients.admin.CreateTopicsResult
- 
Returns a future that provides replication factor for the topic when the request completes.
- replicationHops(String) - Method in class org.apache.kafka.connect.mirror.MirrorClient
- 
Computes the shortest number of hops from an upstream source cluster.
- replicationHops(Map<String, Object>, String) - Static method in class org.apache.kafka.connect.mirror.RemoteClusterUtils
- 
Finds the shortest number of hops from an upstream cluster.
- replicationPolicy() - Method in class org.apache.kafka.connect.mirror.MirrorClient
- 
Gets theReplicationPolicyinstance used to interpret remote topics.
- replicationPolicy() - Method in class org.apache.kafka.connect.mirror.MirrorClientConfig
- ReplicationPolicy - Interface in org.apache.kafka.connect.mirror
- 
An interface used by the MirrorMaker connectors to manage topics names between source and target clusters.
- report(SinkRecord, Throwable) - Method in interface org.apache.kafka.connect.sink.ErrantRecordReporter
- 
Report a problematic record and the corresponding error to be written to the sink connector's dead letter queue (DLQ).
- reporters() - Method in class org.apache.kafka.common.metrics.Metrics
- REQUEST - Enum constant in enum class 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
- REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
request.timeout.ms
- requestCommit() - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
- 
Request an offset commit.
- REQUESTED - Enum constant in enum class org.apache.kafka.common.config.SslClientAuth
- 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.
- requestTaskReconfiguration() - Method in interface org.apache.kafka.connect.connector.ConnectorContext
- 
Requests that the runtime reconfigure the Tasks for this source.
- requestType() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
- 
16-bit API key of the request from the request header.
- requestVersion() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
- 
Returns the request version from the request header.
- requireActive() - Method in class org.apache.kafka.streams.query.StateQueryRequest
- 
Specifies that this query should only run on partitions for which this instance is the leader (aka "active").
- required() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- 
Set this schema as required.
- REQUIRED - Enum constant in enum class org.apache.kafka.common.config.SslClientAuth
- requireStable() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsOptions
- requireStable(boolean) - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsOptions
- 
Sets an optional requireStable flag.
- RESERVED - Static variable in class org.apache.kafka.common.Uuid
- 
The set of reserved UUIDs that will never be returned by the randomUuid method.
- resetCommit() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- 
Reset the commit capture tofalse(whether or not it was previouslytrue).
- resetCommit() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.Reset the commit capture tofalse(whether or not it was previouslytrue).
- resetForwards() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- 
Clear the captured forwarded data.
- resetForwards() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.Clear the captured forwarded data.
- resetShouldRebalance() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- resolveDslStoreSuppliers() - Method in class org.apache.kafka.streams.TopologyConfig
- resource() - Method in exception class org.apache.kafka.common.errors.DuplicateResourceException
- resource() - Method in exception class org.apache.kafka.common.errors.ResourceNotFoundException
- 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.
- ResourceNotFoundException - Exception Class in org.apache.kafka.common.errors
- 
Exception thrown due to a request for a resource that does not exist.
- ResourceNotFoundException(String) - Constructor for exception class org.apache.kafka.common.errors.ResourceNotFoundException
- 
Constructor
- ResourceNotFoundException(String, String) - Constructor for exception class org.apache.kafka.common.errors.ResourceNotFoundException
- 
Constructor
- ResourceNotFoundException(String, String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.ResourceNotFoundException
- 
Constructor
- ResourceNotFoundException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.ResourceNotFoundException
- resourcePattern() - Method in class org.apache.kafka.server.authorizer.Action
- ResourcePattern - Class in org.apache.kafka.common.resource
- 
Represents a pattern that is used by ACLs to match zero or moreResources.
- 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 matchResourcePattern.
- ResourcePatternFilter(ResourceType, String, PatternType) - Constructor for class org.apache.kafka.common.resource.ResourcePatternFilter
- 
Create a filter using the supplied parameters.
- resourceReferenceCount() - Method in class org.apache.kafka.server.authorizer.Action
- 
Number of times the resource being authorized is referenced within the request.
- resourceType() - Method in class org.apache.kafka.common.resource.Resource
- 
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 Class in org.apache.kafka.common.resource
- 
Represents a type of resource which an ACL can be applied to.
- restore(byte[], byte[]) - Method in interface org.apache.kafka.streams.processor.BatchingStateRestoreCallback
- restore(byte[], byte[]) - Method in interface org.apache.kafka.streams.processor.StateRestoreCallback
- RESTORE_CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Prefix used to overrideconsumerconfigs for the restore consumer client from the general consumer client configs.
- restoreAll(Collection<KeyValue<byte[], byte[]>>) - Method in interface org.apache.kafka.streams.processor.BatchingStateRestoreCallback
- 
Called to restore a number of records.
- restoreConsumerClientId() - Method in interface org.apache.kafka.streams.ThreadMetadata
- 
Client ID of the restore Kafka consumer used by the stream thread
- restoreConsumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
- 
Prefix a property withStreamsConfig.RESTORE_CONSUMER_PREFIX.
- resultOrder() - Method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
- 
The order of the returned records by timestamp.
- resultOrder() - Method in class org.apache.kafka.streams.query.RangeQuery
- 
Determines if the serialized byte[] of the keys in ascending or descending or unordered order.
- resultOrder() - Method in class org.apache.kafka.streams.query.TimestampedRangeQuery
- 
Determines if the serialized byte[] of the keys in ascending or descending or unordered order.
- ResultOrder - Enum Class in org.apache.kafka.streams.query
- resume() - Method in class org.apache.kafka.streams.KafkaStreams
- 
This method resumes processing for the KafkaStreams instance.
- 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 withKafkaConsumer.pause(Collection).
- resume(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- resume(TopicPartition...) - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
- 
Resume consumption of messages from previously paused TopicPartitions.
- retainDuplicates() - Method in class org.apache.kafka.streams.state.DslWindowParams
- retainDuplicates() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
- 
Whether or not this store is retaining duplicate keys.
- retainLatest() - Method in class org.apache.kafka.connect.header.ConnectHeaders
- retainLatest() - Method in interface org.apache.kafka.connect.header.Headers
- 
Removes all but the lastHeaderobject with each key.
- retainLatest(String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- retainLatest(String) - Method in interface org.apache.kafka.connect.header.Headers
- 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
- retentionPeriod() - Method in class org.apache.kafka.streams.state.DslSessionParams
- retentionPeriod() - Method in class org.apache.kafka.streams.state.DslWindowParams
- retentionPeriod() - Method in interface org.apache.kafka.streams.state.SessionBytesStoreSupplier
- 
The time period for which theSessionStorewill retain historic data.
- retentionPeriod() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
- 
The time period for which theWindowStorewill retain historic data.
- RetriableCommitFailedException - Exception Class in org.apache.kafka.clients.consumer
- RetriableCommitFailedException(String) - Constructor for exception class org.apache.kafka.clients.consumer.RetriableCommitFailedException
- RetriableCommitFailedException(String, Throwable) - Constructor for exception class org.apache.kafka.clients.consumer.RetriableCommitFailedException
- RetriableCommitFailedException(Throwable) - Constructor for exception class org.apache.kafka.clients.consumer.RetriableCommitFailedException
- RetriableException - Exception Class in org.apache.kafka.common.errors
- 
A retriable exception is a transient exception that if retried may succeed.
- RetriableException - Exception Class in org.apache.kafka.connect.errors
- 
An exception that indicates the operation can be reattempted.
- RetriableException() - Constructor for exception class org.apache.kafka.common.errors.RetriableException
- RetriableException(String) - Constructor for exception class org.apache.kafka.common.errors.RetriableException
- RetriableException(String) - Constructor for exception class org.apache.kafka.connect.errors.RetriableException
- RetriableException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.RetriableException
- RetriableException(String, Throwable) - Constructor for exception class org.apache.kafka.connect.errors.RetriableException
- RetriableException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.RetriableException
- RetriableException(Throwable) - Constructor for exception class org.apache.kafka.connect.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 - Enum constant in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
- 
Retry the failed operation.
- RETRY_BACKOFF_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- 
retry.backoff.max.ms
- RETRY_BACKOFF_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- 
retry.backoff.max.ms
- RETRY_BACKOFF_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
retry.backoff.max.ms
- 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
- RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
retry.backoff.ms
- retryOnQuotaViolation(boolean) - Method in class org.apache.kafka.clients.admin.CreatePartitionsOptions
- 
Set to true if quota violation should be automatically retried.
- retryOnQuotaViolation(boolean) - Method in class org.apache.kafka.clients.admin.CreateTopicsOptions
- 
Set to true if quota violation should be automatically retried.
- retryOnQuotaViolation(boolean) - Method in class org.apache.kafka.clients.admin.DeleteTopicsOptions
- 
Set to true if quota violation should be automatically retried.
- REUSE_KTABLE_SOURCE_TOPICS - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"topology.optimization"for enabling the specific optimization that reuses source topic as changelog topic for KTables.
- reverseAll() - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
- 
Return a reverse iterator over all keys in this store.
- reverseRange(K, K) - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
- 
Get a reverse iterator over a given range of keys.
- ROCKS_DB - Enum constant in enum class org.apache.kafka.streams.kstream.Materialized.StoreType
- ROCKS_DB - Static variable in class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers
- ROCKS_DB - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- ROCKSDB_CONFIG_SETTER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
rocksdb.config.setter
- RocksDBConfigSetter - Interface in org.apache.kafka.streams.state
- 
An interface to that allows developers to customize the RocksDB settings for a given Store.
- RocksDBDslStoreSuppliers() - Constructor for class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers.RocksDBDslStoreSuppliers
- ROUNDROBIN_ASSIGNOR_NAME - Static variable in class org.apache.kafka.clients.consumer.RoundRobinAssignor
- RoundRobinAssignor - Class in org.apache.kafka.clients.consumer
- 
The round robin assignor lays out all the available partitions and all the available consumers.
- RoundRobinAssignor() - Constructor for class org.apache.kafka.clients.consumer.RoundRobinAssignor
- RoundRobinPartitioner - Class in org.apache.kafka.clients.producer
- 
The "Round-Robin" partitioner This partitioning strategy can be used when user wants to distribute the writes to all partitions equally.
- RoundRobinPartitioner() - Constructor for class org.apache.kafka.clients.producer.RoundRobinPartitioner
- Rules of forming the resulting map - Search tag in interface org.apache.kafka.streams.kstream.BranchedKStream
- Section
- RUNNING - Enum constant in enum class org.apache.kafka.streams.KafkaStreams.State
S
- SAFE_DOWNGRADE - Enum constant in enum class org.apache.kafka.clients.admin.FeatureUpdate.UpgradeType
- salt() - Method in class org.apache.kafka.clients.admin.UserScramCredentialUpsertion
- salt() - Method in class org.apache.kafka.common.security.scram.ScramCredential
- 
Returns the salt used to process this credential using the SCRAM algorithm.
- SampledStat - Class in org.apache.kafka.common.metrics.stats
- 
A SampledStat records a single scalar value measured over one or more samples.
- SampledStat(double) - Constructor for class org.apache.kafka.common.metrics.stats.SampledStat
- samples() - Method in class org.apache.kafka.common.metrics.MetricConfig
- samples(int) - Method in class org.apache.kafka.common.metrics.MetricConfig
- 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_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_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_CONNECT_TIMEOUT_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_LOGIN_CONNECT_TIMEOUT_MS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_LOGIN_READ_TIMEOUT_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_LOGIN_READ_TIMEOUT_MS_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_LOGIN_RETRY_BACKOFF_MAX_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_LOGIN_RETRY_BACKOFF_MAX_MS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_LOGIN_RETRY_BACKOFF_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_LOGIN_RETRY_BACKOFF_MS_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_OAUTHBEARER_CLOCK_SKEW_SECONDS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_CLOCK_SKEW_SECONDS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_EXPECTED_AUDIENCE - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_EXPECTED_AUDIENCE_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_EXPECTED_ISSUER - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_EXPECTED_ISSUER_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_HEADER_URLENCODE - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_HEADER_URLENCODE_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_JWKS_ENDPOINT_REFRESH_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_JWKS_ENDPOINT_REFRESH_MS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_JWKS_ENDPOINT_RETRY_BACKOFF_MAX_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_JWKS_ENDPOINT_RETRY_BACKOFF_MAX_MS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_JWKS_ENDPOINT_RETRY_BACKOFF_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_JWKS_ENDPOINT_RETRY_BACKOFF_MS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_JWKS_ENDPOINT_URL - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_JWKS_ENDPOINT_URL_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_SCOPE_CLAIM_NAME - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_SCOPE_CLAIM_NAME_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_SUB_CLAIM_NAME - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_SUB_CLAIM_NAME_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_TOKEN_ENDPOINT_URL - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_OAUTHBEARER_TOKEN_ENDPOINT_URL_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
- SASL_PLAINTEXT - Enum constant in enum class org.apache.kafka.common.security.auth.SecurityProtocol
- 
SASL authenticated, non-encrypted channel
- SASL_SSL - Enum constant in enum class 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
- SaslAuthenticationContext(SaslServer, SecurityProtocol, InetAddress, String, Optional<SSLSession>) - Constructor for class org.apache.kafka.common.security.auth.SaslAuthenticationContext
- SaslAuthenticationException - Exception Class in org.apache.kafka.common.errors
- 
This exception indicates that SASL authentication has failed.
- SaslAuthenticationException(String) - Constructor for exception class org.apache.kafka.common.errors.SaslAuthenticationException
- SaslAuthenticationException(String, Throwable) - Constructor for exception class 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
- SCALE_FIELD - Static variable in class org.apache.kafka.connect.data.Decimal
- schedule(Duration, PunctuationType, Punctuator) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- schedule(Duration, PunctuationType, Punctuator) - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
- 
Schedule a periodic operation for processors.
- schedule(Duration, PunctuationType, Punctuator) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- schedule(Duration, PunctuationType, Punctuator) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Schedule a periodic operation for processors.
- scheduledPunctuators() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- 
Get the punctuators scheduled so far.
- scheduledPunctuators() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.Get the punctuators scheduled so far.
- 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().
- schema() - Method in class org.apache.kafka.connect.data.ConnectSchema
- schema() - Method in class org.apache.kafka.connect.data.Field
- 
Get the schema of this field
- schema() - Method in interface org.apache.kafka.connect.data.Schema
- 
Return a concrete instance of theSchema
- schema() - Method in class org.apache.kafka.connect.data.SchemaAndValue
- schema() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- 
Return a concrete instance of theSchemaspecified by this builder
- schema() - Method in class org.apache.kafka.connect.data.Struct
- 
Get the schema for this Struct.
- schema() - Method in interface org.apache.kafka.connect.header.Header
- 
Return theSchemaassociated with this header, if there is one.
- schema(int) - Static method in class org.apache.kafka.connect.data.Decimal
- Schema - Interface in org.apache.kafka.connect.data
- 
Definition of an abstract data type.
- SCHEMA - Static variable in class org.apache.kafka.connect.data.Date
- SCHEMA - Static variable in class org.apache.kafka.connect.data.Time
- SCHEMA - Static variable in class org.apache.kafka.connect.data.Timestamp
- Schema.Type - Enum Class in org.apache.kafka.connect.data
- 
The type of a schema.
- SchemaAndValue - Class in org.apache.kafka.connect.data
- 
A composite containing aSchemaand associated value
- SchemaAndValue(Schema, Object) - Constructor for class org.apache.kafka.connect.data.SchemaAndValue
- SchemaBuilder - Class in org.apache.kafka.connect.data
- 
SchemaBuilder provides a fluent API for constructingSchemaobjects.
- SchemaBuilder(Schema.Type) - Constructor for class org.apache.kafka.connect.data.SchemaBuilder
- SchemaBuilderException - Exception Class in org.apache.kafka.connect.errors
- 
Indicates an error while building a schema viaSchemaBuilder
- SchemaBuilderException(String) - Constructor for exception class org.apache.kafka.connect.errors.SchemaBuilderException
- SchemaBuilderException(String, Throwable) - Constructor for exception class org.apache.kafka.connect.errors.SchemaBuilderException
- SchemaBuilderException(Throwable) - Constructor for exception class org.apache.kafka.connect.errors.SchemaBuilderException
- SchemaProjector - Class in org.apache.kafka.connect.data
- 
SchemaProjector is a utility to project a value between compatible schemas and throw exceptions when non compatible schemas are provided.
- SchemaProjector() - Constructor for class org.apache.kafka.connect.data.SchemaProjector
- SchemaProjectorException - Exception Class in org.apache.kafka.connect.errors
- 
Indicates an error while projecting a schema viaSchemaProjector
- SchemaProjectorException(String) - Constructor for exception class org.apache.kafka.connect.errors.SchemaProjectorException
- SchemaProjectorException(String, Throwable) - Constructor for exception class org.apache.kafka.connect.errors.SchemaProjectorException
- SchemaProjectorException(Throwable) - Constructor for exception class org.apache.kafka.connect.errors.SchemaProjectorException
- SchemaSourceConnector - Class in org.apache.kafka.connect.tools
- 
A simple source connector that is capable of producing static data withStructschemas.
- SchemaSourceConnector() - Constructor for class org.apache.kafka.connect.tools.SchemaSourceConnector
- SchemaSourceTask - Class in org.apache.kafka.connect.tools
- 
Task implementation forSchemaSourceConnector.
- SchemaSourceTask() - Constructor for class org.apache.kafka.connect.tools.SchemaSourceTask
- schemaType(Class<?>) - Static method in class org.apache.kafka.connect.data.ConnectSchema
- 
Get theSchema.Typeassociated with the given class.
- scope() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
- 
The token's scope of access, as per RFC 6749 Section 1.4
- SCOPE_CONFIG - Static variable in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- SCOPE_DOC - Static variable in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- SCRAM_SHA_256 - Enum constant in enum class org.apache.kafka.clients.admin.ScramMechanism
- SCRAM_SHA_512 - Enum constant in enum class org.apache.kafka.clients.admin.ScramMechanism
- 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
- ScramCredentialInfo - Class in org.apache.kafka.clients.admin
- 
Mechanism and iterations for a SASL/SCRAM credential associated with a user.
- ScramCredentialInfo(ScramMechanism, int) - Constructor for class org.apache.kafka.clients.admin.ScramCredentialInfo
- 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
- ScramMechanism - Enum Class in org.apache.kafka.clients.admin
- 
Representation of a SASL/SCRAM Mechanism.
- SECURITY_PROTOCOL_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- SECURITY_PROTOCOL_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
security.protocol
- SECURITY_PROVIDERS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- 
security.providers
- SECURITY_PROVIDERS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- 
security.providers
- SECURITY_PROVIDERS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
security.providers
- SECURITY_PROVIDERS_CONFIG - Static variable in class org.apache.kafka.common.config.SecurityConfig
- SECURITY_PROVIDERS_DOC - Static variable in class org.apache.kafka.common.config.SecurityConfig
- SecurityConfig - Class in org.apache.kafka.common.config
- 
Contains the common security config for SSL and SASL
- SecurityConfig() - Constructor for class org.apache.kafka.common.config.SecurityConfig
- SecurityDisabledException - Exception Class in org.apache.kafka.common.errors
- 
An error indicating that security is disabled on the broker.
- SecurityDisabledException(String) - Constructor for exception class org.apache.kafka.common.errors.SecurityDisabledException
- SecurityDisabledException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.SecurityDisabledException
- securityProtocol() - Method in class org.apache.kafka.common.Endpoint
- 
Returns the security protocol of this endpoint.
- 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() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
- 
Returns the security protocol for the listener on which request was received.
- SecurityProtocol - Enum Class in org.apache.kafka.common.security.auth
- SecurityProviderCreator - Interface in org.apache.kafka.common.security.auth
- 
An interface for generating security providers.
- 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 nextpoll(timeout).
- seek(TopicPartition, long) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- seek(TopicPartition, OffsetAndMetadata) - Method in interface org.apache.kafka.clients.consumer.Consumer
- seek(TopicPartition, OffsetAndMetadata) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
- 
Overrides the fetch offsets that the consumer will use on the nextpoll(timeout).
- seek(TopicPartition, OffsetAndMetadata) - 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
- 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
- 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
- segmentIntervalMs() - Method in interface org.apache.kafka.streams.state.SessionBytesStoreSupplier
- 
The size of a segment, in milliseconds.
- segmentIntervalMs() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
- 
The size of the segments (in milliseconds) the store has.
- segmentLeaderEpochs() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- segmentSizeInBytes() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- selectKey(KeyValueMapper<? super K, ? super V, ? extends KR>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Set a new key (with possibly new type) for each input record.
- selectKey(KeyValueMapper<? super K, ? super V, ? extends KR>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Set a new key (with possibly new type) for each input record.
- 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
- SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
send.buffer.bytes
- sendException - Variable in class org.apache.kafka.clients.producer.MockProducer
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in class org.apache.kafka.clients.producer.KafkaProducer
- 
Sends a list of specified offsets to the consumer group coordinator, and also marks those offsets as part of the current transaction.
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in class org.apache.kafka.clients.producer.MockProducer
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in interface org.apache.kafka.clients.producer.Producer
- sendOffsetsToTransactionException - Variable in class org.apache.kafka.clients.producer.MockProducer
- sensor(String) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Get or create a sensor with the given unique name and no parent sensors.
- sensor(String, MetricConfig, long, Sensor...) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Get or create a sensor with the given unique name and zero or more parent sensors.
- sensor(String, MetricConfig, long, Sensor.RecordingLevel, Sensor...) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Get or create a sensor with the given unique name and zero or more parent sensors.
- sensor(String, MetricConfig, Sensor...) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Get or create a sensor with the given unique name and zero or more parent sensors.
- sensor(String, MetricConfig, Sensor.RecordingLevel, Sensor...) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Get or create a sensor with the given unique name and zero or more parent sensors.
- sensor(String, Sensor...) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Get or create a sensor with the given unique name and zero or more parent sensors.
- sensor(String, Sensor.RecordingLevel) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Get or create a sensor with the given unique name and no parent sensors and with a given recording level.
- sensor(String, Sensor.RecordingLevel, Sensor...) - Method in class org.apache.kafka.common.metrics.Metrics
- 
Get or create a sensor with the given unique name and zero or more parent sensors.
- Sensor - Class in org.apache.kafka.common.metrics
- 
A sensor applies a continuous sequence of numerical values to a set of associated metrics.
- Sensor.RecordingLevel - Enum Class in org.apache.kafka.common.metrics
- sentOffsets() - Method in class org.apache.kafka.clients.producer.MockProducer
- SEPARATOR_CONFIG - Static variable in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
- SEPARATOR_DEFAULT - Static variable in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
- 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.BooleanSerde - Class in org.apache.kafka.common.serialization
- 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.ListSerde<Inner> - 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.VoidSerde - Class in org.apache.kafka.common.serialization
- Serdes.WrapperSerde<T> - Class in org.apache.kafka.common.serialization
- SerializationException - Exception Class in org.apache.kafka.common.errors
- 
Any exception during serialization in the producer
- SerializationException() - Constructor for exception class org.apache.kafka.common.errors.SerializationException
- SerializationException(String) - Constructor for exception class org.apache.kafka.common.errors.SerializationException
- SerializationException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.SerializationException
- SerializationException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.SerializationException
- serialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ByteArraySerializer
- serialize(String, Boolean) - Method in class org.apache.kafka.common.serialization.BooleanSerializer
- 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, Void) - Method in class org.apache.kafka.common.serialization.VoidSerializer
- serialize(String, ByteBuffer) - Method in class org.apache.kafka.common.serialization.ByteBufferSerializer
- serialize(String, List<Inner>) - Method in class org.apache.kafka.common.serialization.ListSerializer
- serialize(String, UUID) - Method in class org.apache.kafka.common.serialization.UUIDSerializer
- serialize(String, Headers, T) - Method in interface org.apache.kafka.common.serialization.Serializer
- 
Convertdatainto a byte array.
- serialize(String, Bytes) - Method in class org.apache.kafka.common.serialization.BytesSerializer
- serialize(String, Windowed<T>) - Method in class org.apache.kafka.streams.kstream.SessionWindowedSerializer
- serialize(String, Windowed<T>) - Method in class org.apache.kafka.streams.kstream.TimeWindowedSerializer
- serialize(String, T) - Method in interface org.apache.kafka.common.serialization.Serializer
- 
Convertdatainto a byte array.
- serialize(KafkaPrincipal) - Method in interface org.apache.kafka.common.security.auth.KafkaPrincipalSerde
- 
Serialize aKafkaPrincipalinto byte array.
- serializeBaseKey(String, Windowed<T>) - Method in class org.apache.kafka.streams.kstream.SessionWindowedSerializer
- serializeBaseKey(String, Windowed<T>) - Method in class org.apache.kafka.streams.kstream.TimeWindowedSerializer
- 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
- SessionBytesStoreSupplier - Interface in org.apache.kafka.streams.state
- 
A store supplier that can be used to create one or moreSessionStore<Byte, byte[]>instances.
- sessionStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
- 
AQueryableStoreTypethat acceptsReadOnlySessionStore.
- sessionStore(DslSessionParams) - Method in enum class org.apache.kafka.streams.kstream.Materialized.StoreType
- sessionStore(DslSessionParams) - Method in class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers.InMemoryDslStoreSuppliers
- sessionStore(DslSessionParams) - Method in class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers.RocksDBDslStoreSuppliers
- sessionStore(DslSessionParams) - Method in interface org.apache.kafka.streams.state.DslStoreSuppliers
- SessionStore<K,AGG> - Interface in org.apache.kafka.streams.state
- 
Interface for storing the aggregated values of sessions.
- sessionStoreBuilder(SessionBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
- 
Creates aStoreBuilderthat can be used to build aSessionStore.
- SessionWindowedCogroupedKStream<K,V> - Interface in org.apache.kafka.streams.kstream
- 
SessionWindowedCogroupKStreamis an abstraction of a windowed record stream ofKeyValuepairs.
- SessionWindowedDeserializer<T> - Class in org.apache.kafka.streams.kstream
- SessionWindowedDeserializer() - Constructor for class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
- SessionWindowedDeserializer(Deserializer<T>) - Constructor for class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
- SessionWindowedKStream<K,V> - Interface in org.apache.kafka.streams.kstream
- 
SessionWindowedKStreamis an abstraction of a windowed record stream ofKeyValuepairs.
- SessionWindowedSerde() - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.SessionWindowedSerde
- SessionWindowedSerde(Serde<T>) - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.SessionWindowedSerde
- sessionWindowedSerdeFrom(Class<T>) - Static method in class org.apache.kafka.streams.kstream.WindowedSerdes
- 
Construct aSessionWindowedSerdeobject for the specified inner class type.
- SessionWindowedSerializer<T> - Class in org.apache.kafka.streams.kstream
- SessionWindowedSerializer() - Constructor for class org.apache.kafka.streams.kstream.SessionWindowedSerializer
- SessionWindowedSerializer(Serializer<T>) - Constructor for class org.apache.kafka.streams.kstream.SessionWindowedSerializer
- SessionWindows - Class in org.apache.kafka.streams.kstream
- 
A session based window specification used for aggregating events into sessions.
- SET - Enum constant in enum class org.apache.kafka.clients.admin.AlterConfigOp.OpType
- 
Set the value of the configuration entry.
- setAcknowledgementCommitCallback(AcknowledgementCommitCallback) - Method in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- 
Sets the acknowledgement commit callback which can be used to handle acknowledgement completion.
- setAcknowledgementCommitCallback(AcknowledgementCommitCallback) - Method in class org.apache.kafka.clients.consumer.MockShareConsumer
- setAcknowledgementCommitCallback(AcknowledgementCommitCallback) - Method in interface org.apache.kafka.clients.consumer.ShareConsumer
- setClientInstanceId(Uuid) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- setClientInstanceId(Uuid) - Method in class org.apache.kafka.clients.consumer.MockShareConsumer
- setClientInstanceId(Uuid) - Method in class org.apache.kafka.clients.producer.MockProducer
- setClusterId(Optional<String>) - Method in class org.apache.kafka.clients.admin.AddRaftVoterOptions
- setClusterId(Optional<String>) - Method in class org.apache.kafka.clients.admin.RemoveRaftVoterOptions
- setConfig(String, Options, Map<String, Object>) - Method in interface org.apache.kafka.streams.state.RocksDBConfigSetter
- 
Set the rocks db options for the provided storeName.
- setCurrentStreamTimeMs(long) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- setCurrentStreamTimeMs(long) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- setCurrentSystemTimeMs(long) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- setCurrentSystemTimeMs(long) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- setExpiryTimestamp(long) - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
- setGlobalResult(QueryResult<R>) - Method in class org.apache.kafka.streams.query.StateQueryResult
- 
Set the result for a global store query.
- setGlobalStateRestoreListener(StateRestoreListener) - Method in class org.apache.kafka.streams.KafkaStreams
- 
Set the listener which is triggered whenever aStateStoreis being restored in order to resume processing.
- setGroupInstanceId(Optional<String>) - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
- setHeaders(Headers) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.The context exposes this metadata for use in the processor.
- setIsChangelogTopic(boolean) - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
- setMaxPollRecords(long) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- 
Sets the maximum number of records returned in a single call toMockConsumer.poll(Duration).
- setMockMetrics(MetricName, Metric) - Method in class org.apache.kafka.clients.producer.MockProducer
- 
Set a mock metric for testing purpose
- setOffset(long) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.The context exposes this metadata for use in the processor.
- setOffsetsException(KafkaException) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- setPartition(int) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.The context exposes this metadata for use in the processor.
- setPollException(KafkaException) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- setPosition(Position) - Method in interface org.apache.kafka.streams.query.QueryResult
- 
Used by stores to report what exact position in the store's history it was at when it executed the query.
- setRecordMetadata(String, int, long) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- 
The context exposes these metadata for use in the processor.
- setRecordMetadata(String, int, long, Headers, long) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.The context exposes these metadata for use in the processor.
- setRecordTimestamp(long) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.The context exposes this metadata for use in the processor.
- setStandbyUpdateListener(StandbyUpdateListener) - Method in class org.apache.kafka.streams.KafkaStreams
- 
Set the listener which is triggered whenever a standby task is updated
- setStateListener(KafkaStreams.StateListener) - Method in class org.apache.kafka.streams.KafkaStreams
- 
An app can set a singleKafkaStreams.StateListenerso that the app is notified when state changes.
- setTaskId(TaskId) - Method in exception class org.apache.kafka.streams.errors.StreamsException
- setTopic(String) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.The context exposes this metadata for use in the processor.
- setUncaughtExceptionHandler(StreamsUncaughtExceptionHandler) - Method in class org.apache.kafka.streams.KafkaStreams
- 
Set the handler invoked when an internalstream threadthrows an unexpected exception.
- SHARE - Enum constant in enum class org.apache.kafka.common.GroupType
- ShareConsumer<K,V> - Interface in org.apache.kafka.clients.consumer
- ShareGroupDescription - Class in org.apache.kafka.clients.admin
- 
A detailed description of a single share group in the cluster.
- ShareGroupDescription(String, Collection<ShareMemberDescription>, GroupState, Node) - Constructor for class org.apache.kafka.clients.admin.ShareGroupDescription
- ShareGroupDescription(String, Collection<ShareMemberDescription>, GroupState, Node, Set<AclOperation>) - Constructor for class org.apache.kafka.clients.admin.ShareGroupDescription
- ShareGroupPartitionAssignor - Interface in org.apache.kafka.coordinator.group.api.assignor
- 
Server-side partition assignor for share groups used by the GroupCoordinator.
- Share Groups and Topic Subscriptions - Search tag in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- Section
- ShareMemberAssignment - Class in org.apache.kafka.clients.admin
- 
A description of the assignments of a specific share group member.
- ShareMemberAssignment(Set<TopicPartition>) - Constructor for class org.apache.kafka.clients.admin.ShareMemberAssignment
- 
Creates an instance with the specified parameters.
- ShareMemberDescription - Class in org.apache.kafka.clients.admin
- 
A detailed description of a single share group member in the cluster.
- ShareMemberDescription(String, String, String, ShareMemberAssignment) - Constructor for class org.apache.kafka.clients.admin.ShareMemberDescription
- ShareSessionNotFoundException - Exception Class in org.apache.kafka.common.errors
- 
Thrown when the share session was not found.
- ShareSessionNotFoundException(String) - Constructor for exception class org.apache.kafka.common.errors.ShareSessionNotFoundException
- Short() - Static method in class org.apache.kafka.common.serialization.Serdes
- 
A serde for nullableShorttype.
- SHORT - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigType
- SHORT - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Type
- 
Used for numerical values within the Java Short range.
- SHORT - Enum constant in enum class 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
- shouldBeRebuilt(Map<String, Object>) - Method in interface org.apache.kafka.common.security.auth.SslEngineFactory
- 
Returns true ifSSLEngineneeds to be rebuilt.
- shouldListInternal() - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
- 
Return true if we should list internal topics.
- shouldRebalance() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- shouldRecord() - Method in class org.apache.kafka.common.metrics.Sensor
- shouldRecord(int) - Method in enum class org.apache.kafka.common.metrics.Sensor.RecordingLevel
- shouldRetryOnQuotaViolation() - Method in class org.apache.kafka.clients.admin.CreatePartitionsOptions
- 
Returns true if quota violation should be automatically retried.
- shouldRetryOnQuotaViolation() - Method in class org.apache.kafka.clients.admin.CreateTopicsOptions
- 
Returns true if quota violation should be automatically retried.
- shouldRetryOnQuotaViolation() - Method in class org.apache.kafka.clients.admin.DeleteTopicsOptions
- 
Returns true if quota violation should be automatically retried.
- 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.
- SHUTDOWN_APPLICATION - Enum constant in enum class org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
- 
Try to shut down the whole application.
- SHUTDOWN_CLIENT - Enum constant in enum class org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
- 
Shut down the client.
- shutDownWhenFull() - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
- 
Set the buffer to gracefully shut down the application when any of its constraints are violated
- SimpleHeaderConverter - Class in org.apache.kafka.connect.storage
- 
AHeaderConverterthat serializes header values as strings and that deserializes header values to the most appropriate numeric, boolean, array, or map representation.
- SimpleHeaderConverter() - Constructor for class org.apache.kafka.connect.storage.SimpleHeaderConverter
- SimpleRate - Class in org.apache.kafka.common.metrics.stats
- 
A simple rate the rate is incrementally calculated based on the elapsed time between the earliest reading and now.
- SimpleRate() - Constructor for class org.apache.kafka.common.metrics.stats.SimpleRate
- SINGLE_STORE_SELF_JOIN - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"topology.optimization"for enabling the optimization that optimizes inner stream-stream joins into self-joins when both arguments are the same stream.
- SINK - Enum constant in enum class org.apache.kafka.connect.health.ConnectorType
- 
Identifies a sink connector
- SinkConnector - Class in org.apache.kafka.connect.sink
- 
SinkConnectors implement the Connector interface to send Kafka data to another system.
- SinkConnector() - Constructor for class org.apache.kafka.connect.sink.SinkConnector
- SinkConnectorContext - Interface in org.apache.kafka.connect.sink
- 
A context to allow aSinkConnectorto interact with the Kafka Connect runtime.
- SinkRecord - Class in org.apache.kafka.connect.sink
- 
SinkRecord is aConnectRecordthat has been read from Kafka and includes the original Kafka record's topic, partition and offset (before anytransformationshave been applied) in addition to the standard fields.
- SinkRecord(String, int, Schema, Object, Schema, Object, long) - Constructor for class org.apache.kafka.connect.sink.SinkRecord
- SinkRecord(String, int, Schema, Object, Schema, Object, long, Long, TimestampType) - Constructor for class org.apache.kafka.connect.sink.SinkRecord
- SinkRecord(String, int, Schema, Object, Schema, Object, long, Long, TimestampType, Iterable<Header>) - Constructor for class org.apache.kafka.connect.sink.SinkRecord
- SinkRecord(String, int, Schema, Object, Schema, Object, long, Long, TimestampType, Iterable<Header>, String, Integer, long) - Constructor for class org.apache.kafka.connect.sink.SinkRecord
- 
This constructor is intended for use by the Connect runtime only and plugins (sink connectors or transformations) should not use this directly outside testing code.
- SinkTask - Class in org.apache.kafka.connect.sink
- 
SinkTask is a Task that takes records loaded from Kafka and sends them to another system.
- SinkTask() - Constructor for class org.apache.kafka.connect.sink.SinkTask
- SinkTaskContext - Interface in org.apache.kafka.connect.sink
- 
Context passed toSinkTasks, allowing them to access utilities in the Kafka Connect runtime.
- size() - Method in class org.apache.kafka.clients.admin.ReplicaInfo
- 
The total size of the log segments in this replica in bytes.
- size() - Method in class org.apache.kafka.connect.header.ConnectHeaders
- size() - Method in interface org.apache.kafka.connect.header.Headers
- 
Get the number of headers in this object.
- size() - Method in class org.apache.kafka.streams.kstream.JoinWindows
- size() - Method in class org.apache.kafka.streams.kstream.TimeWindows
- size() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
- 
Return the size of the specified windows in milliseconds.
- size() - Method in class org.apache.kafka.streams.kstream.Windows
- 
Return the size of the specified windows in milliseconds.
- sizeMs - Variable in class org.apache.kafka.streams.kstream.TimeWindows
- 
The size of the windows in milliseconds.
- skipCache() - Method in class org.apache.kafka.streams.query.KeyQuery
- 
Specifies that the cache should be skipped during query evaluation.
- skipCache() - Method in class org.apache.kafka.streams.query.TimestampedKeyQuery
- 
Specifies that the cache should be skipped during query evaluation.
- SlidingWindows - Class in org.apache.kafka.streams.kstream
- 
A sliding window used for aggregating events.
- SnapshotNotFoundException - Exception Class in org.apache.kafka.common.errors
- SnapshotNotFoundException(String) - Constructor for exception class org.apache.kafka.common.errors.SnapshotNotFoundException
- SnapshotNotFoundException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.SnapshotNotFoundException
- SOCKET_CONNECTION_SETUP_TIMEOUT_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- 
socket.connection.setup.timeout.max.ms
- SOCKET_CONNECTION_SETUP_TIMEOUT_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- 
socket.connection.setup.timeout.max.ms
- SOCKET_CONNECTION_SETUP_TIMEOUT_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
socket.connection.setup.timeout.max.ms
- SOCKET_CONNECTION_SETUP_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- 
socket.connection.setup.timeout.ms
- SOCKET_CONNECTION_SETUP_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- 
socket.connection.setup.timeout.ms
- SOCKET_CONNECTION_SETUP_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- 
socket.connection.setup.timeout.ms
- 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.
- source() - Method in class org.apache.kafka.connect.mirror.SourceAndTarget
- source() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
- 
The source node reading from a "global" topic.
- SOURCE - Enum constant in enum class org.apache.kafka.connect.health.ConnectorType
- 
Identifies a source connector
- SOURCE_CLUSTER_ALIAS_CONFIG - Static variable in class org.apache.kafka.connect.mirror.IdentityReplicationPolicy
- SOURCE_CLUSTER_ALIAS_KEY - Static variable in class org.apache.kafka.connect.mirror.Heartbeat
- SourceAndTarget - Class in org.apache.kafka.connect.mirror
- 
Directional pair of clusters, where source is mirrored to target.
- SourceAndTarget(String, String) - Constructor for class org.apache.kafka.connect.mirror.SourceAndTarget
- sourceClusterAlias() - Method in class org.apache.kafka.connect.mirror.Heartbeat
- SourceConnector - Class in org.apache.kafka.connect.source
- 
SourceConnectors implement the connector interface to pull data from another system and send it to Kafka.
- SourceConnector() - Constructor for class org.apache.kafka.connect.source.SourceConnector
- SourceConnectorContext - Interface in org.apache.kafka.connect.source
- 
A context to allow aSourceConnectorto interact with the Kafka Connect runtime.
- sourceOffset() - Method in class org.apache.kafka.connect.source.SourceRecord
- sourcePartition() - Method in class org.apache.kafka.connect.source.SourceRecord
- SourceRecord - Class in org.apache.kafka.connect.source
- 
SourceRecords are generated bySourceTasks and passed to Kafka Connect for storage in Kafka.
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Integer, Schema, Object) - Constructor for class org.apache.kafka.connect.source.SourceRecord
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Integer, Schema, Object, Schema, Object) - Constructor for class org.apache.kafka.connect.source.SourceRecord
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Integer, Schema, Object, Schema, Object, Long) - Constructor for class org.apache.kafka.connect.source.SourceRecord
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Integer, Schema, Object, Schema, Object, Long, Iterable<Header>) - Constructor for class org.apache.kafka.connect.source.SourceRecord
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Schema, Object) - Constructor for class org.apache.kafka.connect.source.SourceRecord
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Schema, Object, Schema, Object) - Constructor for class org.apache.kafka.connect.source.SourceRecord
- SourceTask - Class in org.apache.kafka.connect.source
- 
SourceTask is a Task that pulls records from another system for storage in Kafka.
- SourceTask() - Constructor for class org.apache.kafka.connect.source.SourceTask
- SourceTask.TransactionBoundary - Enum Class in org.apache.kafka.connect.source
- 
Represents the permitted values for theSourceTask.TRANSACTION_BOUNDARY_CONFIGproperty.
- SourceTaskContext - Interface in org.apache.kafka.connect.source
- 
SourceTaskContext is provided to SourceTasks to allow them to interact with the underlying runtime.
- split() - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Split this stream into different branches.
- split(Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Split this stream into different branches.
- SSL - Enum constant in enum class 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_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_ENGINE_FACTORY_CLASS_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
- SSL_ENGINE_FACTORY_CLASS_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_CERTIFICATE_CHAIN_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
- SSL_KEYSTORE_CERTIFICATE_CHAIN_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
- SSL_KEYSTORE_KEY_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
- SSL_KEYSTORE_KEY_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_CERTIFICATES_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
- SSL_TRUSTSTORE_CERTIFICATES_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 Class in org.apache.kafka.common.errors
- 
This exception indicates that SSL handshake has failed.
- SslAuthenticationException(String) - Constructor for exception class org.apache.kafka.common.errors.SslAuthenticationException
- SslAuthenticationException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.SslAuthenticationException
- SslClientAuth - Enum Class in org.apache.kafka.common.config
- 
Describes whether the server should require or request client authentication.
- SslConfigs - Class in org.apache.kafka.common.config
- SslConfigs() - Constructor for class org.apache.kafka.common.config.SslConfigs
- SslEngineFactory - Interface in org.apache.kafka.common.security.auth
- 
Plugin interface for allowing creation ofSSLEngineobject in a custom way.
- sslSession() - Method in class org.apache.kafka.common.security.auth.SaslAuthenticationContext
- 
Returns SSL session for the connection if security protocol is SASL_SSL.
- STABLE - Enum constant in enum class org.apache.kafka.common.ClassicGroupState
- STABLE - Enum constant in enum class org.apache.kafka.common.ConsumerGroupState
- 
Deprecated.
- STABLE - Enum constant in enum class org.apache.kafka.common.GroupState
- StaleBrokerEpochException - Exception Class in org.apache.kafka.common.errors
- StaleBrokerEpochException(String) - Constructor for exception class org.apache.kafka.common.errors.StaleBrokerEpochException
- StaleBrokerEpochException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.StaleBrokerEpochException
- StaleMemberEpochException - Exception Class in org.apache.kafka.common.errors
- 
The StaleMemberEpochException is used in the context of the new consumer group protocol (KIP-848).
- StaleMemberEpochException(String) - Constructor for exception class org.apache.kafka.common.errors.StaleMemberEpochException
- staleStoresEnabled() - Method in class org.apache.kafka.streams.StoreQueryParameters
- 
Get the flag staleStores.
- STANDBY - Enum constant in enum class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask.Type
- standbyHosts() - Method in class org.apache.kafka.streams.KeyQueryMetadata
- 
Get the Kafka Streams instances that host the key as standbys.
- standbyStateStoreNames() - Method in interface org.apache.kafka.streams.StreamsMetadata
- 
Names of the state stores assigned to standby tasks of the Streams client.
- standbyTasks() - Method in interface org.apache.kafka.streams.ThreadMetadata
- 
Metadata of the standby tasks assigned to the stream thread.
- standbyTopicPartitions() - Method in interface org.apache.kafka.streams.StreamsMetadata
- 
Source topic partitions for which the instance acts as standby.
- StandbyUpdateListener - Interface in org.apache.kafka.streams.processor
- StandbyUpdateListener.SuspendReason - Enum Class in org.apache.kafka.streams.processor
- start() - Method in class org.apache.kafka.streams.KafkaStreams
- 
Start theKafkaStreamsinstance by starting all its threads.
- start() - Method in class org.apache.kafka.streams.kstream.Window
- 
Return the start timestamp of this window.
- start(Map<String, String>) - Method in class org.apache.kafka.connect.connector.Connector
- 
Start this Connector.
- start(Map<String, String>) - Method in interface org.apache.kafka.connect.connector.Task
- 
Start the Task
- start(Map<String, String>) - Method in class org.apache.kafka.connect.sink.SinkTask
- 
Start the Task.
- start(Map<String, String>) - Method in class org.apache.kafka.connect.source.SourceTask
- 
Start the Task.
- start(Map<String, String>) - Method in class org.apache.kafka.connect.tools.MockConnector
- start(Map<String, String>) - Method in class org.apache.kafka.connect.tools.MockSinkConnector
- start(Map<String, String>) - Method in class org.apache.kafka.connect.tools.MockSinkTask
- start(Map<String, String>) - Method in class org.apache.kafka.connect.tools.MockSourceConnector
- start(Map<String, String>) - Method in class org.apache.kafka.connect.tools.MockSourceTask
- start(Map<String, String>) - Method in class org.apache.kafka.connect.tools.SchemaSourceConnector
- start(Map<String, String>) - Method in class org.apache.kafka.connect.tools.SchemaSourceTask
- start(Map<String, String>) - Method in class org.apache.kafka.connect.tools.VerifiableSinkConnector
- start(Map<String, String>) - Method in class org.apache.kafka.connect.tools.VerifiableSinkTask
- start(Map<String, String>) - Method in class org.apache.kafka.connect.tools.VerifiableSourceConnector
- start(Map<String, String>) - Method in class org.apache.kafka.connect.tools.VerifiableSourceTask
- start(AuthorizerServerInfo) - Method in interface org.apache.kafka.server.authorizer.Authorizer
- 
Starts loading authorization metadata and returns futures that can be used to wait until metadata for authorizing requests on each listener is available.
- startMs - Variable in class org.apache.kafka.streams.kstream.UnlimitedWindows
- 
The start timestamp of the window.
- startOffset() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- startOn(Instant) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
- 
Return a new unlimited window for the specified start timestamp.
- startTime() - Method in class org.apache.kafka.streams.kstream.Window
- 
Return the start time of this window.
- 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.
- stat() - Method in class org.apache.kafka.common.metrics.CompoundStat.NamedMeasurable
- Stat - Interface in org.apache.kafka.common.metrics
- 
A Stat is a quantity such as average, max, etc that is computed off the stream of updates to a sensor
- state() - Method in class org.apache.kafka.clients.admin.ClassicGroupDescription
- 
The classic group state, or UNKNOWN if the state is too new for us to parse.
- state() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
- 
Deprecated.Since 4.0. UseConsumerGroupDescription.groupState()instead.
- state() - Method in class org.apache.kafka.clients.admin.ConsumerGroupListing
- 
Deprecated.Since 4.0. UseConsumerGroupListing.groupState()instead.
- state() - Method in class org.apache.kafka.clients.admin.TransactionDescription
- state() - Method in class org.apache.kafka.clients.admin.TransactionListing
- state() - Method in class org.apache.kafka.connect.health.AbstractState
- 
Provides the current state of the connector or task.
- state() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- 
Returns the current state of this remote log segment.
- state() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
- 
It represents the state of the remote log segment.
- state() - Method in class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteMetadata
- 
It represents the state of the remote partition.
- state() - Method in class org.apache.kafka.streams.KafkaStreams
- 
Return the currentKafkaStreams.Stateof thisKafkaStreamsinstance.
- STATE_CLEANUP_DELAY_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
state.cleanup.delay
- STATE_DIR_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
state.dir
- STATE_UPDATER_ENABLED - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- stateDir() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- stateDir() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
- 
Return the state directory for the partition.
- stateDir() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- stateDir() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Return the state directory for the partition.
- stateDir() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
- 
Returns the state directory for the partition.
- statefulTasksToLagSums() - Method in interface org.apache.kafka.streams.processor.assignment.KafkaStreamsState
- 
Returns a collection containing all (and only) stateful tasks in the topology byTaskId, mapped to its "offset lag sum".
- StateQueryRequest<R> - Class in org.apache.kafka.streams.query
- 
The request object for Interactive Queries.
- StateQueryRequest.InStore - Class in org.apache.kafka.streams.query
- 
A progressive builder interface for creatingStoreQueryRequests.
- StateQueryResult<R> - Class in org.apache.kafka.streams.query
- 
The response object for interactive queries.
- StateQueryResult() - Constructor for class org.apache.kafka.streams.query.StateQueryResult
- StateRestoreCallback - Interface in org.apache.kafka.streams.processor
- 
Restoration logic for log-backed state stores upon restart, it takes one record at a time from the logs to apply to the restoring state.
- StateRestoreListener - Interface in org.apache.kafka.streams.processor
- 
Class for listening to various states of the restoration process of a StateStore.
- states() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsOptions
- 
Deprecated.Since 4.0. UseListConsumerGroupsOptions.inGroupStates(Set)instead.
- StateSerdes<K,V> - Class in org.apache.kafka.streams.state
- 
Factory for creating serializers / deserializers for state stores in Kafka Streams.
- StateSerdes(String, Serde<K>, Serde<V>) - Constructor for class org.apache.kafka.streams.state.StateSerdes
- 
Create a context for serialization using the specified serializers and deserializers which must match the key and value types used as parameters for this object; the state changelog topic is provided to bind this serde factory to, so that future calls for serialize / deserialize do not need to provide the topic name any more.
- StateStore - Interface in org.apache.kafka.streams.processor
- 
A storage engine for managing state maintained by a stream processor.
- STATESTORE_CACHE_MAX_BYTES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
statestore.cache.max.bytes
- STATESTORE_CACHE_MAX_BYTES_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- StateStoreContext - Interface in org.apache.kafka.streams.processor
- 
State store context interface.
- StateStoreMigratedException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates that the state store being queried is closed although the Kafka Streams state isRUNNINGorREBALANCING.
- StateStoreMigratedException(String) - Constructor for exception class org.apache.kafka.streams.errors.StateStoreMigratedException
- StateStoreMigratedException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.StateStoreMigratedException
- stateStoreNames() - Method in interface org.apache.kafka.streams.processor.assignment.TaskInfo
- stateStoreNames() - Method in interface org.apache.kafka.streams.StreamsMetadata
- 
Names of the state stores assigned to active tasks of the Streams client.
- StateStoreNotAvailableException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates that the state store being queried is already closed.
- StateStoreNotAvailableException(String) - Constructor for exception class org.apache.kafka.streams.errors.StateStoreNotAvailableException
- StateStoreNotAvailableException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.StateStoreNotAvailableException
- stateUpdaterEnabled(Map<String, Object>) - Static method in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- STATIC_BROKER_CONFIG - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
- stats() - Method in interface org.apache.kafka.common.metrics.CompoundStat
- stats() - Method in class org.apache.kafka.common.metrics.stats.Frequencies
- stats() - Method in class org.apache.kafka.common.metrics.stats.Meter
- stats() - Method in class org.apache.kafka.common.metrics.stats.Percentiles
- STICKY_ASSIGNOR_NAME - Static variable in class org.apache.kafka.clients.consumer.StickyAssignor
- StickyAssignor - Class in org.apache.kafka.clients.consumer
- 
The sticky assignor serves two purposes.
- StickyAssignor() - Constructor for class org.apache.kafka.clients.consumer.StickyAssignor
- StickyTaskAssignor - Class in org.apache.kafka.streams.processor.assignment.assignors
- StickyTaskAssignor() - Constructor for class org.apache.kafka.streams.processor.assignment.assignors.StickyTaskAssignor
- StickyTaskAssignor(boolean) - Constructor for class org.apache.kafka.streams.processor.assignment.assignors.StickyTaskAssignor
- stop() - Method in class org.apache.kafka.connect.connector.Connector
- 
Stop this connector.
- stop() - Method in interface org.apache.kafka.connect.connector.Task
- 
Stop this task.
- stop() - Method in class org.apache.kafka.connect.sink.SinkTask
- 
Perform any cleanup to stop this task.
- stop() - Method in class org.apache.kafka.connect.source.SourceTask
- 
Signal this SourceTask to stop.
- stop() - Method in class org.apache.kafka.connect.tools.MockConnector
- stop() - Method in class org.apache.kafka.connect.tools.MockSinkConnector
- stop() - Method in class org.apache.kafka.connect.tools.MockSinkTask
- stop() - Method in class org.apache.kafka.connect.tools.MockSourceConnector
- stop() - Method in class org.apache.kafka.connect.tools.MockSourceTask
- stop() - Method in class org.apache.kafka.connect.tools.SchemaSourceConnector
- stop() - Method in class org.apache.kafka.connect.tools.SchemaSourceTask
- stop() - Method in class org.apache.kafka.connect.tools.VerifiableSinkConnector
- stop() - Method in class org.apache.kafka.connect.tools.VerifiableSinkTask
- stop() - Method in class org.apache.kafka.connect.tools.VerifiableSourceConnector
- stop() - Method in class org.apache.kafka.connect.tools.VerifiableSourceTask
- store(StoreQueryParameters<T>) - Method in class org.apache.kafka.streams.KafkaStreams
- 
Get a facade wrapping the localStateStoreinstances with the providedStoreQueryParameters.
- STORE_EXCEPTION - Enum constant in enum class org.apache.kafka.streams.query.FailureReason
- 
The store that handled the query got an exception during query execution.
- StoreBuilder<T> - Interface in org.apache.kafka.streams.state
- 
Build aStateStorewrapped with optional caching and logging.
- storedKey() - Method in class org.apache.kafka.common.security.scram.ScramCredential
- 
Stored key computed from the client password using the SCRAM algorithm.
- storeName() - Method in class org.apache.kafka.streams.StoreQueryParameters
- 
Get the name of the state store that should be queried.
- StoreQueryParameters<T> - Class in org.apache.kafka.streams
- 
StoreQueryParametersallows you to pass a variety of parameters when fetching a store for interactive query.
- stores() - Method in interface org.apache.kafka.streams.processor.ConnectedStoreProvider
- stores() - Method in interface org.apache.kafka.streams.TopologyDescription.Processor
- 
The names of all connected stores.
- Stores - Class in org.apache.kafka.streams.state
- 
Factory for creating state stores in Kafka Streams.
- Stores() - Constructor for class org.apache.kafka.streams.state.Stores
- StoreSupplier<T> - Interface in org.apache.kafka.streams.state
- 
A state store supplier which can create one or moreStateStoreinstances.
- storeType - Variable in class org.apache.kafka.streams.TopologyConfig
- Storing Offsets Outside Kafka - Search tag in class org.apache.kafka.clients.consumer.KafkaConsumer
- Section
- stream(String) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Create aKStreamfrom the specified topic.
- stream(String, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Create aKStreamfrom the specified topic.
- stream(Collection<String>) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Create aKStreamfrom the specified topics.
- stream(Collection<String>, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Create aKStreamfrom the specified topics.
- stream(Pattern) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Create aKStreamfrom the specified topic pattern.
- stream(Pattern, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Create aKStreamfrom the specified topic pattern.
- STREAM_TIME - Enum constant in enum class org.apache.kafka.streams.processor.PunctuationType
- StreamJoined<K,V1, - Class in org.apache.kafka.streams.kstreamV2> 
- 
Class used to configure the name of the join processor, the repartition topic name, state stores or state store names in Stream-Stream join.
- streamPartitioner(StreamPartitioner<? super K, ? super V>) - Static method in class org.apache.kafka.streams.kstream.Produced
- 
Create a Produced instance with provided partitioner.
- streamPartitioner(StreamPartitioner<K, V>) - Static method in class org.apache.kafka.streams.kstream.Repartitioned
- 
Create aRepartitionedinstance with provided partitioner.
- StreamPartitioner<K,V> - Interface in org.apache.kafka.streams.processor
- 
Determine how records are distributed among the partitions in a Kafka topic.
- StreamsBuilder - Class in org.apache.kafka.streams
- 
StreamsBuilderprovides the high-level Kafka Streams DSL to specify a Kafka Streams topology.
- StreamsBuilder() - Constructor for class org.apache.kafka.streams.StreamsBuilder
- StreamsBuilder(TopologyConfig) - Constructor for class org.apache.kafka.streams.StreamsBuilder
- 
Create aStreamsBuilderinstance.
- StreamsConfig - Class in org.apache.kafka.streams
- 
Configuration for aKafkaStreamsinstance.
- StreamsConfig(Map<?, ?>) - Constructor for class org.apache.kafka.streams.StreamsConfig
- 
Create a newStreamsConfigusing the given properties.
- StreamsConfig.InternalConfig - Class in org.apache.kafka.streams
- StreamsException - Exception Class in org.apache.kafka.streams.errors
- 
StreamsExceptionis the top-level exception type generated by Kafka Streams, and indicates errors have occurred during aStreamThread'sprocessing.
- StreamsException(String) - Constructor for exception class org.apache.kafka.streams.errors.StreamsException
- StreamsException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.StreamsException
- StreamsException(String, Throwable, TaskId) - Constructor for exception class org.apache.kafka.streams.errors.StreamsException
- StreamsException(String, TaskId) - Constructor for exception class org.apache.kafka.streams.errors.StreamsException
- StreamsException(Throwable) - Constructor for exception class org.apache.kafka.streams.errors.StreamsException
- StreamsException(Throwable, TaskId) - Constructor for exception class org.apache.kafka.streams.errors.StreamsException
- StreamsMetadata - Interface in org.apache.kafka.streams
- 
Metadata of a Kafka Streams client.
- streamsMetadataForStore(String) - Method in class org.apache.kafka.streams.KafkaStreams
- 
Find all currently runningKafkaStreamsinstances (potentially remotely) that use the sameapplication IDas this instance (i.e., all instances that belong to the same Kafka Streams application) and that contain aStateStorewith the givenstoreNameand returnStreamsMetadatafor each discovered instance.
- StreamsMetrics - Interface in org.apache.kafka.streams
- 
The Kafka Streams metrics interface for adding metric sensors and collecting metric values.
- StreamsNotStartedException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates that Kafka Streams is in stateCREATEDand thus state stores cannot be queries yet.
- StreamsNotStartedException(String) - Constructor for exception class org.apache.kafka.streams.errors.StreamsNotStartedException
- StreamsNotStartedException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.StreamsNotStartedException
- StreamsRebalancingException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates that Kafka Streams is in stateREBALANCINGand thus cannot be queried by default.
- StreamsRebalancingException(String) - Constructor for exception class org.apache.kafka.streams.errors.StreamsRebalancingException
- StreamsRebalancingException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.StreamsRebalancingException
- StreamsStoppedException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates that Kafka Streams is in a terminating or terminal state, such asKafkaStreams.State.PENDING_SHUTDOWN,KafkaStreams.State.PENDING_ERROR,KafkaStreams.State.NOT_RUNNING, orKafkaStreams.State.ERROR.
- StreamsStoppedException(String) - Constructor for exception class org.apache.kafka.streams.errors.StreamsStoppedException
- StreamsStoppedException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.StreamsStoppedException
- StreamsUncaughtExceptionHandler - Interface in org.apache.kafka.streams.errors
- StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse - Enum Class in org.apache.kafka.streams.errors
- 
Enumeration that describes the response from the exception handler.
- strict() - Method in class org.apache.kafka.common.quota.ClientQuotaFilter
- string() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- String() - Static method in class org.apache.kafka.common.serialization.Serdes
- 
A serde for nullableStringtype.
- STRING - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigType
- STRING - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Type
- 
Used for string values.
- STRING - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
- 
Character string that supports all Unicode characters.
- STRING_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- StringConverter - Class in org.apache.kafka.connect.storage
- 
ConverterandHeaderConverterimplementation that only supports serializing to strings.
- StringConverter() - Constructor for class org.apache.kafka.connect.storage.StringConverter
- StringConverterConfig - Class in org.apache.kafka.connect.storage
- 
Configuration options forStringConverterinstances.
- StringConverterConfig(Map<String, ?>) - Constructor for class org.apache.kafka.connect.storage.StringConverterConfig
- StringDecoder - Class in org.apache.kafka.tools.api
- 
The string decoder translates bytes into strings.
- StringDecoder() - Constructor for class org.apache.kafka.tools.api.StringDecoder
- 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
- struct() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- Struct - Class in org.apache.kafka.connect.data
- 
A structured record containing a set of named fields with values, each field using an independentSchema.
- Struct(Schema) - Constructor for class org.apache.kafka.connect.data.Struct
- 
Create a new Struct for thisSchema
- STRUCT - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
- 
A structured record containing a set of named fields, each field using a fixed, independentSchema.
- 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.KafkaShareConsumer
- 
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>) - Method in class org.apache.kafka.clients.consumer.MockShareConsumer
- subscribe(Collection<String>) - Method in interface org.apache.kafka.clients.consumer.ShareConsumer
- 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(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
- subscribe(SubscriptionPattern) - Method in interface org.apache.kafka.clients.consumer.Consumer
- subscribe(SubscriptionPattern) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
- 
Subscribe to all topics matching the specified pattern, to get dynamically assigned partitions.
- subscribe(SubscriptionPattern) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- subscribe(SubscriptionPattern, ConsumerRebalanceListener) - Method in interface org.apache.kafka.clients.consumer.Consumer
- subscribe(SubscriptionPattern, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
- 
Subscribe to all topics matching the specified pattern, to get dynamically assigned partitions.
- subscribe(SubscriptionPattern, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- SubscribedTopicDescriber - Interface in org.apache.kafka.coordinator.group.api.assignor
- 
The subscribed topic describer is used by thePartitionAssignorto obtain topic and partition metadata of the subscribed topics.
- subscribedTopicIds() - Method in interface org.apache.kafka.coordinator.group.api.assignor.MemberSubscription
- 
Gets the set of subscribed topic Ids.
- 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.KafkaShareConsumer
- 
Get the current subscription.
- subscription() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- subscription() - Method in class org.apache.kafka.clients.consumer.MockShareConsumer
- subscription() - Method in interface org.apache.kafka.clients.consumer.ShareConsumer
- Subscription(List<String>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
- Subscription(List<String>, ByteBuffer) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
- Subscription(List<String>, ByteBuffer, List<TopicPartition>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
- Subscription(List<String>, ByteBuffer, List<TopicPartition>, int, Optional<String>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
- SubscriptionPattern - Class in org.apache.kafka.clients.consumer
- 
Represents a regular expression compatible with Google RE2/J, used to subscribe to topics.
- SubscriptionPattern(String) - Constructor for class org.apache.kafka.clients.consumer.SubscriptionPattern
- subscriptionType() - Method in interface org.apache.kafka.coordinator.group.api.assignor.GroupSpec
- SubscriptionType - Enum Class in org.apache.kafka.coordinator.group.api.assignor
- 
The subscription type followed by a consumer group.
- subscriptionUserData(Set<String>) - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
- 
Return serialized data that will be included in theConsumerPartitionAssignor.Subscriptionsent to the leader and can be leveraged inConsumerPartitionAssignor.assign(Cluster, GroupSubscription)((e.g.
- subscriptionUserData(Set<String>) - Method in class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
- subscriptionUserData(Set<String>) - Method in class org.apache.kafka.clients.consumer.StickyAssignor
- subtopologies() - Method in interface org.apache.kafka.streams.TopologyDescription
- 
All sub-topologies of the represented topology.
- subtopology() - Method in class org.apache.kafka.streams.processor.TaskId
- SUBTRACT - Enum constant in enum class org.apache.kafka.clients.admin.AlterConfigOp.OpType
- 
(For list-type configuration entries only.) Removes the specified values from the current value of the configuration entry.
- SUCCESS - Static variable in class org.apache.kafka.server.authorizer.AclCreateResult
- successors() - Method in interface org.apache.kafka.streams.TopologyDescription.Node
- 
The successor of this node within a sub-topology.
- SUPPORTED - Enum constant in enum class org.apache.kafka.connect.source.ConnectorTransactionBoundaries
- 
Signals that a connector can define its own transaction boundaries.
- SUPPORTED - Enum constant in enum class org.apache.kafka.connect.source.ExactlyOnceSupport
- 
Signals that a connector supports exactly-once semantics.
- supportedFeatures() - Method in class org.apache.kafka.clients.admin.FeatureMetadata
- 
Returns a map of supported feature versions.
- supportedProtocols() - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
- 
Indicate which rebalance protocol this assignor works with; By default it should always work withConsumerPartitionAssignor.RebalanceProtocol.EAGER.
- supportedProtocols() - Method in class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
- SupportedVersionRange - Class in org.apache.kafka.clients.admin
- 
Represents a range of versions that a particular broker supports for some feature.
- SupportedVersionRange(short, short) - Constructor for class org.apache.kafka.clients.admin.SupportedVersionRange
- 
Raises an exception unless the following conditions are met: 0 <= minVersion <= maxVersion.
- suppress(Suppressed<? super K>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Suppress some updates from this changelog stream, determined by the suppliedSuppressedconfiguration.
- Suppressed<K> - Interface in org.apache.kafka.streams.kstream
- Suppressed.BufferConfig<BC> - Interface in org.apache.kafka.streams.kstream
- Suppressed.EagerBufferConfig - Interface in org.apache.kafka.streams.kstream
- 
Marker interface for a buffer configuration that will strictly enforce size constraints (bytes and/or number of records) on the buffer, so it is suitable for reducing duplicate results downstream, but does not promise to eliminate them entirely.
- Suppressed.StrictBufferConfig - Interface in org.apache.kafka.streams.kstream
- 
Marker interface for a buffer configuration that is "strict" in the sense that it will strictly enforce the time bound and never emit early.
- 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
- table(String) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Create aKTablefor the specified topic.
- table(String, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Create aKTablefor the specified topic.
- table(String, Consumed<K, V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Create aKTablefor the specified topic.
- table(String, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
- 
Create aKTablefor the specified topic.
- TableJoined<K,KO> - Class in org.apache.kafka.streams.kstream
- 
TheTableJoinedclass represents optional parameters that can be passed toKTable#join(KTable,Function,...)andKTable#leftJoin(KTable,Function,...)operations, for foreign key joins.
- 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.
- tags() - Method in class org.apache.kafka.common.metrics.MetricConfig
- tags(Map<String, String>) - Method in class org.apache.kafka.common.metrics.MetricConfig
- target() - Method in class org.apache.kafka.connect.mirror.SourceAndTarget
- TARGET_CLUSTER_ALIAS_KEY - Static variable in class org.apache.kafka.connect.mirror.Heartbeat
- targetAssignment() - Method in class org.apache.kafka.clients.admin.MemberDescription
- 
The target assignment of the member.
- targetAssignmentEpoch() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
- 
The epoch of the target assignment.
- targetClusterAlias() - Method in class org.apache.kafka.connect.mirror.Heartbeat
- targetReplicas() - Method in class org.apache.kafka.clients.admin.NewPartitionReassignment
- Task - Interface in org.apache.kafka.connect.connector
- 
Tasks contain the code that actually copies data to/from another system.
- TASK_ASSIGNOR_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
task.assignor.class
- TASK_FAILURE - Static variable in class org.apache.kafka.connect.tools.MockConnector
- TASK_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
task.timeout.ms
- TASK_TIMEOUT_MS_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Deprecated.
- TaskAssignment(Collection<KafkaStreamsAssignment>) - Constructor for class org.apache.kafka.streams.processor.assignment.TaskAssignor.TaskAssignment
- TaskAssignmentException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates a run time error incurred while trying to assignstream taskstothreads.
- TaskAssignmentException(String) - Constructor for exception class org.apache.kafka.streams.errors.TaskAssignmentException
- TaskAssignmentException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.TaskAssignmentException
- TaskAssignmentException(Throwable) - Constructor for exception class org.apache.kafka.streams.errors.TaskAssignmentException
- TaskAssignmentUtils - Class in org.apache.kafka.streams.processor.assignment
- 
A set of utilities to help implement task assignment via theTaskAssignor
- TaskAssignmentUtils.MoveStandbyTaskPredicate - Interface in org.apache.kafka.streams.processor.assignment
- TaskAssignmentUtils.RackAwareOptimizationParams - Class in org.apache.kafka.streams.processor.assignment
- 
A simple config container for necessary parameters and optional overrides to apply when running the active or standby task rack-aware optimizations.
- TaskAssignor - Interface in org.apache.kafka.streams.processor.assignment
- 
A TaskAssignor is responsible for creating a TaskAssignment from a givenApplicationState.
- TaskAssignor.AssignmentError - Enum Class in org.apache.kafka.streams.processor.assignment
- 
NONE: no error detected ACTIVE_TASK_ASSIGNED_MULTIPLE_TIMES: multiple KafkaStreams clients assigned with the same active task INVALID_STANDBY_TASK: stateless task assigned as a standby task MISSING_PROCESS_ID: ProcessId present in the input ApplicationState was not present in the output TaskAssignment UNKNOWN_PROCESS_ID: unrecognized ProcessId not matching any of the participating consumers UNKNOWN_TASK_ID: unrecognized TaskId not matching any of the tasks to be assigned
- TaskAssignor.TaskAssignment - Class in org.apache.kafka.streams.processor.assignment
- 
Wrapper class for the final assignment of active and standbys tasks to individual KafkaStreams clients.
- taskClass() - Method in class org.apache.kafka.connect.connector.Connector
- 
Returns theTaskimplementation for this Connector.
- taskClass() - Method in class org.apache.kafka.connect.tools.MockConnector
- taskClass() - Method in class org.apache.kafka.connect.tools.MockSinkConnector
- taskClass() - Method in class org.apache.kafka.connect.tools.MockSourceConnector
- taskClass() - Method in class org.apache.kafka.connect.tools.SchemaSourceConnector
- taskClass() - Method in class org.apache.kafka.connect.tools.VerifiableSinkConnector
- taskClass() - Method in class org.apache.kafka.connect.tools.VerifiableSourceConnector
- taskConfigs(int) - Method in class org.apache.kafka.connect.connector.Connector
- 
Returns a set of configurations for Tasks based on the current configuration, producing at mostmaxTasksconfigurations.
- taskConfigs(int) - Method in class org.apache.kafka.connect.tools.MockConnector
- taskConfigs(int) - Method in class org.apache.kafka.connect.tools.MockSinkConnector
- taskConfigs(int) - Method in class org.apache.kafka.connect.tools.MockSourceConnector
- taskConfigs(int) - Method in class org.apache.kafka.connect.tools.SchemaSourceConnector
- taskConfigs(int) - Method in class org.apache.kafka.connect.tools.VerifiableSinkConnector
- taskConfigs(int) - Method in class org.apache.kafka.connect.tools.VerifiableSourceConnector
- TaskCorruptedException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates a specific task is corrupted and need to be re-initialized.
- TaskCorruptedException(Set<TaskId>) - Constructor for exception class org.apache.kafka.streams.errors.TaskCorruptedException
- TaskCorruptedException(Set<TaskId>, InvalidOffsetException) - Constructor for exception class org.apache.kafka.streams.errors.TaskCorruptedException
- taskId() - Method in class org.apache.kafka.connect.health.TaskState
- 
Provides the ID of the task.
- taskId() - Method in interface org.apache.kafka.streams.errors.ErrorHandlerContext
- 
Return the task ID.
- taskId() - Method in exception class org.apache.kafka.streams.errors.StreamsException
- taskId() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- taskId() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
- 
Return the task id.
- taskId() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- taskId() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Return the task id.
- taskId() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
- 
Returns the task id.
- taskId() - Method in interface org.apache.kafka.streams.TaskMetadata
- 
Task ID of the task.
- TaskId - Class in org.apache.kafka.streams.processor
- 
The task ID representation composed as subtopology plus the assigned partition ID.
- TaskId(int, int) - Constructor for class org.apache.kafka.streams.processor.TaskId
- TaskId(int, int, String) - Constructor for class org.apache.kafka.streams.processor.TaskId
- TaskIdFormatException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates a run time error incurred while trying parse thetask idfrom the read string.
- TaskIdFormatException(String) - Constructor for exception class org.apache.kafka.streams.errors.TaskIdFormatException
- TaskIdFormatException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.TaskIdFormatException
- TaskIdFormatException(Throwable) - Constructor for exception class org.apache.kafka.streams.errors.TaskIdFormatException
- TaskInfo - Interface in org.apache.kafka.streams.processor.assignment
- 
A simple container class corresponding to a givenTaskId.
- TaskMetadata - Interface in org.apache.kafka.streams
- 
Metadata of a task.
- TaskMigratedException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates that all tasks belongs to the thread have migrated to another thread.
- TaskMigratedException(String) - Constructor for exception class org.apache.kafka.streams.errors.TaskMigratedException
- TaskMigratedException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.TaskMigratedException
- tasks() - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment
- tasksState() - Method in class org.apache.kafka.connect.health.ConnectorHealth
- 
Provides the current state of the connector tasks.
- TaskState - Class in org.apache.kafka.connect.health
- 
Describes the state, IDs, and any errors of a connector task.
- TaskState(int, String, String, String) - Constructor for class org.apache.kafka.connect.health.TaskState
- 
Provides an instance ofTaskState.
- taskTimeoutMs - Variable in class org.apache.kafka.streams.TopologyConfig.TaskConfig
- taskTimeoutMs - Variable in class org.apache.kafka.streams.TopologyConfig
- TaskTopicPartition - Interface in org.apache.kafka.streams.processor.assignment
- 
This is a simple container class used during the assignment process to distinguish TopicPartitions type.
- TelemetryTooLargeException - Exception Class in org.apache.kafka.common.errors
- 
This exception indicates that the size of the telemetry metrics data is too large.
- TelemetryTooLargeException(String) - Constructor for exception class org.apache.kafka.common.errors.TelemetryTooLargeException
- test(K, V) - Method in interface org.apache.kafka.streams.kstream.Predicate
- 
Test if the record with the given key and value satisfies the predicate.
- test(R) - Method in interface org.apache.kafka.connect.transforms.predicates.Predicate
- 
Returns whether the given record satisfies this predicate.
- TestInputTopic<K,V> - Class in org.apache.kafka.streams
- 
TestInputTopicis used to pipe records to topic inTopologyTestDriver.
- TestOutputTopic<K,V> - Class in org.apache.kafka.streams
- 
TestOutputTopicis used to read records from a topic inTopologyTestDriver.
- TestRecord<K,V> - Class in org.apache.kafka.streams.test
- 
A key/value pair, including timestamp and record headers, to be sent to or received fromTopologyTestDriver.
- TestRecord(K, V) - Constructor for class org.apache.kafka.streams.test.TestRecord
- 
Creates a record.
- TestRecord(K, V, Instant) - Constructor for class org.apache.kafka.streams.test.TestRecord
- 
Creates a record.
- TestRecord(K, V, Headers) - Constructor for class org.apache.kafka.streams.test.TestRecord
- 
Creates a record.
- TestRecord(K, V, Headers, Long) - Constructor for class org.apache.kafka.streams.test.TestRecord
- 
Creates a record.
- TestRecord(K, V, Headers, Instant) - Constructor for class org.apache.kafka.streams.test.TestRecord
- 
Creates a record.
- TestRecord(ConsumerRecord<K, V>) - Constructor for class org.apache.kafka.streams.test.TestRecord
- 
Create aTestRecordfrom aConsumerRecord.
- TestRecord(ProducerRecord<K, V>) - Constructor for class org.apache.kafka.streams.test.TestRecord
- 
Create aTestRecordfrom aProducerRecord.
- TestRecord(V) - Constructor for class org.apache.kafka.streams.test.TestRecord
- 
Create a record withnullkey.
- 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.
- ThreadMetadata - Interface in org.apache.kafka.streams
- 
Metadata of a stream thread.
- threadName() - Method in interface org.apache.kafka.streams.ThreadMetadata
- 
Name of the stream thread
- threadState() - Method in interface org.apache.kafka.streams.ThreadMetadata
- 
State of the stream thread
- throttleTimeMs() - Method in exception class org.apache.kafka.common.errors.ThrottlingQuotaExceededException
- ThrottlingQuotaExceededException - Exception Class in org.apache.kafka.common.errors
- 
Exception thrown if an operation on a resource exceeds the throttling quota.
- ThrottlingQuotaExceededException(int, String) - Constructor for exception class org.apache.kafka.common.errors.ThrottlingQuotaExceededException
- ThrottlingQuotaExceededException(String) - Constructor for exception class org.apache.kafka.common.errors.ThrottlingQuotaExceededException
- THROUGHPUT_CONFIG - Static variable in class org.apache.kafka.connect.tools.SchemaSourceTask
- THROUGHPUT_CONFIG - Static variable in class org.apache.kafka.connect.tools.VerifiableSourceTask
- Time - Class in org.apache.kafka.connect.data
- 
A time representing a specific point in a day, not tied to any specific date.
- Time() - Constructor for class org.apache.kafka.connect.data.Time
- timeCurrentIdlingStarted() - Method in interface org.apache.kafka.streams.TaskMetadata
- 
Time task idling started.
- timeDifferenceMs() - Method in class org.apache.kafka.streams.kstream.SlidingWindows
- timeIndex() - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
- timeout(long) - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
- 
Set the timeout in milliseconds.
- timeout(Duration) - Method in class org.apache.kafka.streams.KafkaStreams.CloseOptions
- TimeoutException - Exception Class in org.apache.kafka.common.errors
- 
Indicates that a request timed out.
- TimeoutException() - Constructor for exception class org.apache.kafka.common.errors.TimeoutException
- TimeoutException(String) - Constructor for exception class org.apache.kafka.common.errors.TimeoutException
- TimeoutException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.TimeoutException
- TimeoutException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.TimeoutException
- timeoutMs() - Method in class org.apache.kafka.clients.admin.AbstractOptions
- 
The timeout in milliseconds for this operation ornullif the default api timeout for the AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.AbstractOptions
- 
Set the timeout in milliseconds for this operation ornullif the default api timeout for the AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.AlterConfigsOptions
- 
Set the timeout in milliseconds for this operation ornullif the default api timeout for the AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.CreateAclsOptions
- 
Set the timeout in milliseconds for this operation ornullif the default api timeout for the AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.CreateTopicsOptions
- 
Set the timeout in milliseconds for this operation ornullif the default api timeout for the AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DeleteAclsOptions
- 
Set the timeout in milliseconds for this operation ornullif the default api timeout for the AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DeleteTopicsOptions
- 
Set the timeout in milliseconds for this operation ornullif the default api timeout for the AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DescribeAclsOptions
- 
Set the timeout in milliseconds for this operation ornullif the default api timeout for the AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DescribeClusterOptions
- 
Set the timeout in milliseconds for this operation ornullif the default api timeout for the AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DescribeConfigsOptions
- 
Set the timeout in milliseconds for this operation ornullif the default api timeout for the AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DescribeTopicsOptions
- 
Set the timeout in milliseconds for this operation ornullif the default api timeout for the AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
- 
Set the timeout in milliseconds for this operation ornullif the default api timeout for the AdminClient should be used.
- timestamp() - Method in class org.apache.kafka.clients.admin.ListOffsetsResult.ListOffsetsResultInfo
- timestamp() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
- 
The timestamp of this record, in milliseconds elapsed since unix epoch.
- 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.
- timestamp() - Method in exception class org.apache.kafka.common.errors.RecordDeserializationException
- timestamp() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- timestamp() - Method in class org.apache.kafka.connect.mirror.Heartbeat
- timestamp() - Method in interface org.apache.kafka.streams.errors.ErrorHandlerContext
- 
Return the current timestamp; could be-1if it is not available.
- timestamp() - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
- 
The timestamp of the record.
- timestamp() - Method in class org.apache.kafka.streams.processor.api.Record
- 
The timestamp of the record.
- timestamp() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedForward
- 
Deprecated.The timestamp attached to the forwarded record.
- timestamp() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- timestamp() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Return the current timestamp.
- timestamp() - Method in interface org.apache.kafka.streams.processor.RecordContext
- 
Return the current timestamp.
- timestamp() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
- timestamp() - Method in class org.apache.kafka.streams.state.VersionedRecord
- timestamp() - Method in class org.apache.kafka.streams.test.TestRecord
- Timestamp - Class in org.apache.kafka.connect.data
- 
A timestamp representing an absolute time, without timezone information.
- Timestamp() - Constructor for class org.apache.kafka.connect.data.Timestamp
- TIMESTAMP - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemoteStorageManager.IndexType
- 
Represents timestamp index.
- TIMESTAMP_KEY - Static variable in class org.apache.kafka.connect.mirror.Heartbeat
- TIMESTAMP_SIZE - Static variable in class org.apache.kafka.streams.state.StateSerdes
- TimestampedBytesStore - Interface in org.apache.kafka.streams.state
- TimestampedKeyQuery<K,V> - Class in org.apache.kafka.streams.query
- 
Interactive query for retrieving a single record based on its key fromTimestampedKeyValueStore
- timestampedKeyValueStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
- 
AQueryableStoreTypethat acceptsReadOnlyKeyValueStore<K, ValueAndTimestamp<V>>.
- TimestampedKeyValueStore<K,V> - Interface in org.apache.kafka.streams.state
- 
A key-(value/timestamp) store that supports put/get/delete and range queries.
- timestampedKeyValueStoreBuilder(KeyValueBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
- 
Creates aStoreBuilderthat can be used to build aTimestampedKeyValueStore.
- TimestampedRangeQuery<K,V> - Class in org.apache.kafka.streams.query
- 
Interactive query for issuing range queries and scans overTimestampedKeyValueStore
- timestampedWindowStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
- 
AQueryableStoreTypethat acceptsReadOnlyWindowStore<K, ValueAndTimestamp<V>>.
- TimestampedWindowStore<K,V> - Interface in org.apache.kafka.streams.state
- 
Interface for storing the aggregated values of fixed-size time windows.
- timestampedWindowStoreBuilder(WindowBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
- 
Creates aStoreBuilderthat can be used to build aTimestampedWindowStore.
- timestampExtractor - Variable in class org.apache.kafka.streams.TopologyConfig.TaskConfig
- TimestampExtractor - Interface in org.apache.kafka.streams.processor
- 
An interface that allows the Kafka Streams framework to extract a timestamp from an instance ofConsumerRecord.
- timestampExtractorSupplier - Variable in class org.apache.kafka.streams.TopologyConfig
- timestampType() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
- 
The timestamp type of this record
- timestampType() - Method in exception class org.apache.kafka.common.errors.RecordDeserializationException
- timestampType() - Method in class org.apache.kafka.connect.sink.SinkRecord
- timeWindow(long, TimeUnit) - Method in class org.apache.kafka.common.metrics.MetricConfig
- TimeWindowedCogroupedKStream<K,V> - Interface in org.apache.kafka.streams.kstream
- 
TimeWindowedCogroupKStreamis an abstraction of a windowed record stream ofKeyValuepairs.
- TimeWindowedDeserializer<T> - Class in org.apache.kafka.streams.kstream
- TimeWindowedDeserializer() - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
- TimeWindowedDeserializer(Deserializer<T>, Long) - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
- TimeWindowedKStream<K,V> - Interface in org.apache.kafka.streams.kstream
- 
TimeWindowedKStreamis an abstraction of a windowed record stream ofKeyValuepairs.
- TimeWindowedSerde() - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
- TimeWindowedSerde(Serde<T>, long) - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
- timeWindowedSerdeFrom(Class<T>, long) - Static method in class org.apache.kafka.streams.kstream.WindowedSerdes
- 
Construct aTimeWindowedSerdeobject to deserialize changelog topic for the specified inner class type and window size.
- TimeWindowedSerializer<T> - Class in org.apache.kafka.streams.kstream
- TimeWindowedSerializer() - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedSerializer
- TimeWindowedSerializer(Serializer<T>) - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedSerializer
- timeWindowMs() - Method in class org.apache.kafka.common.metrics.MetricConfig
- TimeWindows - Class in org.apache.kafka.streams.kstream
- 
The fixed-size time-based window specifications used for aggregations.
- to(String) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Materialize this stream to a topic using default serializers specified in the config and producer's default partitioning strategy.
- to(String, Produced<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Materialize this stream to a topic using the providedProducedinstance.
- to(TopicNameExtractor<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Dynamically materialize this stream to topics using default serializers specified in the config and producer's default partitioning strategy.
- to(TopicNameExtractor<K, V>, Produced<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Dynamically materialize this stream to topics using the providedProducedinstance.
- To - Class in org.apache.kafka.streams.processor
- 
This class is used to provide the optional parameters when sending output records to downstream processor usingProcessorContext.forward(Object, Object, To).
- toArray() - Method in interface org.apache.kafka.common.header.Headers
- 
Returns all headers as an array, in the order they were added in.
- toArray(List<Uuid>) - Static method in class org.apache.kafka.common.Uuid
- 
Convert a list of Uuid to an array of Uuid.
- toBin(double) - Method in interface org.apache.kafka.common.metrics.stats.Histogram.BinScheme
- 
Determine the 0-based bin number in which the supplied value should be placed.
- toBin(double) - Method in class org.apache.kafka.common.metrics.stats.Histogram.ConstantBinScheme
- toBin(double) - Method in class org.apache.kafka.common.metrics.stats.Histogram.LinearBinScheme
- toCompletionStage() - Method in class org.apache.kafka.common.KafkaFuture
- 
Gets aCompletionStagewith the same completion properties as thisKafkaFuture.
- toConnectData(String, byte[]) - Method in interface org.apache.kafka.connect.storage.Converter
- 
Convert a native object to a Kafka Connect data object for deserialization.
- toConnectData(String, byte[]) - Method in class org.apache.kafka.connect.storage.StringConverter
- toConnectData(String, Headers, byte[]) - Method in interface org.apache.kafka.connect.storage.Converter
- 
Convert a native object to a Kafka Connect data object for deserialization, potentially using the supplied topic and headers in the record as necessary.
- toConnectHeader(String, String, byte[]) - Method in interface org.apache.kafka.connect.storage.HeaderConverter
- 
Convert the header name and byte array value into aHeaderobject.
- toConnectHeader(String, String, byte[]) - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
- toConnectHeader(String, String, byte[]) - Method in class org.apache.kafka.connect.storage.StringConverter
- 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.
- toFile(String) - Static method in class org.apache.kafka.streams.kstream.Printed
- 
Print the records of aKStreamto a file.
- 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.ResourcePattern
- toHtml() - Method in class org.apache.kafka.common.config.ConfigDef
- toHtml(int, Function<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
- 
Converts this config into an HTML list that can be embedded into docs.
- toHtml(int, Function<String, String>, Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
- 
Converts this config into an HTML list that can be embedded into docs.
- toHtml(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
- 
Converts this config into an HTML list that can be embedded into docs.
- toHtmlTable() - Method in class org.apache.kafka.common.config.ConfigDef
- toHtmlTable(String, Iterable<MetricNameTemplate>) - Static method in class org.apache.kafka.common.metrics.Metrics
- 
Use the specified domain and metric name templates to generate an HTML table documenting the metrics.
- 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
- TokenBucket - Class in org.apache.kafka.common.metrics.stats
- 
TheTokenBucketis aMeasurableStatimplementing a token bucket algorithm that is usable within aSensor.
- TokenBucket() - Constructor for class org.apache.kafka.common.metrics.stats.TokenBucket
- TokenBucket(TimeUnit) - Constructor for class org.apache.kafka.common.metrics.stats.TokenBucket
- 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
- TokenInformation(String, KafkaPrincipal, KafkaPrincipal, Collection<KafkaPrincipal>, long, long, long) - Constructor for class org.apache.kafka.common.security.token.delegation.TokenInformation
- tokenRequester() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
- tokenRequesterAsString() - Method in 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
- toList(Uuid[]) - Static method in class org.apache.kafka.common.Uuid
- 
Convert an array of Uuids to a list of Uuid.
- toLogical(Schema, byte[]) - Static method in class org.apache.kafka.connect.data.Decimal
- 
Convert a value from its encoded format (byte[]) to its logical format (BigDecimal).
- toLogical(Schema, int) - Static method in class org.apache.kafka.connect.data.Date
- 
Convert a value from its encoded format (int) to its logical format (Date).
- toLogical(Schema, int) - Static method in class org.apache.kafka.connect.data.Time
- 
Convert a value from its encoded format (int) to its logical format (Date).
- toLogical(Schema, long) - Static method in class org.apache.kafka.connect.data.Timestamp
- 
Convert a value from its encoded format (long) to its logical format (Date).
- topic() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
- 
The topic this record is received from (never null)
- 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.TopicIdPartition
- 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.connect.connector.ConnectRecord
- topic() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
- 
Return the name of the topic to create.
- topic() - Method in interface org.apache.kafka.streams.errors.ErrorHandlerContext
- 
Return the topic name of the current input record; could benullif it is not available.
- topic() - Method in interface org.apache.kafka.streams.processor.api.RecordMetadata
- 
Return the topic name of the current input record; could benullif it is not available.
- topic() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- topic() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Return the topic name of the current input record; could benullif it is not available.
- topic() - Method in interface org.apache.kafka.streams.processor.RecordContext
- 
Return the topic name of the current input record; could benullif it is not available.
- topic() - Method in class org.apache.kafka.streams.state.StateSerdes
- 
Return the topic.
- topic() - Method in interface org.apache.kafka.streams.TopologyDescription.Sink
- 
The topic name this sink node is writing to.
- TOPIC - Enum constant in enum class org.apache.kafka.common.config.ConfigResource.Type
- TOPIC - Enum constant in enum class org.apache.kafka.common.resource.ResourceType
- 
A Kafka topic.
- TOPIC_CONFIG - Static variable in class org.apache.kafka.connect.tools.SchemaSourceTask
- TOPIC_CONFIG - Static variable in class org.apache.kafka.connect.tools.VerifiableSourceTask
- TOPIC_KEY - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
- TOPIC_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Prefix used to provide default topic configs to be applied when creating internal topics.
- TOPIC_PREFIX_ALTERNATIVE - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- TopicAuthorizationException - Exception Class in org.apache.kafka.common.errors
- TopicAuthorizationException(String) - Constructor for exception class org.apache.kafka.common.errors.TopicAuthorizationException
- TopicAuthorizationException(String, Set<String>) - Constructor for exception class org.apache.kafka.common.errors.TopicAuthorizationException
- TopicAuthorizationException(Set<String>) - Constructor for exception class org.apache.kafka.common.errors.TopicAuthorizationException
- TopicCollection - Class in org.apache.kafka.common
- 
A class used to represent a collection of topics.
- TopicCollection.TopicIdCollection - Class in org.apache.kafka.common
- 
A class used to represent a collection of topics defined by their topic ID.
- TopicCollection.TopicNameCollection - Class in org.apache.kafka.common
- 
A class used to represent a collection of topics defined by their topic name.
- 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 Class in org.apache.kafka.common.errors
- TopicDeletionDisabledException() - Constructor for exception class org.apache.kafka.common.errors.TopicDeletionDisabledException
- TopicDeletionDisabledException(String) - Constructor for exception class 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.
- TopicDescription(String, boolean, List<TopicPartitionInfo>, Set<AclOperation>) - Constructor for class org.apache.kafka.clients.admin.TopicDescription
- 
Create an instance with the specified parameters.
- TopicDescription(String, boolean, List<TopicPartitionInfo>, Set<AclOperation>, Uuid) - Constructor for class org.apache.kafka.clients.admin.TopicDescription
- 
Create an instance with the specified parameters.
- TopicExistsException - Exception Class in org.apache.kafka.common.errors
- TopicExistsException(String) - Constructor for exception class org.apache.kafka.common.errors.TopicExistsException
- TopicExistsException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.TopicExistsException
- topicId() - Method in class org.apache.kafka.clients.admin.CreateTopicsResult.TopicMetadataAndConfig
- topicId() - Method in class org.apache.kafka.clients.admin.TopicDescription
- topicId() - Method in class org.apache.kafka.clients.admin.TopicListing
- 
The id of the topic.
- topicId() - Method in class org.apache.kafka.common.TopicIdPartition
- topicId(String) - Method in class org.apache.kafka.clients.admin.CreateTopicsResult
- 
Returns a future that provides topic ID for the topic when the request completes.
- topicId(String) - Method in class org.apache.kafka.common.Cluster
- topicIdPartition() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogMetadata
- topicIdPartition() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentId
- topicIdPartition() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- topicIdPartition() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
- topicIdPartition() - Method in class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteMetadata
- TopicIdPartition - Class in org.apache.kafka.common
- 
This represents universally unique identifier with topic id for a topic partition.
- TopicIdPartition(Uuid, int, String) - Constructor for class org.apache.kafka.common.TopicIdPartition
- 
Create an instance with the provided parameters.
- TopicIdPartition(Uuid, TopicPartition) - Constructor for class org.apache.kafka.common.TopicIdPartition
- 
Create an instance with the provided parameters.
- topicIds() - Method in class org.apache.kafka.common.Cluster
- topicIds() - Method in class org.apache.kafka.common.TopicCollection.TopicIdCollection
- topicIdValues() - Method in class org.apache.kafka.clients.admin.DeleteTopicsResult
- 
Use whenAdmin.deleteTopics(TopicCollection, DeleteTopicsOptions)used a TopicIdCollection
- topicIdValues() - Method in class org.apache.kafka.clients.admin.DescribeTopicsResult
- 
Use whenAdmin.describeTopics(TopicCollection, DescribeTopicsOptions)used a TopicIdCollection
- TopicListing - Class in org.apache.kafka.clients.admin
- 
A listing of a topic in the cluster.
- TopicListing(String, Uuid, boolean) - Constructor for class org.apache.kafka.clients.admin.TopicListing
- 
Create an instance with the specified parameters.
- TopicMetadataAndConfig(ApiException) - Constructor for class org.apache.kafka.clients.admin.CreateTopicsResult.TopicMetadataAndConfig
- TopicMetadataAndConfig(Uuid, int, int, Config) - Constructor for class org.apache.kafka.clients.admin.CreateTopicsResult.TopicMetadataAndConfig
- topicName(Uuid) - Method in class org.apache.kafka.common.Cluster
- topicNameExtractor() - Method in interface org.apache.kafka.streams.TopologyDescription.Sink
- 
TheTopicNameExtractorclass that this sink node uses to dynamically extract the topic name to write to.
- TopicNameExtractor<K,V> - Interface in org.apache.kafka.streams.processor
- 
An interface that allows to dynamically determine the name of the Kafka topic to send at the sink node of the topology.
- topicNames() - Method in class org.apache.kafka.common.TopicCollection.TopicNameCollection
- topicNameValues() - Method in class org.apache.kafka.clients.admin.DeleteTopicsResult
- 
Use whenAdmin.deleteTopics(TopicCollection, DeleteTopicsOptions)used a TopicNameCollection
- topicNameValues() - Method in class org.apache.kafka.clients.admin.DescribeTopicsResult
- 
Use whenAdmin.describeTopics(TopicCollection, DescribeTopicsOptions)used a TopicNameCollection
- topicPartition() - Method in class org.apache.kafka.clients.admin.AbortTransactionSpec
- topicPartition() - Method in exception class org.apache.kafka.common.errors.RecordDeserializationException
- topicPartition() - Method in class org.apache.kafka.common.TopicIdPartition
- topicPartition() - Method in class org.apache.kafka.connect.mirror.Checkpoint
- topicPartition() - Method in interface org.apache.kafka.streams.processor.assignment.TaskTopicPartition
- 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
- TopicPartitionInfo(int, Node, List<Node>, List<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.ListConsumerGroupOffsetsSpec
- 
Returns the topic partitions whose offsets are to be listed for a consumer group.
- topicPartitions() - Method in class org.apache.kafka.clients.admin.MemberAssignment
- 
The topic partitions assigned to a group member.
- topicPartitions() - Method in class org.apache.kafka.clients.admin.ShareMemberAssignment
- 
The topic partitions assigned to a group member.
- topicPartitions() - Method in class org.apache.kafka.clients.admin.TransactionDescription
- topicPartitions() - Method in interface org.apache.kafka.streams.processor.assignment.TaskInfo
- topicPartitions() - Method in interface org.apache.kafka.streams.StreamsMetadata
- 
Source topic partitions of the active tasks of the Streams client.
- topicPartitions() - Method in interface org.apache.kafka.streams.TaskMetadata
- 
Source topic partitions of the task.
- topicPartitions(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsSpec
- 
Set the topic partitions whose offsets are to be listed for a consumer group.
- topicPattern() - Method in interface org.apache.kafka.streams.TopologyDescription.Source
- 
The pattern used to match topic names that is reading from.
- topicPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
- 
Prefix a property withStreamsConfig.TOPIC_PREFIXused to provide default topic configs to be applied when creating internal topics.
- topics() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
- topics() - Method in class org.apache.kafka.common.Cluster
- 
Get all topics.
- TOPICS_CONFIG - Static variable in class org.apache.kafka.connect.sink.SinkConnector
- 
Configuration key for the list of input topics for this connector.
- TOPICS_CONFIG - Static variable in class org.apache.kafka.connect.sink.SinkTask
- 
The configuration key that provides the list of topics that are inputs for this SinkTask.
- TOPICS_REGEX_CONFIG - Static variable in class org.apache.kafka.connect.sink.SinkTask
- 
The configuration key that provides a regex specifying which topics to include as inputs for this SinkTask.
- topicSet() - Method in interface org.apache.kafka.streams.TopologyDescription.Source
- 
The topic names this source node is reading from.
- topicSource(String) - Method in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
- topicSource(String) - Method in class org.apache.kafka.connect.mirror.IdentityReplicationPolicy
- 
UnlikeDefaultReplicationPolicy, IdentityReplicationPolicy cannot know the source of a remote topic based on its name alone.
- topicSource(String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
- 
Returns the source cluster alias of given topic.
- Topology - Class in org.apache.kafka.streams
- 
A logical representation of aProcessorTopology.
- Topology() - Constructor for class org.apache.kafka.streams.Topology
- Topology(TopologyConfig) - Constructor for class org.apache.kafka.streams.Topology
- TOPOLOGY_OPTIMIZATION_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
topology.optimization
- Topology.AutoOffsetReset - Enum Class in org.apache.kafka.streams
- 
Deprecated.Since 4.0. UseAutoOffsetResetinstead.
- TopologyConfig - Class in org.apache.kafka.streams
- 
Streams configs that apply at the topology level.
- TopologyConfig(String, StreamsConfig, Properties) - Constructor for class org.apache.kafka.streams.TopologyConfig
- TopologyConfig(StreamsConfig) - Constructor for class org.apache.kafka.streams.TopologyConfig
- TopologyConfig.InternalConfig - Class in org.apache.kafka.streams
- TopologyConfig.TaskConfig - Class in org.apache.kafka.streams
- TopologyDescription - Interface in org.apache.kafka.streams
- 
A meta representation of atopology.
- TopologyDescription.GlobalStore - Interface in org.apache.kafka.streams
- 
Represents aglobal store.
- TopologyDescription.Node - Interface in org.apache.kafka.streams
- 
A node of a topology.
- TopologyDescription.Processor - Interface in org.apache.kafka.streams
- 
A processor node of a topology.
- TopologyDescription.Sink - Interface in org.apache.kafka.streams
- 
A sink node of a topology.
- TopologyDescription.Source - Interface in org.apache.kafka.streams
- 
A source node of a topology.
- TopologyDescription.Subtopology - Interface in org.apache.kafka.streams
- 
A connected sub-graph of aTopology.
- TopologyException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates a pre run time error occurred while parsing thelogical topologyto construct thephysical processor topology.
- TopologyException(String) - Constructor for exception class org.apache.kafka.streams.errors.TopologyException
- TopologyException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.TopologyException
- TopologyException(Throwable) - Constructor for exception class org.apache.kafka.streams.errors.TopologyException
- topologyName - Variable in class org.apache.kafka.streams.TopologyConfig
- topologyName() - Method in class org.apache.kafka.streams.processor.TaskId
- 
Experimental feature -- will return null
- topologyOverrides - Variable in class org.apache.kafka.streams.TopologyConfig
- TopologyTestDriver - Class in org.apache.kafka.streams
- 
This class makes it easier to write tests to verify the behavior of topologies created withTopologyorStreamsBuilder.
- TopologyTestDriver(Topology) - Constructor for class org.apache.kafka.streams.TopologyTestDriver
- 
Create a new test diver instance.
- TopologyTestDriver(Topology, Instant) - Constructor for class org.apache.kafka.streams.TopologyTestDriver
- 
Create a new test diver instance.
- TopologyTestDriver(Topology, Properties) - Constructor for class org.apache.kafka.streams.TopologyTestDriver
- 
Create a new test diver instance.
- TopologyTestDriver(Topology, Properties, Instant) - Constructor for class org.apache.kafka.streams.TopologyTestDriver
- 
Create a new test diver instance.
- toRst() - Method in class org.apache.kafka.common.config.ConfigDef
- 
Get the configs formatted with reStructuredText, suitable for embedding in Sphinx documentation.
- toStream() - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Convert this changelog stream to aKStream.
- toStream(KeyValueMapper<? super K, ? super V, ? extends KR>) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Convert this changelog stream to aKStreamusing the givenKeyValueMapperto select the new key.
- toStream(KeyValueMapper<? super K, ? super V, ? extends KR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Convert this changelog stream to aKStreamusing the givenKeyValueMapperto select the new key.
- toStream(Named) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Convert this changelog stream to aKStream.
- toString() - Method in class org.apache.kafka.clients.admin.AbortTransactionOptions
- toString() - Method in class org.apache.kafka.clients.admin.AbortTransactionSpec
- toString() - Method in class org.apache.kafka.clients.admin.AlterConfigOp
- toString() - Method in class org.apache.kafka.clients.admin.ClassicGroupDescription
- toString() - Method in class org.apache.kafka.clients.admin.ClientMetricsResourceListing
- 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
- 
Override toString to redact sensitive value.
- 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.DescribeProducersOptions
- toString() - Method in class org.apache.kafka.clients.admin.DescribeProducersResult.PartitionProducerState
- toString() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
- toString() - Method in class org.apache.kafka.clients.admin.DescribeTransactionsOptions
- toString() - Method in class org.apache.kafka.clients.admin.FeatureMetadata
- toString() - Method in class org.apache.kafka.clients.admin.FeatureUpdate
- toString() - Method in class org.apache.kafka.clients.admin.FenceProducersOptions
- toString() - Method in class org.apache.kafka.clients.admin.FinalizedVersionRange
- toString() - Method in class org.apache.kafka.clients.admin.GroupListing
- toString() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsSpec
- toString() - Method in class org.apache.kafka.clients.admin.ListOffsetsResult.ListOffsetsResultInfo
- toString() - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
- toString() - Method in class org.apache.kafka.clients.admin.ListTransactionsOptions
- toString() - Method in class org.apache.kafka.clients.admin.LogDirDescription
- 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.PartitionReassignment
- toString() - Method in class org.apache.kafka.clients.admin.ProducerState
- toString() - Method in class org.apache.kafka.clients.admin.QuorumInfo.Node
- toString() - Method in class org.apache.kafka.clients.admin.QuorumInfo.ReplicaState
- toString() - Method in class org.apache.kafka.clients.admin.QuorumInfo
- toString() - Method in class org.apache.kafka.clients.admin.RaftVoterEndpoint
- toString() - Method in class org.apache.kafka.clients.admin.RecordsToDelete
- toString() - Method in class org.apache.kafka.clients.admin.ReplicaInfo
- toString() - Method in class org.apache.kafka.clients.admin.ScramCredentialInfo
- toString() - Method in class org.apache.kafka.clients.admin.ShareGroupDescription
- toString() - Method in class org.apache.kafka.clients.admin.ShareMemberAssignment
- toString() - Method in class org.apache.kafka.clients.admin.ShareMemberDescription
- toString() - Method in class org.apache.kafka.clients.admin.SupportedVersionRange
- 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.admin.TransactionDescription
- toString() - Method in class org.apache.kafka.clients.admin.TransactionListing
- toString() - Method in enum class org.apache.kafka.clients.admin.TransactionState
- toString() - Method in class org.apache.kafka.clients.admin.UserScramCredentialsDescription
- toString() - Method in enum class org.apache.kafka.clients.consumer.AcknowledgeType
- toString() - Method in class org.apache.kafka.clients.consumer.ConsumerGroupMetadata
- toString() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Assignment
- toString() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.GroupAssignment
- toString() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.GroupSubscription
- toString() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
- 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 enum class org.apache.kafka.clients.consumer.OffsetResetStrategy
- 
Deprecated.
- toString() - Method in class org.apache.kafka.clients.consumer.SubscriptionPattern
- 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 enum class org.apache.kafka.common.ClassicGroupState
- 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.CaseInsensitiveValidString
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.CompositeValidator
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.LambdaValidator
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.ListSize
- 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 class org.apache.kafka.common.config.SslClientAuth
- toString() - Method in enum class org.apache.kafka.common.ConsumerGroupState
- 
Deprecated.
- toString() - Method in class org.apache.kafka.common.Endpoint
- toString() - Method in enum class org.apache.kafka.common.GroupState
- toString() - Method in enum class org.apache.kafka.common.GroupType
- toString() - Method in enum class org.apache.kafka.common.IsolationLevel
- 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.metrics.Quota
- toString() - Method in exception class org.apache.kafka.common.metrics.QuotaViolationException
- toString() - Method in class org.apache.kafka.common.metrics.stats.CumulativeSum
- toString() - Method in class org.apache.kafka.common.metrics.stats.Frequency
- toString() - Method in class org.apache.kafka.common.metrics.stats.Histogram
- toString() - Method in class org.apache.kafka.common.metrics.stats.Meter
- toString() - Method in class org.apache.kafka.common.metrics.stats.Rate
- toString() - Method in class org.apache.kafka.common.metrics.stats.SampledStat
- toString() - Method in class org.apache.kafka.common.metrics.stats.TokenBucket
- 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.quota.ClientQuotaAlteration.Op
- toString() - Method in class org.apache.kafka.common.quota.ClientQuotaAlteration
- toString() - Method in class org.apache.kafka.common.quota.ClientQuotaEntity
- toString() - Method in class org.apache.kafka.common.quota.ClientQuotaFilter
- toString() - Method in class org.apache.kafka.common.quota.ClientQuotaFilterComponent
- toString() - Method in class org.apache.kafka.common.resource.Resource
- 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.TopicIdPartition
- 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.common.Uuid
- 
Returns a base64 string encoding of the UUID.
- toString() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- toString() - Method in class org.apache.kafka.connect.data.ConnectSchema
- toString() - Method in class org.apache.kafka.connect.data.Field
- toString() - Method in class org.apache.kafka.connect.data.SchemaAndValue
- toString() - Method in class org.apache.kafka.connect.data.Struct
- toString() - Method in class org.apache.kafka.connect.header.ConnectHeaders
- toString() - Method in class org.apache.kafka.connect.health.ConnectorHealth
- toString() - Method in class org.apache.kafka.connect.health.ConnectorState
- toString() - Method in enum class org.apache.kafka.connect.health.ConnectorType
- toString() - Method in class org.apache.kafka.connect.health.TaskState
- toString() - Method in class org.apache.kafka.connect.mirror.Checkpoint
- toString() - Method in class org.apache.kafka.connect.mirror.Heartbeat
- toString() - Method in class org.apache.kafka.connect.mirror.SourceAndTarget
- toString() - Method in class org.apache.kafka.connect.sink.SinkRecord
- toString() - Method in class org.apache.kafka.connect.source.SourceRecord
- toString() - Method in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
- toString() - Method in class org.apache.kafka.coordinator.group.api.assignor.GroupAssignment
- toString() - Method in enum class org.apache.kafka.coordinator.group.api.assignor.SubscriptionType
- toString() - Method in class org.apache.kafka.server.authorizer.Action
- toString() - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
- toString() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentId
- toString() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata.CustomMetadata
- toString() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- toString() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
- toString() - Method in class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteMetadata
- toString() - Method in class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
- toString() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
- toString() - Method in class org.apache.kafka.streams.KeyQueryMetadata
- toString() - Method in class org.apache.kafka.streams.KeyValue
- toString() - Method in class org.apache.kafka.streams.kstream.JoinWindows
- toString() - Method in class org.apache.kafka.streams.kstream.SessionWindows
- toString() - Method in class org.apache.kafka.streams.kstream.SlidingWindows
- toString() - Method in class org.apache.kafka.streams.kstream.StreamJoined
- toString() - Method in class org.apache.kafka.streams.kstream.TimeWindows
- toString() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
- toString() - Method in class org.apache.kafka.streams.kstream.Window
- toString() - Method in class org.apache.kafka.streams.kstream.Windowed
- toString() - Method in class org.apache.kafka.streams.LagInfo
- toString() - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
- toString() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedForward
- toString() - Method in class org.apache.kafka.streams.processor.api.Record
- toString() - Method in class org.apache.kafka.streams.processor.assignment.AssignmentConfigs
- toString() - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask
- toString() - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment
- toString() - Method in class org.apache.kafka.streams.processor.assignment.ProcessId
- toString() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedForward
- 
Deprecated.
- toString() - Method in class org.apache.kafka.streams.processor.TaskId
- toString() - Method in class org.apache.kafka.streams.processor.To
- toString() - Method in class org.apache.kafka.streams.query.Position
- toString() - Method in class org.apache.kafka.streams.query.PositionBound
- toString() - Method in class org.apache.kafka.streams.query.StateQueryResult
- toString() - Method in class org.apache.kafka.streams.query.WindowKeyQuery
- toString() - Method in class org.apache.kafka.streams.query.WindowRangeQuery
- toString() - Method in class org.apache.kafka.streams.state.DslKeyValueParams
- toString() - Method in class org.apache.kafka.streams.state.DslSessionParams
- toString() - Method in class org.apache.kafka.streams.state.DslWindowParams
- toString() - Method in class org.apache.kafka.streams.state.HostInfo
- toString() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
- toString() - Method in class org.apache.kafka.streams.state.VersionedRecord
- toString() - Method in class org.apache.kafka.streams.StoreQueryParameters
- toString() - Method in class org.apache.kafka.streams.test.TestRecord
- toString() - Method in class org.apache.kafka.streams.TestInputTopic
- toString() - Method in class org.apache.kafka.streams.TestOutputTopic
- toSysOut() - Static method in class org.apache.kafka.streams.kstream.Printed
- 
Print the records of aKStreamto system out.
- toTable() - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Convert this stream to aKTable.
- toTable(Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Convert this stream to aKTable.
- toTable(Named) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Convert this stream to aKTable.
- toTable(Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KStream
- 
Convert this stream to aKTable.
- totalBytes() - Method in class org.apache.kafka.clients.admin.LogDirDescription
- 
The total size of the volume this log directory is on or empty if the broker did not return a value.
- totalCount() - Method in class org.apache.kafka.clients.admin.NewPartitions
- 
The total number of partitions after the operation succeeds.
- toTime() - Method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
- 
The ending time point of the query, if specified
- toTime(Instant) - Method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
- 
Specifies the ending time point for the key query.
- TRACE - Enum constant in enum class org.apache.kafka.common.metrics.Sensor.RecordingLevel
- TRACE_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
- 
TheTRACElevel designates finer-grained informational events than theDEBUGlevel.
- traceMessage() - Method in class org.apache.kafka.connect.health.AbstractState
- 
The error message associated with the connector or task.
- TRANSACTION - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemoteStorageManager.IndexType
- 
Represents transaction index.
- TRANSACTION_BOUNDARY_CONFIG - Static variable in class org.apache.kafka.connect.source.SourceTask
- 
The configuration key that determines how source tasks will define transaction boundaries when exactly-once support is enabled.
- 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
- TransactionAbortableException - Exception Class in org.apache.kafka.common.errors
- TransactionAbortableException(String) - Constructor for exception class org.apache.kafka.common.errors.TransactionAbortableException
- transactionAborted() - Method in class org.apache.kafka.clients.producer.MockProducer
- TransactionAbortedException - Exception Class in org.apache.kafka.common.errors
- 
This is the Exception thrown when we are aborting any undrained batches during a transaction which is aborted without any underlying cause - which likely means that the user chose to abort.
- TransactionAbortedException() - Constructor for exception class org.apache.kafka.common.errors.TransactionAbortedException
- TransactionAbortedException(String) - Constructor for exception class org.apache.kafka.common.errors.TransactionAbortedException
- TransactionAbortedException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.TransactionAbortedException
- TRANSACTIONAL_ID - Enum constant in enum class 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
- transactionalId() - Method in class org.apache.kafka.clients.admin.TransactionListing
- TransactionalIdAuthorizationException - Exception Class in org.apache.kafka.common.errors
- TransactionalIdAuthorizationException(String) - Constructor for exception class org.apache.kafka.common.errors.TransactionalIdAuthorizationException
- TransactionalIdNotFoundException - Exception Class in org.apache.kafka.common.errors
- TransactionalIdNotFoundException(String) - Constructor for exception class org.apache.kafka.common.errors.TransactionalIdNotFoundException
- transactionCommitted() - Method in class org.apache.kafka.clients.producer.MockProducer
- transactionContext() - Method in interface org.apache.kafka.connect.source.SourceTaskContext
- 
Get aTransactionContextthat can be used to define producer transaction boundaries when exactly-once support is enabled for the connector.
- TransactionContext - Interface in org.apache.kafka.connect.source
- 
Provided to source tasks to allow them to define their own producer transaction boundaries when exactly-once support is enabled.
- TransactionCoordinatorFencedException - Exception Class in org.apache.kafka.common.errors
- TransactionCoordinatorFencedException(String) - Constructor for exception class org.apache.kafka.common.errors.TransactionCoordinatorFencedException
- TransactionCoordinatorFencedException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.TransactionCoordinatorFencedException
- TransactionDescription - Class in org.apache.kafka.clients.admin
- TransactionDescription(int, TransactionState, long, int, long, OptionalLong, Set<TopicPartition>) - Constructor for class org.apache.kafka.clients.admin.TransactionDescription
- transactionIndex() - Method in class org.apache.kafka.server.log.remote.storage.LogSegmentData
- transactionInFlight() - Method in class org.apache.kafka.clients.producer.MockProducer
- transactionInitialized() - Method in class org.apache.kafka.clients.producer.MockProducer
- TransactionListing - Class in org.apache.kafka.clients.admin
- TransactionListing(String, long, TransactionState) - Constructor for class org.apache.kafka.clients.admin.TransactionListing
- transactionStartTimeMs() - Method in class org.apache.kafka.clients.admin.TransactionDescription
- TransactionState - Enum Class in org.apache.kafka.clients.admin
- transactionTimeoutMs() - Method in class org.apache.kafka.clients.admin.TransactionDescription
- transform(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigTransformer
- 
Transforms the given configuration data by using theConfigProviderinstances to look up values to replace the variables in the pattern.
- transform(K, V) - Method in interface org.apache.kafka.streams.kstream.Transformer
- 
Deprecated.Transform the record with the given key and value.
- transform(K, V) - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKey
- 
Transform the given [key and] value to a new value.
- transform(V) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
- 
Deprecated.Transform the given value to a new value.
- Transformation<R> - Interface in org.apache.kafka.connect.transforms
- 
Single message transformation for Kafka Connect record types.
- Transformer<K,V, - Interface in org.apache.kafka.streams.kstreamR> 
- 
Deprecated.Since 4.0. Useapi.Processorinstead.
- TransformerSupplier<K,V, - Interface in org.apache.kafka.streams.kstreamR> 
- 
Deprecated.Since 4.0. Useapi.ProcessorSupplierinstead.
- transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTableby transforming the value of each record in thisKTableinto a new value (with possibly a new type), with default serializers, deserializers, and state store.
- transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTableby transforming the value of each record in thisKTableinto a new value (with possibly a new type), with thekey serde,value serde, and the underlyingmaterialized state storageconfigured in theMaterializedinstance.
- transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTableby transforming the value of each record in thisKTableinto a new value (with possibly a new type), with thekey serde,value serde, and the underlyingmaterialized state storageconfigured in theMaterializedinstance.
- transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
- 
Create a newKTableby transforming the value of each record in thisKTableinto a new value (with possibly a new type), with default serializers, deserializers, and state store.
- translateOffsets(Map<String, Object>, String, String, Duration) - Static method in class org.apache.kafka.connect.mirror.RemoteClusterUtils
- 
Translates a remote consumer group's offsets into corresponding local offsets.
- truststore() - Method in interface org.apache.kafka.common.security.auth.SslEngineFactory
- 
Returns truststore configured for this factory.
- 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.clients.admin.ConfigEntry
- 
Return the config data type.
- type() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
- 
The group type (or the protocol) of this consumer group.
- type() - Method in class org.apache.kafka.clients.admin.ConsumerGroupListing
- 
The type of the consumer group.
- type() - Method in class org.apache.kafka.clients.admin.GroupListing
- 
The type of the group.
- type() - Method in enum class org.apache.kafka.clients.admin.ScramMechanism
- type() - Method in class org.apache.kafka.common.config.ConfigDef.ConfigKey
- type() - Method in class org.apache.kafka.common.config.ConfigResource
- 
Return the resource type.
- type() - Method in class org.apache.kafka.connect.data.ConnectSchema
- type() - Method in interface org.apache.kafka.connect.data.Schema
- type() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- type() - Method in class org.apache.kafka.connect.health.ConnectorHealth
- 
Provides the type of the connector.
- type() - Method in class org.apache.kafka.connect.storage.ConverterConfig
- 
Get the type of converter as defined by theConverterConfig.TYPE_CONFIGconfiguration.
- type() - Method in interface org.apache.kafka.streams.kstream.EmitStrategy
- 
Returns the strategy type.
- type() - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask
- type(Schema.Type) - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- 
Create a SchemaBuilder for the specified type.
- TYPE_CONFIG - Static variable in class org.apache.kafka.connect.storage.ConverterConfig
- typeOf(String) - Method in class org.apache.kafka.common.config.AbstractConfig
- types() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsOptions
- 
Returns the list of group types that are requested or empty if no types have been specified.
- types() - Method in class org.apache.kafka.clients.admin.ListGroupsOptions
- 
Returns the list of group types that are requested or empty if no types have been specified.
U
- UnacceptableCredentialException - Exception Class in org.apache.kafka.common.errors
- 
Exception thrown when attempting to define a credential that does not meet the criteria for acceptability (for example, attempting to create a SCRAM credential with an empty username or password or too few/many iterations).
- UnacceptableCredentialException(String) - Constructor for exception class org.apache.kafka.common.errors.UnacceptableCredentialException
- 
Constructor
- UnacceptableCredentialException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.UnacceptableCredentialException
- unauthorizedTopics() - Method in class org.apache.kafka.common.Cluster
- unauthorizedTopics() - Method in exception class org.apache.kafka.common.errors.TopicAuthorizationException
- 
Get the set of topics which failed authorization.
- unavailable() - Static method in class org.apache.kafka.streams.state.HostInfo
- unbounded() - Static method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
- 
Create a buffer unconstrained by size (either keys or bytes).
- unbounded() - Static method in class org.apache.kafka.streams.query.PositionBound
- 
Creates a new PositionBound representing "no bound"
- UNCLEAN - Enum constant in enum class org.apache.kafka.common.ElectionType
- 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
- uncommittedOffsets() - Method in class org.apache.kafka.clients.producer.MockProducer
- uncommittedRecords() - Method in class org.apache.kafka.clients.producer.MockProducer
- unitName() - Method in class org.apache.kafka.common.metrics.stats.Rate
- UNKNOWN - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
- UNKNOWN - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigType
- UNKNOWN - Enum constant in enum class org.apache.kafka.clients.admin.EndpointType
- UNKNOWN - Enum constant in enum class org.apache.kafka.clients.admin.FeatureUpdate.UpgradeType
- UNKNOWN - Enum constant in enum class org.apache.kafka.clients.admin.ScramMechanism
- UNKNOWN - Enum constant in enum class org.apache.kafka.clients.admin.TransactionState
- UNKNOWN - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
- 
Represents any AclOperation which this client cannot understand, perhaps because this client is too old.
- UNKNOWN - Enum constant in enum class org.apache.kafka.common.acl.AclPermissionType
- 
Represents any AclPermissionType which this client cannot understand, perhaps because this client is too old.
- UNKNOWN - Enum constant in enum class org.apache.kafka.common.ClassicGroupState
- UNKNOWN - Enum constant in enum class org.apache.kafka.common.config.ConfigResource.Type
- UNKNOWN - Enum constant in enum class org.apache.kafka.common.ConsumerGroupState
- 
Deprecated.
- UNKNOWN - Enum constant in enum class org.apache.kafka.common.GroupState
- UNKNOWN - Enum constant in enum class org.apache.kafka.common.GroupType
- UNKNOWN - Enum constant in enum class org.apache.kafka.common.resource.PatternType
- 
Represents any PatternType which this client cannot understand, perhaps because this client is too old.
- UNKNOWN - Enum constant in enum class org.apache.kafka.common.resource.ResourceType
- 
Represents any ResourceType which this client cannot understand, perhaps because this client is too old.
- UNKNOWN - Enum constant in enum class org.apache.kafka.connect.health.ConnectorType
- 
Identifies a connector whose type could not be inferred
- UNKNOWN_PARTITION - Static variable in class org.apache.kafka.clients.producer.RecordMetadata
- 
Partition value for record without partition assigned
- UNKNOWN_PROCESS_ID - Enum constant in enum class org.apache.kafka.streams.processor.assignment.TaskAssignor.AssignmentError
- UNKNOWN_QUERY_TYPE - Enum constant in enum class org.apache.kafka.streams.query.FailureReason
- 
Failure indicating that the store doesn't know how to handle the given query.
- UNKNOWN_TASK_ID - Enum constant in enum class org.apache.kafka.streams.processor.assignment.TaskAssignor.AssignmentError
- UnknownControllerIdException - Exception Class in org.apache.kafka.common.errors
- UnknownControllerIdException(String) - Constructor for exception class org.apache.kafka.common.errors.UnknownControllerIdException
- UnknownLeaderEpochException - Exception Class 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 class org.apache.kafka.common.errors.UnknownLeaderEpochException
- UnknownLeaderEpochException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.UnknownLeaderEpochException
- UnknownMemberIdException - Exception Class in org.apache.kafka.common.errors
- UnknownMemberIdException() - Constructor for exception class org.apache.kafka.common.errors.UnknownMemberIdException
- UnknownMemberIdException(String) - Constructor for exception class org.apache.kafka.common.errors.UnknownMemberIdException
- UnknownMemberIdException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.UnknownMemberIdException
- UnknownMemberIdException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.UnknownMemberIdException
- UnknownProducerIdException - Exception Class 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 class org.apache.kafka.common.errors.UnknownProducerIdException
- UnknownServerException - Exception Class 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 class org.apache.kafka.common.errors.UnknownServerException
- UnknownServerException(String) - Constructor for exception class org.apache.kafka.common.errors.UnknownServerException
- UnknownServerException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.UnknownServerException
- UnknownServerException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.UnknownServerException
- UnknownStateStoreException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates that the state store being queried is unknown, i.e., the state store does either not exist in your topology or it is not queryable.
- UnknownStateStoreException(String) - Constructor for exception class org.apache.kafka.streams.errors.UnknownStateStoreException
- UnknownStateStoreException(String, Throwable) - Constructor for exception class org.apache.kafka.streams.errors.UnknownStateStoreException
- UnknownSubscriptionIdException - Exception Class in org.apache.kafka.common.errors
- 
This exception indicates that the client sent an invalid or outdated SubscriptionId
- UnknownSubscriptionIdException(String) - Constructor for exception class org.apache.kafka.common.errors.UnknownSubscriptionIdException
- UnknownTopicIdException - Exception Class in org.apache.kafka.common.errors
- UnknownTopicIdException(String) - Constructor for exception class org.apache.kafka.common.errors.UnknownTopicIdException
- UnknownTopicOrPartitionException - Exception Class in org.apache.kafka.common.errors
- 
This topic/partition doesn't exist.
- UnknownTopicOrPartitionException() - Constructor for exception class org.apache.kafka.common.errors.UnknownTopicOrPartitionException
- UnknownTopicOrPartitionException(String) - Constructor for exception class org.apache.kafka.common.errors.UnknownTopicOrPartitionException
- UnknownTopicOrPartitionException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.UnknownTopicOrPartitionException
- UnknownTopicOrPartitionException(Throwable) - Constructor for exception class org.apache.kafka.common.errors.UnknownTopicOrPartitionException
- UnknownTopologyException - Exception Class in org.apache.kafka.streams.errors
- 
Indicates that theNamedTopologybeing looked up does not exist in this application
- UnknownTopologyException(String, String) - Constructor for exception class org.apache.kafka.streams.errors.UnknownTopologyException
- UnknownTopologyException(String, Throwable, String) - Constructor for exception class org.apache.kafka.streams.errors.UnknownTopologyException
- UnlimitedWindows - Class in org.apache.kafka.streams.kstream
- 
The unlimited window specifications used for aggregations.
- unregisterBroker(int) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Unregister a broker.
- unregisterBroker(int, UnregisterBrokerOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Unregister a broker.
- unregisterBroker(int, UnregisterBrokerOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- unregisterBroker(int, UnregisterBrokerOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- UnregisterBrokerOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.unregisterBroker(int, UnregisterBrokerOptions).
- UnregisterBrokerOptions() - Constructor for class org.apache.kafka.clients.admin.UnregisterBrokerOptions
- UnregisterBrokerResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.unregisterBroker(int, UnregisterBrokerOptions)call.
- unregisterMetricFromSubscription(KafkaMetric) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Remove the provided application metric for subscription.
- unregisterMetricFromSubscription(KafkaMetric) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- unregisterMetricFromSubscription(KafkaMetric) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- unregisterMetricFromSubscription(KafkaMetric) - Method in interface org.apache.kafka.clients.consumer.Consumer
- unregisterMetricFromSubscription(KafkaMetric) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
- 
Remove the provided application metric for subscription.
- unregisterMetricFromSubscription(KafkaMetric) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- unregisterMetricFromSubscription(KafkaMetric) - Method in class org.apache.kafka.clients.producer.KafkaProducer
- 
Remove the provided application metric for subscription.
- unregisterMetricFromSubscription(KafkaMetric) - Method in class org.apache.kafka.clients.producer.MockProducer
- unregisterMetricFromSubscription(KafkaMetric) - Method in interface org.apache.kafka.clients.producer.Producer
- UnreleasedInstanceIdException - Exception Class in org.apache.kafka.common.errors
- UnreleasedInstanceIdException(String) - Constructor for exception class org.apache.kafka.common.errors.UnreleasedInstanceIdException
- UNSAFE_DOWNGRADE - Enum constant in enum class org.apache.kafka.clients.admin.FeatureUpdate.UpgradeType
- UnstableOffsetCommitException - Exception Class in org.apache.kafka.common.errors
- 
Exception thrown when there are unstable offsets for the requested topic partitions.
- UnstableOffsetCommitException(String) - Constructor for exception class org.apache.kafka.common.errors.UnstableOffsetCommitException
- 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 withKafkaConsumer.subscribe(Collection)orKafkaConsumer.subscribe(Pattern).
- unsubscribe() - Method in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- 
Unsubscribe from topics currently subscribed withKafkaShareConsumer.subscribe(Collection).
- unsubscribe() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- unsubscribe() - Method in class org.apache.kafka.clients.consumer.MockShareConsumer
- unsubscribe() - Method in interface org.apache.kafka.clients.consumer.ShareConsumer
- 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).
- UNSUPPORTED - Enum constant in enum class org.apache.kafka.connect.source.ConnectorTransactionBoundaries
- 
Signals that a connector cannot define its own transaction boundaries.
- UNSUPPORTED - Enum constant in enum class org.apache.kafka.connect.source.ExactlyOnceSupport
- 
Signals that a connector does not support exactly-once semantics.
- UnsupportedAssignorException - Exception Class in org.apache.kafka.common.errors
- UnsupportedAssignorException(String) - Constructor for exception class org.apache.kafka.common.errors.UnsupportedAssignorException
- UnsupportedByAuthenticationException - Exception Class in org.apache.kafka.common.errors
- 
Authentication mechanism does not support the requested function.
- UnsupportedByAuthenticationException(String) - Constructor for exception class org.apache.kafka.common.errors.UnsupportedByAuthenticationException
- UnsupportedByAuthenticationException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.UnsupportedByAuthenticationException
- UnsupportedCompressionTypeException - Exception Class in org.apache.kafka.common.errors
- 
The requesting client does not support the compression type of given partition.
- UnsupportedCompressionTypeException(String) - Constructor for exception class org.apache.kafka.common.errors.UnsupportedCompressionTypeException
- UnsupportedCompressionTypeException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.UnsupportedCompressionTypeException
- UnsupportedEndpointTypeException - Exception Class in org.apache.kafka.common.errors
- UnsupportedEndpointTypeException(String) - Constructor for exception class org.apache.kafka.common.errors.UnsupportedEndpointTypeException
- UnsupportedForMessageFormatException - Exception Class in org.apache.kafka.common.errors
- 
The message format version does not support the requested function.
- UnsupportedForMessageFormatException(String) - Constructor for exception class org.apache.kafka.common.errors.UnsupportedForMessageFormatException
- UnsupportedForMessageFormatException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.UnsupportedForMessageFormatException
- UnsupportedSaslMechanismException - Exception Class 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 class org.apache.kafka.common.errors.UnsupportedSaslMechanismException
- UnsupportedSaslMechanismException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.UnsupportedSaslMechanismException
- UnsupportedVersionException - Exception Class 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 class org.apache.kafka.common.errors.UnsupportedVersionException
- UnsupportedVersionException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.UnsupportedVersionException
- untilTimeLimit(Duration, Suppressed.BufferConfig<?>) - Static method in interface org.apache.kafka.streams.kstream.Suppressed
- 
Configure the suppression to waittimeToWaitForMoreEventsamount of time after receiving a record before emitting it further downstream.
- untilWindowCloses(Suppressed.StrictBufferConfig) - Static method in interface org.apache.kafka.streams.kstream.Suppressed
- 
Configure the suppression to emit only the "final results" from the window.
- 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
- 
This callback is invoked whenever there are changes in the cluster metadata, such as brokers being added or removed, topics being created or deleted, or partition leadership updates.
- updateDurationOffsets(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- updateEndOffsets(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- updateFeatures(Map<String, FeatureUpdate>, UpdateFeaturesOptions) - Method in interface org.apache.kafka.clients.admin.Admin
- 
Applies specified updates to finalized features.
- updateFeatures(Map<String, FeatureUpdate>, UpdateFeaturesOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- updateFeatures(Map<String, FeatureUpdate>, UpdateFeaturesOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- UpdateFeaturesOptions - Class in org.apache.kafka.clients.admin
- 
Options forAdmin.updateFeatures(Map, UpdateFeaturesOptions).
- UpdateFeaturesOptions() - Constructor for class org.apache.kafka.clients.admin.UpdateFeaturesOptions
- UpdateFeaturesResult - Class in org.apache.kafka.clients.admin
- 
The result of theAdmin.updateFeatures(Map, UpdateFeaturesOptions)call.
- 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 the quorum.
- updateRemoteLogSegmentMetadata(RemoteLogSegmentMetadataUpdate) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
- 
This method is used to update theRemoteLogSegmentMetadataasynchronously.
- UPGRADE - Enum constant in enum class org.apache.kafka.clients.admin.FeatureUpdate.UpgradeType
- UPGRADE_FROM_0100 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version0.10.0.x.
- UPGRADE_FROM_0101 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version0.10.1.x.
- UPGRADE_FROM_0102 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version0.10.2.x.
- UPGRADE_FROM_0110 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version0.11.0.x.
- UPGRADE_FROM_10 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version1.0.x.
- UPGRADE_FROM_11 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version1.1.x.
- UPGRADE_FROM_20 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version2.0.x.
- UPGRADE_FROM_21 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version2.1.x.
- UPGRADE_FROM_22 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version2.2.x.
- UPGRADE_FROM_23 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version2.3.x.
- UPGRADE_FROM_24 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version2.4.x.
- UPGRADE_FROM_25 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version2.5.x.
- UPGRADE_FROM_26 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version2.6.x.
- UPGRADE_FROM_27 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version2.7.x.
- UPGRADE_FROM_28 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version2.8.x.
- UPGRADE_FROM_30 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version3.0.x.
- UPGRADE_FROM_31 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version3.1.x.
- UPGRADE_FROM_32 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version3.2.x.
- UPGRADE_FROM_33 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version3.3.x.
- UPGRADE_FROM_34 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version3.4.x.
- UPGRADE_FROM_35 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version3.5.x.
- UPGRADE_FROM_36 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version3.6.x.
- UPGRADE_FROM_37 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version3.7.x.
- UPGRADE_FROM_38 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version3.8.x.
- UPGRADE_FROM_39 - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
Config value for parameter"upgrade.from"for upgrading an application from version3.9.x.
- UPGRADE_FROM_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
upgrade.from
- upgraded() - Method in class org.apache.kafka.clients.admin.MemberDescription
- 
The flag indicating whether a member within aGroupType.CONSUMERgroup uses theGroupType.CONSUMERprotocol.
- upgradeType() - Method in class org.apache.kafka.clients.admin.FeatureUpdate
- upperBound() - Method in class org.apache.kafka.streams.query.TimestampedRangeQuery
- 
The upper bound of the query, if specified
- upperBound(double) - Static method in class org.apache.kafka.common.metrics.Quota
- UPSTREAM_OFFSET_KEY - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
- upstreamClusters() - Method in class org.apache.kafka.connect.mirror.MirrorClient
- 
Finds upstream clusters, which may be multiple hops away, based on incoming heartbeats.
- upstreamClusters(Map<String, Object>) - Static method in class org.apache.kafka.connect.mirror.RemoteClusterUtils
- 
Finds all upstream clusters
- upstreamOffset() - Method in class org.apache.kafka.connect.mirror.Checkpoint
- upstreamTopic(String) - Method in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
- upstreamTopic(String) - Method in class org.apache.kafka.connect.mirror.IdentityReplicationPolicy
- 
Since any topic may be a remote topic, this just returns `topic`.
- upstreamTopic(String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
- 
Return the name of the given topic on the source cluster.
- usableBytes() - Method in class org.apache.kafka.clients.admin.LogDirDescription
- 
The usable size on the volume this log directory is on or empty if the broker did not return a value.
- Usage examples - Search tag in interface org.apache.kafka.streams.kstream.BranchedKStream
- Section
- Usage Examples - Search tag in class org.apache.kafka.clients.consumer.KafkaConsumer
- Section
- Usage Examples - Search tag in class org.apache.kafka.clients.consumer.KafkaShareConsumer
- Section
- UsePartitionTimeOnInvalidTimestamp - Class in org.apache.kafka.streams.processor
- 
Retrieves embedded metadata timestamps from Kafka messages.
- UsePartitionTimeOnInvalidTimestamp() - Constructor for class org.apache.kafka.streams.processor.UsePartitionTimeOnInvalidTimestamp
- user() - Method in class org.apache.kafka.clients.admin.UserScramCredentialAlteration
- USER - Enum constant in enum class org.apache.kafka.common.resource.ResourceType
- 
A user principal
- USER - Enum constant in enum class org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
- USER - Static variable in class org.apache.kafka.common.quota.ClientQuotaEntity
- 
The type of an entity entry.
- USER_TYPE - Static variable in class org.apache.kafka.common.security.auth.KafkaPrincipal
- userData() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Assignment
- userData() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
- users() - Method in class org.apache.kafka.clients.admin.DescribeUserScramCredentialsResult
- UserScramCredentialAlteration - Class in org.apache.kafka.clients.admin
- 
A request to alter a user's SASL/SCRAM credentials.
- UserScramCredentialDeletion - Class in org.apache.kafka.clients.admin
- 
A request to delete a SASL/SCRAM credential for a user.
- UserScramCredentialDeletion(String, ScramMechanism) - Constructor for class org.apache.kafka.clients.admin.UserScramCredentialDeletion
- UserScramCredentialsDescription - Class in org.apache.kafka.clients.admin
- 
Representation of all SASL/SCRAM credentials associated with a user that can be retrieved, or an exception indicating why credentials could not be retrieved.
- UserScramCredentialsDescription(String, List<ScramCredentialInfo>) - Constructor for class org.apache.kafka.clients.admin.UserScramCredentialsDescription
- UserScramCredentialUpsertion - Class in org.apache.kafka.clients.admin
- 
A request to update/insert a SASL/SCRAM credential for a user.
- UserScramCredentialUpsertion(String, ScramCredentialInfo, byte[]) - Constructor for class org.apache.kafka.clients.admin.UserScramCredentialUpsertion
- 
Constructor that generates a random salt
- UserScramCredentialUpsertion(String, ScramCredentialInfo, byte[], byte[]) - Constructor for class org.apache.kafka.clients.admin.UserScramCredentialUpsertion
- 
Constructor that accepts an explicit salt
- UserScramCredentialUpsertion(String, ScramCredentialInfo, String) - Constructor for class org.apache.kafka.clients.admin.UserScramCredentialUpsertion
- 
Constructor that generates a random salt
- Uuid - Class in org.apache.kafka.common
- 
This class defines an immutable universally unique identifier (UUID).
- Uuid(long, long) - Constructor for class org.apache.kafka.common.Uuid
- 
Constructs a 128-bit type 4 UUID where the first long represents the most significant 64 bits and the second long represents the least significant 64 bits.
- UUID() - Static method in class org.apache.kafka.common.serialization.Serdes
- 
A serde for nullableUUIDtype
- 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() - Method in class org.apache.kafka.clients.admin.ListGroupsResult
- 
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 originalinputExtensionsmap
- VALID_LOG_LEVELS - Static variable in class org.apache.kafka.common.config.LogLevelConfig
- validate() - Method in class org.apache.kafka.connect.data.Struct
- 
Validates that this struct has filled in all the necessary data with valid values.
- validate(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
- 
Validate the current configuration values with the configuration definition.
- validate(Map<String, String>) - Method in class org.apache.kafka.connect.connector.Connector
- 
Validate the connector configuration values against configuration definitions.
- validate(Map<String, String>) - Method in class org.apache.kafka.connect.tools.MockSinkConnector
- validate(Map<String, String>) - Method in class org.apache.kafka.connect.tools.MockSourceConnector
- validate(ConnectorClientConfigRequest) - Method in interface org.apache.kafka.connect.connector.policy.ConnectorClientConfigOverridePolicy
- 
Workers will invoke this before configuring per-connector Kafka admin, producer, and consumer client instances to validate if all the overridden client configurations are allowed per the policy implementation.
- validate(AlterConfigPolicy.RequestMetadata) - Method in interface org.apache.kafka.server.policy.AlterConfigPolicy
- 
Validate the request parameters and throw aPolicyViolationExceptionwith 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 aPolicyViolationExceptionwith 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.AlterClientQuotasOptions
- 
Returns whether the request should be validated without altering the configs.
- validateOnly() - Method in class org.apache.kafka.clients.admin.CreatePartitionsOptions
- 
Return true if the request should be validated without creating new partitions.
- validateOnly() - Method in class org.apache.kafka.clients.admin.UpdateFeaturesOptions
- validateOnly(boolean) - Method in class org.apache.kafka.clients.admin.AlterClientQuotasOptions
- 
Sets whether the request should be validated without altering the configs.
- 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.
- validateOnly(boolean) - Method in class org.apache.kafka.clients.admin.UpdateFeaturesOptions
- validateReconfiguration(Map<String, ?>) - Method in class org.apache.kafka.common.metrics.JmxReporter
- validateReconfiguration(Map<String, ?>) - Method in interface org.apache.kafka.common.metrics.MetricsReporter
- validateReconfiguration(Map<String, ?>) - Method in interface org.apache.kafka.common.Reconfigurable
- 
Validates the provided configuration.
- validateTaskAssignment(ApplicationState, TaskAssignor.TaskAssignment) - Static method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils
- 
Validate the passed-inTaskAssignor.TaskAssignmentand return anTaskAssignor.AssignmentErrorrepresenting the first error detected in the assignment, orTaskAssignor.AssignmentError.NONEif the assignment passes the verification check.
- validateValue(Object) - Method in class org.apache.kafka.connect.data.ConnectSchema
- 
Validate that the value can be used for this schema, i.e.
- validateValue(String, Schema, Object) - Static method in class org.apache.kafka.connect.data.ConnectSchema
- validateValue(Schema, Object) - Static method in class org.apache.kafka.connect.data.ConnectSchema
- 
Validate that the value can be used with the schema, i.e.
- validator - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
- validTo() - Method in class org.apache.kafka.streams.state.VersionedRecord
- 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 - Variable in enum class org.apache.kafka.common.ElectionType
- value - Variable in class org.apache.kafka.streams.KeyValue
- 
The value of the key-value pair.
- 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 exception class org.apache.kafka.common.metrics.QuotaViolationException
- value() - Method in class org.apache.kafka.common.quota.ClientQuotaAlteration.Op
- value() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
- 
Theb64tokenvalue as defined in RFC 6750 Section 2.1
- value() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- value() - Method in class org.apache.kafka.connect.data.SchemaAndValue
- value() - Method in interface org.apache.kafka.connect.header.Header
- 
Get the header's value as deserialized by Connect's header converter.
- value() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata.CustomMetadata
- value() - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
- 
The value of the record.
- value() - Method in class org.apache.kafka.streams.processor.api.Record
- 
The value of the record.
- value() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
- value() - Method in class org.apache.kafka.streams.state.VersionedRecord
- value() - Method in class org.apache.kafka.streams.test.TestRecord
- value(double) - Method in class org.apache.kafka.common.metrics.stats.Histogram
- value(Object) - Method in class org.apache.kafka.common.config.ConfigValue
- value(MetricConfig, long) - Method in interface org.apache.kafka.common.metrics.Gauge
- 
Returns the current value associated with this gauge.
- value(MetricConfig, long, double) - Method in class org.apache.kafka.common.metrics.stats.Percentiles
- Value - Class in org.apache.kafka.common.metrics.stats
- 
An instantaneous value.
- Value() - Constructor for class org.apache.kafka.common.metrics.stats.Value
- VALUE - Enum constant in enum class org.apache.kafka.common.errors.RecordDeserializationException.DeserializationExceptionOrigin
- VALUE - Enum constant in enum class org.apache.kafka.connect.storage.ConverterType
- VALUE - Enum constant in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.SerializationExceptionOrigin
- 
Serialization exception occurred during serialization of the value.
- 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_SCHEMA_V0 - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
- VALUE_SCHEMA_V0 - Static variable in class org.apache.kafka.connect.mirror.Heartbeat
- 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
- ValueAndTimestamp<V> - Class in org.apache.kafka.streams.state
- 
Combines a value from aKeyValuewith a timestamp.
- valueBuffer() - Method in exception class org.apache.kafka.common.errors.RecordDeserializationException
- valueDeserializer() - Method in class org.apache.kafka.streams.state.StateSerdes
- 
Return the value deserializer.
- valueFrom(byte[]) - Method in class org.apache.kafka.streams.state.StateSerdes
- 
Deserialize the value from raw bytes.
- ValueJoiner<V1,V2, - Interface in org.apache.kafka.streams.kstreamVR> 
- 
TheValueJoinerinterface for joining two values into a new value of arbitrary type.
- ValueJoinerWithKey<K1,V1, - Interface in org.apache.kafka.streams.kstreamV2, VR> 
- 
TheValueJoinerWithKeyinterface for joining two values into a new value of arbitrary type.
- ValueMapper<V,VR> - Interface in org.apache.kafka.streams.kstream
- 
TheValueMapperinterface for mapping a value to a new value of arbitrary type.
- ValueMapperWithKey<K,V, - Interface in org.apache.kafka.streams.kstreamVR> 
- 
TheValueMapperWithKeyinterface for mapping a value to a new value of arbitrary type.
- valueOf(byte) - Static method in enum class org.apache.kafka.common.ElectionType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.clients.admin.AlterConfigOp.OpType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.clients.admin.EndpointType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.clients.admin.FeatureUpdate.UpgradeType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.clients.admin.ScramMechanism
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.clients.admin.TransactionState
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.clients.consumer.AcknowledgeType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.clients.consumer.GroupProtocol
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.clients.consumer.OffsetResetStrategy
- 
Deprecated.Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.acl.AclOperation
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.acl.AclPermissionType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.ClassicGroupState
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.config.ConfigDef.Importance
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.config.ConfigDef.Type
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.config.ConfigDef.Width
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.config.ConfigResource.Type
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.config.SslClientAuth
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.ConsumerGroupState
- 
Deprecated.Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.ElectionType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.errors.RecordDeserializationException.DeserializationExceptionOrigin
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.GroupState
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.GroupType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.IsolationLevel
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.metrics.Sensor.RecordingLevel
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.metrics.stats.Percentiles.BucketSizing
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.resource.PatternType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.resource.ResourceType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.common.security.auth.SecurityProtocol
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.connect.data.Schema.Type
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.connect.health.ConnectorType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.connect.source.ConnectorTransactionBoundaries
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.connect.source.ExactlyOnceSupport
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.connect.storage.ConverterType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.coordinator.group.api.assignor.SubscriptionType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.server.authorizer.AuthorizationResult
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.server.log.remote.storage.RemoteStorageManager.IndexType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.server.quota.ClientQuotaType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.errors.ProcessingExceptionHandler.ProcessingHandlerResponse
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.SerializationExceptionOrigin
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.KafkaStreams.State
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.kstream.EmitStrategy.StrategyType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.kstream.Materialized.StoreType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask.Type
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.processor.assignment.TaskAssignor.AssignmentError
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.processor.PunctuationType
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.processor.StandbyUpdateListener.SuspendReason
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.query.FailureReason
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.query.ResultOrder
- 
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.streams.Topology.AutoOffsetReset
- 
Deprecated.Returns the enum constant of this class with the specified name.
- values() - Method in class org.apache.kafka.clients.admin.AlterClientQuotasResult
- 
Returns a map from quota entity to a future which can be used to check the status of the operation.
- values() - Static method in enum class org.apache.kafka.clients.admin.AlterConfigOp.OpType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- 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.AlterPartitionReassignmentsResult
- 
Return a map from partitions to futures which can be used to check the status of the reassignment.
- values() - Method in class org.apache.kafka.clients.admin.AlterReplicaLogDirsResult
- 
Return a map fromTopicPartitionReplicatoKafkaFuturewhich holds the status of individual replica movement.
- values() - Method in class org.apache.kafka.clients.admin.AlterUserScramCredentialsResult
- 
Return a map from user names to futures, which can be used to check the status of the alteration(s) for each user.
- values() - Static method in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigType
- 
Returns an array containing the constants of this enum class, 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.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.DescribeReplicaLogDirsResult
- 
Return a map from replica to future which can be used to check the log directory information of individual replicas
- values() - Static method in enum class org.apache.kafka.clients.admin.EndpointType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.clients.admin.FeatureUpdate.UpgradeType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.clients.admin.ScramMechanism
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.clients.admin.TransactionState
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class org.apache.kafka.clients.admin.UpdateFeaturesResult
- values() - Static method in enum class org.apache.kafka.clients.consumer.AcknowledgeType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.clients.consumer.GroupProtocol
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.clients.consumer.OffsetResetStrategy
- 
Deprecated.Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.acl.AclOperation
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.acl.AclPermissionType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.ClassicGroupState
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class org.apache.kafka.common.config.AbstractConfig
- values() - Static method in enum class org.apache.kafka.common.config.ConfigDef.Importance
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.config.ConfigDef.Type
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.config.ConfigDef.Width
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.config.ConfigResource.Type
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.config.SslClientAuth
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.ConsumerGroupState
- 
Deprecated.Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.ElectionType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.errors.RecordDeserializationException.DeserializationExceptionOrigin
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.GroupState
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.GroupType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.IsolationLevel
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.metrics.Sensor.RecordingLevel
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.metrics.stats.Percentiles.BucketSizing
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.resource.PatternType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.resource.ResourceType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.common.security.auth.SecurityProtocol
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.connect.data.Schema.Type
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.connect.health.ConnectorType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.connect.source.ConnectorTransactionBoundaries
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.connect.source.ExactlyOnceSupport
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.connect.storage.ConverterType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.coordinator.group.api.assignor.SubscriptionType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.server.authorizer.AuthorizationResult
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.server.log.remote.storage.RemoteStorageManager.IndexType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.server.quota.ClientQuotaType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.errors.ProcessingExceptionHandler.ProcessingHandlerResponse
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.errors.ProductionExceptionHandler.SerializationExceptionOrigin
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.KafkaStreams.State
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.kstream.EmitStrategy.StrategyType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.kstream.Materialized.StoreType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment.AssignedTask.Type
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.processor.assignment.TaskAssignor.AssignmentError
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.processor.PunctuationType
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.processor.StandbyUpdateListener.SuspendReason
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.query.FailureReason
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.query.ResultOrder
- 
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.streams.Topology.AutoOffsetReset
- 
Deprecated.Returns an array containing the constants of this enum class, in the order they are declared.
- Values - Class in org.apache.kafka.connect.data
- 
Utility for converting from one Connect value to a different form.
- Values() - Constructor for class org.apache.kafka.connect.data.Values
- VALUES - Static variable in enum class org.apache.kafka.common.config.SslClientAuth
- valueSchema() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- valueSchema() - Method in class org.apache.kafka.connect.data.ConnectSchema
- valueSchema() - Method in interface org.apache.kafka.connect.data.Schema
- 
Get the value schema for this map or array schema.
- valueSchema() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- valueSerde() - Method in class org.apache.kafka.streams.kstream.Joined
- 
Deprecated.Since 4.0 and should not be used any longer.
- valueSerde() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- valueSerde() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
- 
Return the default value serde.
- valueSerde() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 
Deprecated.
- valueSerde() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
- 
Return the default value serde.
- valueSerde() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
- 
Returns the default value serde.
- valueSerde() - Method in class org.apache.kafka.streams.state.StateSerdes
- 
Return the value serde.
- valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Grouped
- 
Create aGroupedinstance with the provided valueSerde.
- valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Produced
- 
Create a Produced instance with provided valueSerde.
- valueSerde(Serde<VLeft>) - Static method in class org.apache.kafka.streams.kstream.Joined
- 
Create an instance ofJoinedwith a valueSerde.
- valueSerializer() - Method in class org.apache.kafka.streams.state.StateSerdes
- 
Return the value serializer.
- valuesWithPrefixAllOrNothing(String) - Method in class org.apache.kafka.common.config.AbstractConfig
- 
If at least one key withprefixexists, 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 withprefixand 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.
- ValueTransformer<V,VR> - Interface in org.apache.kafka.streams.kstream
- 
Deprecated.Since 4.0. UseFixedKeyProcessorinstead.
- ValueTransformerSupplier<V,VR> - Interface in org.apache.kafka.streams.kstream
- 
Deprecated.Since 4.0. UseFixedKeyProcessorSupplierinstead.
- ValueTransformerWithKey<K,V, - Interface in org.apache.kafka.streams.kstreamVR> 
- 
TheValueTransformerWithKeyinterface for stateful mapping of a value to a new value (with possible new type).
- ValueTransformerWithKeySupplier<K,V, - Interface in org.apache.kafka.streams.kstreamVR> 
- 
AValueTransformerWithKeySupplierinterface which can create one or moreValueTransformerWithKeyinstances.
- VerifiableSinkConnector - Class in org.apache.kafka.connect.tools
- 
A connector primarily intended for system tests.
- VerifiableSinkConnector() - Constructor for class org.apache.kafka.connect.tools.VerifiableSinkConnector
- VerifiableSinkTask - Class in org.apache.kafka.connect.tools
- 
Counterpart toVerifiableSourceTaskthat consumes records and logs information about each to stdout.
- VerifiableSinkTask() - Constructor for class org.apache.kafka.connect.tools.VerifiableSinkTask
- VerifiableSourceConnector - Class in org.apache.kafka.connect.tools
- 
A connector primarily intended for system tests.
- VerifiableSourceConnector() - Constructor for class org.apache.kafka.connect.tools.VerifiableSourceConnector
- VerifiableSourceTask - Class in org.apache.kafka.connect.tools
- 
A connector primarily intended for system tests.
- VerifiableSourceTask() - Constructor for class org.apache.kafka.connect.tools.VerifiableSourceTask
- verifyTopologyOptimizationConfigs(String) - Static method in class org.apache.kafka.streams.StreamsConfig
- version() - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
- 
Return the version of the assignor which indicates how the user metadata encodings and the assignment algorithm gets evolved.
- version() - Method in interface org.apache.kafka.connect.components.Versioned
- 
Get the version of this component.
- version() - Method in interface org.apache.kafka.connect.connector.Task
- 
Get the version of this task.
- version() - Method in class org.apache.kafka.connect.data.ConnectSchema
- version() - Method in interface org.apache.kafka.connect.data.Schema
- 
Get the optional version of the schema.
- version() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- version() - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
- version() - Method in class org.apache.kafka.connect.storage.StringConverter
- version() - Method in class org.apache.kafka.connect.tools.MockConnector
- version() - Method in class org.apache.kafka.connect.tools.MockSinkConnector
- version() - Method in class org.apache.kafka.connect.tools.MockSinkTask
- version() - Method in class org.apache.kafka.connect.tools.MockSourceConnector
- version() - Method in class org.apache.kafka.connect.tools.MockSourceTask
- version() - Method in class org.apache.kafka.connect.tools.SchemaSourceConnector
- version() - Method in class org.apache.kafka.connect.tools.SchemaSourceTask
- version() - Method in class org.apache.kafka.connect.tools.VerifiableSinkConnector
- version() - Method in class org.apache.kafka.connect.tools.VerifiableSinkTask
- version() - Method in class org.apache.kafka.connect.tools.VerifiableSourceConnector
- version() - Method in class org.apache.kafka.connect.tools.VerifiableSourceTask
- version(Integer) - Method in class org.apache.kafka.connect.data.SchemaBuilder
- 
Set the version of this schema.
- VERSION - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
- VERSION - Static variable in class org.apache.kafka.connect.mirror.Heartbeat
- VERSION_KEY - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
- VERSION_KEY - Static variable in class org.apache.kafka.connect.mirror.Heartbeat
- Versioned - Interface in org.apache.kafka.connect.components
- 
Connect requires some components implement this interface to define a version string.
- VersionedBytesStore - Interface in org.apache.kafka.streams.state
- 
A representation of a versioned key-value store as aKeyValueStoreof type <Bytes, byte[]>.
- VersionedBytesStoreSupplier - Interface in org.apache.kafka.streams.state
- 
A store supplier that can be used to create one or more versioned key-value stores, specifically,VersionedBytesStoreinstances.
- VersionedKeyQuery<K,V> - Class in org.apache.kafka.streams.query
- 
Interactive query for retrieving a single record from a versioned state store based on its key and timestamp.
- VersionedKeyValueStore<K,V> - Interface in org.apache.kafka.streams.state
- 
A key-value store that stores multiple record versions per key, and supports timestamp-based retrieval operations to return the latest record (per key) as of a specified timestamp.
- versionedKeyValueStoreBuilder(VersionedBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
- 
Creates aStoreBuilderthat can be used to build aVersionedKeyValueStore.
- VersionedRecord<V> - Class in org.apache.kafka.streams.state
- 
Combines a value (from a key-value record) with a timestamp, for use as the return type fromVersionedKeyValueStore.get(Object, long)and related methods.
- VersionedRecord(V, long) - Constructor for class org.apache.kafka.streams.state.VersionedRecord
- 
Create a newVersionedRecordinstance.
- VersionedRecord(V, long, long) - Constructor for class org.apache.kafka.streams.state.VersionedRecord
- 
Create a newVersionedRecordinstance.
- VersionedRecordIterator<V> - Interface in org.apache.kafka.streams.state
- 
Iterator interface ofVersionedRecord.
- 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.
- Void() - Static method in class org.apache.kafka.common.serialization.Serdes
- 
A serde forVoidtype.
- VoidDeserializer - Class in org.apache.kafka.common.serialization
- VoidDeserializer() - Constructor for class org.apache.kafka.common.serialization.VoidDeserializer
- VoidSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.VoidSerde
- VoidSerializer - Class in org.apache.kafka.common.serialization
- VoidSerializer() - Constructor for class org.apache.kafka.common.serialization.VoidSerializer
- VoterNotFoundException - Exception Class in org.apache.kafka.common.errors
- VoterNotFoundException(String) - Constructor for exception class org.apache.kafka.common.errors.VoterNotFoundException
- VoterNotFoundException(String, Throwable) - Constructor for exception class org.apache.kafka.common.errors.VoterNotFoundException
- voters() - Method in class org.apache.kafka.clients.admin.QuorumInfo
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.KafkaShareConsumer
- 
Wake up the consumer.
- wakeup() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- wakeup() - Method in class org.apache.kafka.clients.consumer.MockShareConsumer
- wakeup() - Method in interface org.apache.kafka.clients.consumer.ShareConsumer
- WakeupException - Exception Class in org.apache.kafka.common.errors
- 
Exception used to indicate preemption of a blocking operation by an external thread.
- WakeupException() - Constructor for exception class org.apache.kafka.common.errors.WakeupException
- WALL_CLOCK_TIME - Enum constant in enum class org.apache.kafka.streams.processor.PunctuationType
- WallclockTimestampExtractor - Class in org.apache.kafka.streams.processor
- 
Retrieves current wall clock timestamps asSystem.currentTimeMillis().
- WallclockTimestampExtractor() - Constructor for class org.apache.kafka.streams.processor.WallclockTimestampExtractor
- WARN_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
- 
TheWARNlevel designates potentially harmful situations.
- 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'.
- window() - Method in class org.apache.kafka.streams.kstream.Windowed
- 
Return the window containing the values associated with this key.
- Window - Class in org.apache.kafka.streams.kstream
- 
A single window instance, defined by its start and end timestamp.
- Window(long, long) - Constructor for class org.apache.kafka.streams.kstream.Window
- 
Create a new window for the given start and end time.
- WINDOW_SIZE_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
window.size.ms
- WINDOW_STORE_CHANGE_LOG_ADDITIONAL_RETENTION_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
windowstore.changelog.additional.retention.ms
- WindowBytesStoreSupplier - Interface in org.apache.kafka.streams.state
- 
A store supplier that can be used to create one or moreWindowStore<Byte, byte[]>instances of type <Byte, byte[]>.
- Windowed<K> - Class in org.apache.kafka.streams.kstream
- 
The result key type of a windowed stream aggregation.
- Windowed(K, Window) - Constructor for class org.apache.kafka.streams.kstream.Windowed
- WINDOWED_INNER_CLASS_SERDE - Static variable in class org.apache.kafka.streams.StreamsConfig
- 
windowed.inner.class.serde
- windowedBy(SessionWindows) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
- 
Create a newSessionWindowedCogroupedKStreaminstance that can be used to perform session windowed aggregations.
- windowedBy(SessionWindows) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
- 
Create a newSessionWindowedKStreaminstance that can be used to perform session windowed aggregations.
- windowedBy(SlidingWindows) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
- 
Create a newTimeWindowedCogroupedKStreaminstance that can be used to perform sliding windowed aggregations.
- windowedBy(SlidingWindows) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
- 
Create a newTimeWindowedKStreaminstance that can be used to perform sliding windowed aggregations.
- windowedBy(Windows<W>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
- 
Create a newTimeWindowedCogroupedKStreaminstance that can be used to perform windowed aggregations.
- windowedBy(Windows<W>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
- 
Create a newTimeWindowedKStreaminstance that can be used to perform windowed aggregations.
- WindowedCount - Class in org.apache.kafka.common.metrics.stats
- 
ASampledStatthat maintains a simple count of what it has seen.
- WindowedCount() - Constructor for class org.apache.kafka.common.metrics.stats.WindowedCount
- WindowedSerdes - Class in org.apache.kafka.streams.kstream
- WindowedSerdes() - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes
- WindowedSerdes.SessionWindowedSerde<T> - Class in org.apache.kafka.streams.kstream
- WindowedSerdes.TimeWindowedSerde<T> - Class in org.apache.kafka.streams.kstream
- WindowedSum - Class in org.apache.kafka.common.metrics.stats
- 
ASampledStatthat maintains the sum of what it has seen.
- WindowedSum() - Constructor for class org.apache.kafka.common.metrics.stats.WindowedSum
- WindowKeyQuery<K,V> - Class in org.apache.kafka.streams.query
- WindowRangeQuery<K,V> - Class in org.apache.kafka.streams.query
- Windows<W> - Class in org.apache.kafka.streams.kstream
- 
The window specification for fixed size windows that is used to define window boundaries and grace period.
- windowsFor(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
- 
Not supported byJoinWindows.
- windowsFor(long) - Method in class org.apache.kafka.streams.kstream.TimeWindows
- windowsFor(long) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
- windowsFor(long) - Method in class org.apache.kafka.streams.kstream.Windows
- 
Create all windows that contain the provided timestamp, indexed by non-negative window start timestamps.
- windowSize() - Method in class org.apache.kafka.streams.state.DslWindowParams
- windowSize() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
- 
The size of the windows (in milliseconds) any store created from this supplier is creating.
- windowSize(MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.Rate
- windowSize(MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.SimpleRate
- windowStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
- 
AQueryableStoreTypethat acceptsReadOnlyWindowStore.
- windowStore(DslWindowParams) - Method in enum class org.apache.kafka.streams.kstream.Materialized.StoreType
- windowStore(DslWindowParams) - Method in class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers.InMemoryDslStoreSuppliers
- windowStore(DslWindowParams) - Method in class org.apache.kafka.streams.state.BuiltInDslStoreSuppliers.RocksDBDslStoreSuppliers
- windowStore(DslWindowParams) - Method in interface org.apache.kafka.streams.state.DslStoreSuppliers
- WindowStore<K,V> - Interface in org.apache.kafka.streams.state
- 
Interface for storing the aggregated values of fixed-size time windows.
- windowStoreBuilder(WindowBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
- 
Creates aStoreBuilderthat can be used to build aWindowStore.
- WindowStoreIterator<V> - Interface in org.apache.kafka.streams.state
- 
Iterator interface ofKeyValuewith key typedLongused forWindowStore.fetch(Object, long, long)andWindowStore.fetch(Object, Instant, Instant)Users must call itsclosemethod explicitly upon completeness to release resources, or use try-with-resources statement (available since JDK7) for thisCloseableclass.
- with(String, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Grouped
- 
Create aGroupedinstance with the provided name, keySerde, and valueSerde.
- with(BiConsumer<String, Object>, Supplier<String>) - Static method in class org.apache.kafka.common.config.ConfigDef.LambdaValidator
- with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Consumed
- with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Grouped
- 
Create aGroupedinstance with the provided keySerde and valueSerde.
- with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Materialized
- 
Materialize aStateStorewith the provided key and valueSerdes.
- with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Produced
- 
Create a Produced instance with provided keySerde and valueSerde.
- with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Repartitioned
- 
Create aRepartitionedinstance with provided key serde and value serde.
- with(Serde<K>, Serde<V>, StreamPartitioner<? super K, ? super V>) - Static method in class org.apache.kafka.streams.kstream.Produced
- 
Create a Produced instance with provided keySerde, valueSerde, and partitioner.
- with(Serde<K>, Serde<V>, TimestampExtractor, AutoOffsetReset) - Static method in class org.apache.kafka.streams.kstream.Consumed
- 
Create an instance ofConsumedwith the supplied arguments.
- with(Serde<K>, Serde<V>, TimestampExtractor, Topology.AutoOffsetReset) - Static method in class org.apache.kafka.streams.kstream.Consumed
- 
Deprecated.Since 4.0. UseConsumed.with(Serde, Serde, TimestampExtractor, AutoOffsetReset)instead.
- with(Serde<K>, Serde<V1>, Serde<V2>) - Static method in class org.apache.kafka.streams.kstream.StreamJoined
- 
Creates aStreamJoinedinstance with the provided serdes to configure the stores for the join.
- with(Serde<K>, Serde<VLeft>, Serde<VRight>) - Static method in class org.apache.kafka.streams.kstream.Joined
- 
Create an instance ofJoinedwith key, value, and otherValueSerdeinstances.
- with(Serde<K>, Serde<VLeft>, Serde<VRight>, String) - Static method in class org.apache.kafka.streams.kstream.Joined
- 
Create an instance ofJoinedwith key, value, and otherValueSerdeinstances.
- with(Serde<K>, Serde<VLeft>, Serde<VRight>, String, Duration) - Static method in class org.apache.kafka.streams.kstream.Joined
- 
Create an instance ofJoinedwith key, value, and otherValueSerdeinstances.
- with(Schema, Object) - Method in interface org.apache.kafka.connect.header.Header
- 
Return a newHeaderobject that has the same key but with the supplied value.
- with(AutoOffsetReset) - Static method in class org.apache.kafka.streams.kstream.Consumed
- 
Create an instance ofConsumedwith aTopology.AutoOffsetReset.
- with(StreamPartitioner<K, Void>, StreamPartitioner<KO, Void>) - Static method in class org.apache.kafka.streams.kstream.TableJoined
- 
Create an instance ofTableJoinedwith partitioner and otherPartitionerStreamPartitionerinstances.
- with(TimestampExtractor) - Static method in class org.apache.kafka.streams.kstream.Consumed
- 
Create an instance ofConsumedwith aTimestampExtractor.
- with(DslStoreSuppliers) - Static method in class org.apache.kafka.streams.kstream.StreamJoined
- 
Creates a StreamJoined instance with the givenDslStoreSuppliers.
- with(WindowBytesStoreSupplier, WindowBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.StreamJoined
- 
Creates a StreamJoined instance with the provided store suppliers.
- with(Topology.AutoOffsetReset) - Static method in class org.apache.kafka.streams.kstream.Consumed
- 
Deprecated.Since 4.0. UseConsumed.with(AutoOffsetReset)instead.
- withAllPartitions() - Method in class org.apache.kafka.streams.query.StateQueryRequest
- 
Specifies that the query will run against all locally available partitions.
- withAscendingKeys() - Method in class org.apache.kafka.streams.query.RangeQuery
- 
Set the query to return the serialized byte[] of the keys in ascending order.
- withAscendingKeys() - Method in class org.apache.kafka.streams.query.TimestampedRangeQuery
- 
Set the query to return the serialized byte[] of the keys in ascending order.
- withAscendingTimestamps() - Method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
- 
Specifies the order of the returned records by the query as ascending by timestamp.
- withBuiltinTypes(String, Class<K>, Class<V>) - Static method in class org.apache.kafka.streams.state.StateSerdes
- 
Create a new instance ofStateSerdesfor the given state name and key-/value-type classes.
- withCachingDisabled() - Method in class org.apache.kafka.streams.kstream.Materialized
- 
Disable caching for the materializedStateStore.
- withCachingDisabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
- 
Disable caching on the store.
- withCachingEnabled() - Method in class org.apache.kafka.streams.kstream.Materialized
- 
Enable caching for the materializedStateStore.
- withCachingEnabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
- 
Enable caching on the store.
- 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.
- withComponent(String, int, long) - Method in class org.apache.kafka.streams.query.Position
- 
Augment an existing Position by setting a new offset for a topic and partition.
- withConsumer(Consumer<? super KStream<K, V>>, String) - Static method in class org.apache.kafka.streams.kstream.Branched
- 
Create an instance ofBranchedwith provided chain consumer and branch name suffix.
- withConsumer(Consumer<KStream<K, V>>) - Static method in class org.apache.kafka.streams.kstream.Branched
- 
Create an instance ofBranchedwith provided chain consumer.
- withDescendingKeys() - Method in class org.apache.kafka.streams.query.RangeQuery
- 
Set the query to return the serialized byte[] of the keys in descending order.
- withDescendingKeys() - Method in class org.apache.kafka.streams.query.TimestampedRangeQuery
- 
Set the query to return the serialized byte[] of the keys in descending order.
- withDescendingTimestamps() - Method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
- 
Specifies the order of the returned records by the query as descending by timestamp.
- withDslStoreSuppliers(DslStoreSuppliers) - Method in class org.apache.kafka.streams.kstream.StreamJoined
- 
Configure with the providedDslStoreSuppliersfor store suppliers that are not provided.
- withFollowupRebalance(Instant) - Method in class org.apache.kafka.streams.processor.assignment.KafkaStreamsAssignment
- 
This API can be used to request that a followup rebalance be triggered by the KafkaStreams client receiving this assignment.
- withFunction(Function<? super KStream<K, V>, ? extends KStream<K, V>>) - Static method in class org.apache.kafka.streams.kstream.Branched
- 
Create an instance ofBranchedwith provided chain function.
- withFunction(Function<? super KStream<K, V>, ? extends KStream<K, V>>, String) - Static method in class org.apache.kafka.streams.kstream.Branched
- 
Create an instance ofBranchedwith provided chain function and branch name suffix.
- withGracePeriod(Duration) - Method in class org.apache.kafka.streams.kstream.Joined
- 
Set the grace period on the stream side of the join.
- withHeaders(Headers) - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
- 
A convenient way to produce a new record if you only need to change the headers.
- withHeaders(Headers) - Method in class org.apache.kafka.streams.processor.api.Record
- 
A convenient way to produce a new record if you only need to change the headers.
- withKey(K) - Static method in class org.apache.kafka.streams.query.KeyQuery
- 
Creates a query that will retrieve the record identified bykeyif it exists (ornullotherwise).
- withKey(K) - Static method in class org.apache.kafka.streams.query.MultiVersionedKeyQuery
- 
Creates a query that will retrieve the set of records identified bykeyif any exists (ornullotherwise).
- withKey(K) - Static method in class org.apache.kafka.streams.query.TimestampedKeyQuery
- 
Creates a query that will retrieve the record identified bykeyif it exists (ornullotherwise).
- withKey(K) - Static method in class org.apache.kafka.streams.query.VersionedKeyQuery
- 
Creates a query that will retrieve the record from a versioned state store identified bykeyif it exists (ornullotherwise).
- withKey(K) - Static method in class org.apache.kafka.streams.query.WindowRangeQuery
- withKey(NewK) - Method in class org.apache.kafka.streams.processor.api.Record
- 
A convenient way to produce a new record if you only need to change the key.
- withKeyAndWindowStartRange(K, Instant, Instant) - Static method in class org.apache.kafka.streams.query.WindowKeyQuery
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Consumed
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Grouped
- 
Perform the grouping operation using the provided keySerde for serializing the key.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Joined
- 
Set the keySerdeto be used.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Materialized
- 
Set the keySerde the materializedStateStorewill use.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Produced
- 
Produce records using the provided keySerde.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Repartitioned
- 
Create a new instance ofRepartitionedwith the provided key serde.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
- 
Configure with the providedSerdefor the key
- withKeyValueMapper(KeyValueMapper<? super K, ? super V, String>) - Method in class org.apache.kafka.streams.kstream.Printed
- 
Print the records of aKStreamwith the providedKeyValueMapperThe provided KeyValueMapper's mapped value type must beString.
- withLabel(String) - Method in class org.apache.kafka.streams.kstream.Printed
- 
Print the records of aKStreamwith the provided label.
- withLoggingDisabled() - Method in class org.apache.kafka.streams.kstream.Materialized
- 
Disable change logging for the materializedStateStore.
- withLoggingDisabled() - Method in class org.apache.kafka.streams.kstream.StreamJoined
- 
Disable change logging for both state stores.
- withLoggingDisabled() - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
- 
Disable the changelog for this suppression's internal buffer.
- withLoggingDisabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
- 
Disable the changelog for store built by thisStoreBuilder.
- withLoggingEnabled(Map<String, String>) - Method in class org.apache.kafka.streams.kstream.Materialized
- 
Indicates that a changelog should be created for the store.
- withLoggingEnabled(Map<String, String>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
- 
Configures logging for both state stores.
- withLoggingEnabled(Map<String, String>) - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
- 
Indicates that a changelog topic should be created containing the currently suppressed records.
- withLoggingEnabled(Map<String, String>) - Method in interface org.apache.kafka.streams.state.StoreBuilder
- 
Maintain a changelog for any changes made to the store.
- withLowerBound(K) - Static method in class org.apache.kafka.streams.query.RangeQuery
- 
Interactive range query using a lower bound to filter the keys returned.
- withLowerBound(K) - Static method in class org.apache.kafka.streams.query.TimestampedRangeQuery
- 
Interactive range query using a lower bound to filter the keys returned.
- withMaxBytes(long) - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
- 
Set a size constraint on the buffer, the maximum number of bytes it will use.
- withMaxRecords(long) - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
- 
Set a size constraint on the buffer in terms of the maximum number of keys it will store.
- withName(String) - Static method in enum class org.apache.kafka.connect.storage.ConverterType
- 
Find the ConverterType with the given name, using a case-insensitive match.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Branched
- 
Configure the instance ofBranchedwith a branch name suffix.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Consumed
- 
Configure the instance ofConsumedwith a processor name.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Grouped
- 
Perform the grouping operation with the name for a repartition topic if required.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Joined
- 
Set the base name used for all components of the join, this may include any repartition topics created to complete the join.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Named
- withName(String) - Method in class org.apache.kafka.streams.kstream.Printed
- 
Print the records of aKStreamwith provided processor name.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Produced
- withName(String) - Method in class org.apache.kafka.streams.kstream.Repartitioned
- 
Create a new instance ofRepartitionedwith the provided name used as part of repartition topic and processor name.
- withName(String) - Method in class org.apache.kafka.streams.kstream.StreamJoined
- 
Set the name to use for the join processor and the repartition topic(s) if required.
- withName(String) - Method in interface org.apache.kafka.streams.kstream.Suppressed
- 
Use the specified name for the suppression node in the topology.
- withName(String) - Method in class org.apache.kafka.streams.kstream.TableJoined
- 
Set the base name used for all components of the join, including internal topics created to complete the join.
- withNoBound() - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
- 
Set the buffer to be unconstrained by size (either keys or bytes).
- withNoBounds() - Static method in class org.apache.kafka.streams.query.RangeQuery
- 
Interactive scan query that returns all records in the store.
- withNoBounds() - Static method in class org.apache.kafka.streams.query.TimestampedRangeQuery
- 
Interactive scan query that returns all records in the store.
- withNonOverlapCostOverride(int) - Method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils.RackAwareOptimizationParams
- 
Return a new config object with the provided nonOverlapCost override applied
- withNumberOfPartitions(int) - Method in class org.apache.kafka.streams.kstream.Repartitioned
- 
Create a new instance ofRepartitionedwith the provided number of partitions for repartition topic.
- withOffsetResetPolicy(AutoOffsetReset) - Method in class org.apache.kafka.streams.kstream.Consumed
- 
Configure the instance ofConsumedwith aTopology.AutoOffsetReset.
- withOffsetResetPolicy(Topology.AutoOffsetReset) - Method in class org.apache.kafka.streams.kstream.Consumed
- 
Deprecated.Since 4.0. UseConsumed.withOffsetResetPolicy(AutoOffsetReset)instead.
- withOtherPartitioner(StreamPartitioner<KO, Void>) - Method in class org.apache.kafka.streams.kstream.TableJoined
- 
Set the custom otherStreamPartitionerto be used as part of computing the join.
- withOtherStoreSupplier(WindowBytesStoreSupplier) - Method in class org.apache.kafka.streams.kstream.StreamJoined
- 
Configure with the providedWindowBytesStoreSupplierfor the other store supplier.
- withOtherValueSerde(Serde<V2>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
- 
Configure with the providedSerdefor the other value
- withOtherValueSerde(Serde<VRight>) - Method in class org.apache.kafka.streams.kstream.Joined
- 
Set the otherValueSerdeto be used.
- withPartition(Integer) - Method in class org.apache.kafka.streams.StoreQueryParameters
- 
Set a specific partition that should be queried exclusively.
- withPartitioner(StreamPartitioner<K, Void>) - Method in class org.apache.kafka.streams.kstream.TableJoined
- 
Set the customStreamPartitionerto be used as part of computing the join.
- withPartitions(Map<TopicPartition, PartitionInfo>) - Method in class org.apache.kafka.common.Cluster
- 
Return a copy of this cluster combined with `partitions`.
- withPartitions(Set<Integer>) - Method in class org.apache.kafka.streams.query.StateQueryRequest
- 
Specifies a set of partitions to run against.
- withPositionBound(PositionBound) - Method in class org.apache.kafka.streams.query.StateQueryRequest
- 
Bounds the position of the state store against its input topics.
- withQuery(Query<R>) - Method in class org.apache.kafka.streams.query.StateQueryRequest.InStore
- 
Specifies the query to run on the specified store.
- withRange(K, K) - Static method in class org.apache.kafka.streams.query.RangeQuery
- 
Interactive range query using a lower and upper bound to filter the keys returned.
- withRange(K, K) - Static method in class org.apache.kafka.streams.query.TimestampedRangeQuery
- 
Interactive range query using a lower and upper bound to filter the keys returned.
- withRetention(Duration) - Method in class org.apache.kafka.streams.kstream.Materialized
- 
Configure retention period for window and session stores.
- withStoreName(String) - Method in class org.apache.kafka.streams.kstream.StreamJoined
- 
Sets the base store name to use for both sides of the join.
- withStoreType(DslStoreSuppliers) - Method in class org.apache.kafka.streams.kstream.Materialized
- 
Set the type of the materializedStateStore.
- withStreamPartitioner(StreamPartitioner<? super K, ? super V>) - Method in class org.apache.kafka.streams.kstream.Produced
- 
Produce records using the provided partitioner.
- withStreamPartitioner(StreamPartitioner<K, V>) - Method in class org.apache.kafka.streams.kstream.Repartitioned
- 
Create a new instance ofRepartitionedwith the provided partitioner.
- withThisStoreSupplier(WindowBytesStoreSupplier) - Method in class org.apache.kafka.streams.kstream.StreamJoined
- 
Configure with the providedWindowBytesStoreSupplierfor this store supplier.
- withTimestamp(long) - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
- 
A convenient way to produce a new record if you only need to change the timestamp.
- withTimestamp(long) - Method in class org.apache.kafka.streams.processor.api.Record
- 
A convenient way to produce a new record if you only need to change the timestamp.
- withTimestamp(long) - Method in class org.apache.kafka.streams.processor.To
- 
Set the timestamp of the output record.
- withTimestampExtractor(TimestampExtractor) - Method in class org.apache.kafka.streams.kstream.Consumed
- 
Configure the instance ofConsumedwith aTimestampExtractor.
- withTrafficCostOverride(int) - Method in class org.apache.kafka.streams.processor.assignment.TaskAssignmentUtils.RackAwareOptimizationParams
- 
Return a new config object with the provided trafficCost override applied
- withTypes(Set<GroupType>) - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsOptions
- 
If types is set, only groups of these types will be returned by listConsumerGroups().
- withTypes(Set<GroupType>) - Method in class org.apache.kafka.clients.admin.ListGroupsOptions
- 
If types is set, only groups of these types will be returned by listGroups().
- withUpperBound(K) - Static method in class org.apache.kafka.streams.query.RangeQuery
- 
Interactive range query using an upper bound to filter the keys returned.
- withUpperBound(K) - Static method in class org.apache.kafka.streams.query.TimestampedRangeQuery
- 
Interactive range query using an upper bound to filter the keys returned.
- withValue(NewV) - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
- 
A convenient way to produce a new record if you only need to change the value.
- withValue(NewV) - Method in class org.apache.kafka.streams.processor.api.Record
- 
A convenient way to produce a new record if you only need to change the value.
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Consumed
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Grouped
- 
Perform the grouping operation using the provided valueSerde for serializing the value.
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Materialized
- 
Set the valueSerde the materializedStateStorewill use.
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Produced
- 
Produce records using the provided valueSerde.
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Repartitioned
- 
Create a new instance ofRepartitionedwith the provided value serde.
- withValueSerde(Serde<V1>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
- 
Configure with the providedSerdefor this value
- withValueSerde(Serde<VLeft>) - Method in class org.apache.kafka.streams.kstream.Joined
- 
Set the valueSerdeto be used.
- withWindowStartRange(Instant, Instant) - Static method in class org.apache.kafka.streams.query.WindowRangeQuery
- workerId() - Method in class org.apache.kafka.connect.health.AbstractState
- 
The identifier of the worker associated with the connector or the task.
- wrapFixedKeyProcessorSupplier(String, FixedKeyProcessorSupplier<KIn, VIn, VOut>) - Method in interface org.apache.kafka.streams.processor.api.ProcessorWrapper
- 
Wrap or replace the providedFixedKeyProcessorSupplierand return aWrappedFixedKeyProcessorSupplierTo convert aFixedKeyProcessorSupplierinstance into aWrappedFixedKeyProcessorSupplier, use theProcessorWrapper.asWrappedFixedKey(FixedKeyProcessorSupplier)method
- WrappedFixedKeyProcessorSupplier<KIn,VIn, - Interface in org.apache.kafka.streams.processor.apiVOut> 
- 
Marker interface for classes implementingFixedKeyProcessorSupplierthat have been wrapped via aProcessorWrapper.
- WrappedProcessorSupplier<KIn,VIn, - Interface in org.apache.kafka.streams.processor.apiKOut, VOut> 
- 
Marker interface for classes implementingProcessorSupplierthat have been wrapped via aProcessorWrapper.
- WrapperSerde(Serializer<T>, Deserializer<T>) - Constructor for class org.apache.kafka.common.serialization.Serdes.WrapperSerde
- wrapProcessorSupplier(String, ProcessorSupplier<KIn, VIn, KOut, VOut>) - Method in interface org.apache.kafka.streams.processor.api.ProcessorWrapper
- 
Wrap or replace the providedProcessorSupplierand return aWrappedProcessorSupplierTo convert aProcessorSupplierinstance into aWrappedProcessorSupplier, use theProcessorWrapper.asWrapped(ProcessorSupplier)method
- WRITE - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
- 
WRITE operation.
- writeTo(ConsumerRecord<byte[], byte[]>, PrintStream) - Method in interface org.apache.kafka.common.MessageFormatter
- 
Parses and formats a record for display
Z
- ZERO_UUID - Static variable in class org.apache.kafka.common.Uuid
- 
A UUID that represents a null or empty UUID.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
Topology.addSource(org.apache.kafka.streams.AutoOffsetReset, String, String...)instead.