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

A

abort() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
 
abort() - Method in class org.apache.kafka.common.security.plain.PlainLoginModule
 
abort() - Method in class org.apache.kafka.common.security.scram.ScramLoginModule
 
abortTransaction() - Method in class org.apache.kafka.clients.producer.KafkaProducer
Aborts the ongoing transaction.
abortTransaction() - Method in class org.apache.kafka.clients.producer.MockProducer
 
abortTransaction() - Method in interface org.apache.kafka.clients.producer.Producer
abortTransactionException - Variable in class org.apache.kafka.clients.producer.MockProducer
 
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 more ConfigProvider that 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 more ConfigProvider that 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 more ConfigProvider that will be used to resolve variables in configuration property values.
AbstractOptions<T extends AbstractOptions> - Class in org.apache.kafka.clients.admin
 
AbstractOptions() - Constructor for class org.apache.kafka.clients.admin.AbstractOptions
 
AbstractProcessor<K,​V> - Class in org.apache.kafka.streams.processor
An abstract implementation of Processor that manages the ProcessorContext instance and provides default no-op implementation of AbstractProcessor.close().
AbstractProcessor() - Constructor for class org.apache.kafka.streams.processor.AbstractProcessor
 
AbstractState - Class in org.apache.kafka.connect.health
Provides the current status along with identifier for Connect worker and tasks.
AbstractState(String, String, String) - Constructor for class org.apache.kafka.connect.health.AbstractState
Construct a state for connector or task.
accept(A, B) - Method in interface org.apache.kafka.common.KafkaFuture.BiConsumer
 
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
accepts(StateStore) - Method in interface org.apache.kafka.streams.state.QueryableStoreType
Called when searching for StateStores to see if they match the type expected by implementors of this interface.
AccessControlEntry - Class in org.apache.kafka.common.acl
Represents an access control entry.
AccessControlEntry(String, String, AclOperation, AclPermissionType) - Constructor for class org.apache.kafka.common.acl.AccessControlEntry
Create an instance of an access control entry with the provided parameters.
AccessControlEntryFilter - Class in org.apache.kafka.common.acl
Represents a filter which matches access control entries.
AccessControlEntryFilter(String, String, AclOperation, AclPermissionType) - Constructor for class org.apache.kafka.common.acl.AccessControlEntryFilter
Create an instance of an access control entry filter with the provided parameters.
ACKS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
acks
aclBinding() - 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.
AclBinding(Resource, AccessControlEntry) - Constructor for class org.apache.kafka.common.acl.AclBinding
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(ResourceFilter, AccessControlEntryFilter) - Constructor for class org.apache.kafka.common.acl.AclBindingFilter
AclBindingFilter(ResourcePatternFilter, AccessControlEntryFilter) - Constructor for class org.apache.kafka.common.acl.AclBindingFilter
Create an instance of this filter with the provided parameters.
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 in org.apache.kafka.common.acl
Represents an operation which an ACL grants or denies permission to perform.
AclPermissionType - Enum in org.apache.kafka.common.acl
Represents whether an ACL grants or denies permissions.
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
 
activeHost() - Method in class org.apache.kafka.streams.KeyQueryMetadata
Get the active Kafka Streams instance for given key.
activeTasks() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
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 a Header with 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 a Header with 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 given Header to 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 a Header with 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 a Header with 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 a Header with 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
Add to this collection a Header with the given key and Date value.
addDecimal(String, BigDecimal) - Method in class org.apache.kafka.connect.header.ConnectHeaders
 
addDecimal(String, BigDecimal) - Method in interface org.apache.kafka.connect.header.Headers
Add to this collection a Header with the given key and Decimal value.
addDeserializerToConfig(Map<String, Object>, Deserializer<?>, Deserializer<?>) - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
Deprecated.
Since 2.7.0. This will be removed in a future major release.
addDeserializerToConfig(Properties, Deserializer<?>, Deserializer<?>) - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
Deprecated.
Since 2.7.0. This will be removed in a future major release.
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 a Header with the given key and value.
addErrorMessage(String) - Method in class org.apache.kafka.common.config.ConfigValue
 
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 a Header with the given key and value.
addGlobalStore(StoreBuilder<?>, String, String, Consumed<K, V>, String, ProcessorSupplier<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
addGlobalStore(StoreBuilder<?>, String, Deserializer<K>, Deserializer<V>, String, String, ProcessorSupplier<K, V>) - Method in class org.apache.kafka.streams.Topology
addGlobalStore(StoreBuilder<?>, String, Deserializer<KIn>, Deserializer<VIn>, String, String, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class org.apache.kafka.streams.Topology
Adds a global StateStore to the topology.
addGlobalStore(StoreBuilder<?>, String, Consumed<K, V>, ProcessorSupplier<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
addGlobalStore(StoreBuilder<?>, String, Consumed<KIn, VIn>, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class org.apache.kafka.streams.StreamsBuilder
Adds a global StateStore to the topology.
addGlobalStore(StoreBuilder<?>, String, TimestampExtractor, Deserializer<K>, Deserializer<V>, String, String, ProcessorSupplier<K, V>) - Method in class org.apache.kafka.streams.Topology
addGlobalStore(StoreBuilder<?>, String, TimestampExtractor, Deserializer<KIn>, Deserializer<VIn>, String, String, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class org.apache.kafka.streams.Topology
Adds a global StateStore to the 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 a Header with the given key and value.
addLatencyAndThroughputSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
Deprecated.
since 2.5. Use addLatencyRateTotalSensor() instead.
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 via Sensor.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 a Header with 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 a Header with 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 a Header with 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.
addProcessor(String, ProcessorSupplier<KIn, VIn, KOut, VOut>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new processor node that receives and processes records output by one or more parent source or processor node.
addProcessor(String, ProcessorSupplier, String...) - Method in class org.apache.kafka.streams.Topology
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 via Sensor.record(double) etc, it will be counted as one invocation of the operation, and hence the rate / count metrics will be updated accordingly.
addRecord(ConsumerRecord<K, V>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
addReporter(MetricsReporter) - Method in class org.apache.kafka.common.metrics.Metrics
Add a MetricReporter
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.
addSerializerToConfig(Map<String, Object>, Serializer<?>, Serializer<?>) - Static method in class org.apache.kafka.clients.producer.ProducerConfig
Deprecated.
Since 2.7.0. This will be removed in a future major release.
addSerializerToConfig(Properties, Serializer<?>, Serializer<?>) - Static method in class org.apache.kafka.clients.producer.ProducerConfig
Deprecated.
Since 2.7.0. This will be removed in a future major release.
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 a Header with the given key and value.
addSink(String, String, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to the named Kafka topic.
addSink(String, String, Serializer<K>, Serializer<V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to the named Kafka topic.
addSink(String, String, Serializer<K>, Serializer<V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to the named Kafka topic.
addSink(String, String, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to the named Kafka topic, using the supplied partitioner.
addSink(String, TopicNameExtractor<K, V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to Kafka topics based on topicExtractor.
addSink(String, TopicNameExtractor<K, V>, Serializer<K>, Serializer<V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to Kafka topics based on topicExtractor.
addSink(String, TopicNameExtractor<K, V>, Serializer<K>, Serializer<V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to Kafka topics based on topicExtractor.
addSink(String, TopicNameExtractor<K, V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to Kafka topics based on topicExtractor, using the supplied partitioner.
addSource(String, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
addSource(String, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forward the records to child processor and/or sink nodes.
addSource(String, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forwards the records to child processor and/or sink nodes.
addSource(String, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor and/or sink nodes.
addSource(TimestampExtractor, String, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
addSource(TimestampExtractor, String, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forward the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forward the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, TimestampExtractor, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forwards the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, TimestampExtractor, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, TimestampExtractor, String, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, TimestampExtractor, String, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forward the records to child processor and/or sink nodes.
addStateStore(StoreBuilder<?>) - Method in class org.apache.kafka.streams.StreamsBuilder
Adds a state store to the underlying Topology.
addStateStore(StoreBuilder<?>, String...) - Method in class org.apache.kafka.streams.Topology
Adds a state store.
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 a Header with 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 a Header with the given key and value.
addThroughputSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
Deprecated.
since 2.5. Use addRateTotalSensor() instead.
addTime(String, Date) - Method in class org.apache.kafka.connect.header.ConnectHeaders
 
addTime(String, Date) - Method in interface org.apache.kafka.connect.header.Headers
Add to this collection a Header with the given key and Time value.
addTimestamp(String, Date) - Method in class org.apache.kafka.connect.header.ConnectHeaders
 
addTimestamp(String, Date) - Method in interface org.apache.kafka.connect.header.Headers
Add to this collection a Header with the given key and Timestamp value.
addWaiter(KafkaFuture.BiConsumer<? super T, ? super Throwable>) - Method in class org.apache.kafka.common.KafkaFuture
 
addWithoutValidating(String, Object, Schema) - Method in class org.apache.kafka.connect.header.ConnectHeaders
 
Admin - Interface in org.apache.kafka.clients.admin
The administrative client for Kafka, which supports managing and inspecting topics, brokers, configurations and ACLs.
ADMIN - 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 isolate admin configs 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
 
AdminClientConfig(Map<?, ?>, boolean) - Constructor for class org.apache.kafka.clients.admin.AdminClientConfig
 
adminClientId() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
adminClientPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
Prefix a property with StreamsConfig.ADMIN_CLIENT_PREFIX.
adminConfig() - Method in class org.apache.kafka.connect.mirror.MirrorClientConfig
Sub-config for Admin clients.
advanceBy(long) - Method in class org.apache.kafka.streams.kstream.TimeWindows
Deprecated.
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.
advanceTimeMs(long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Advances the internally tracked time.
advanceWallClockTime(long) - Method in class org.apache.kafka.streams.TopologyTestDriver
Deprecated.
advanceWallClockTime(Duration) - Method in class org.apache.kafka.streams.TopologyTestDriver
Advances the internally mocked wall-clock time.
after(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Deprecated.
after(Duration) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Changes the end window boundary to timeDifference but 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<VOut>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
Aggregate the values of records in these streams by the grouped key.
aggregate(Initializer<VOut>, Materialized<K, VOut, 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<VOut>, Named) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
Aggregate the values of records in these streams by the grouped key.
aggregate(Initializer<VOut>, Named, Materialized<K, VOut, 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 the value of records of the original KTable that got mapped to the same key into a new instance of KTable using default serializers and deserializers.
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 the value of records of the original KTable that got mapped to the same key into a new instance of KTable.
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 the value of records of the original KTable that got mapped to the same key into a new instance of KTable using default serializers and deserializers.
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 the value of records of the original KTable that got mapped to the same key into a new instance of KTable.
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,​VA> - Interface in org.apache.kafka.streams.kstream
The Aggregator interface for aggregating values of the given key.
alignListEntriesWithSchema(Schema, List<Object>) - Static method in class org.apache.kafka.connect.data.Values
 
alignMapKeysAndValuesWithSchema(Schema, Map<Object, Object>) - Static method in class org.apache.kafka.connect.data.Values
 
alignMapKeysWithSchema(Schema, Map<Object, Object>) - Static method in class org.apache.kafka.connect.data.Values
 
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 a KafkaFuture which succeeds on KafkaFuture.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
Return a future which succeeds only if all the topic deletions succeed.
all() - Method in class org.apache.kafka.clients.admin.DescribeConfigsResult
Return a future which succeeds only if all the config descriptions succeed.
all() - Method in class org.apache.kafka.clients.admin.DescribeConsumerGroupsResult
Return a future which yields all ConsumerGroupDescription objects, if all the describes succeed.
all() - Method in class org.apache.kafka.clients.admin.DescribeLogDirsResult
Deprecated.
Deprecated Since Kafka 2.7. Use DescribeLogDirsResult.allDescriptions().
all() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult
Return a future which succeeds if log directory information of all replicas are available
all() - Method in class org.apache.kafka.clients.admin.DescribeTopicsResult
Return a future which succeeds only if all the topic descriptions succeed.
all() - Method in class org.apache.kafka.clients.admin.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.ElectPreferredLeadersResult
Deprecated.
Return a future which succeeds if all the topic elections 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.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.RemoveMembersFromConsumerGroupResult
Returns a future which indicates whether the request was 100% success, i.e.
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 - org.apache.kafka.common.acl.AclOperation
ALL operation.
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
Returns LagInfo, for all store partitions (active or standby) local to this Streams instance.
allMetadata() - Method in class org.apache.kafka.streams.KafkaStreams
Find all currently running KafkaStreams instances (potentially remotely) that use the same application ID as this instance (i.e., all instances that belong to the same Kafka Streams application) and return StreamsMetadata for each discovered instance.
allMetadataForStore(String) - Method in class org.apache.kafka.streams.KafkaStreams
Find all currently running KafkaStreams instances (potentially remotely) that use the same application ID as this instance (i.e., all instances that belong to the same Kafka Streams application) and that contain a StateStore with the given storeName and return StreamsMetadata for each discovered instance.
allOf(KafkaFuture<?>...) - Static method in class org.apache.kafka.common.KafkaFuture
Returns a new KafkaFuture that is completed when all the given futures have completed.
ALLOW - org.apache.kafka.common.acl.AclPermissionType
Grants access.
ALLOW_AUTO_CREATE_TOPICS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
allow.auto.create.topics
allowDowngrade() - Method in class org.apache.kafka.clients.admin.FeatureUpdate
 
ALLOWED - org.apache.kafka.server.authorizer.AuthorizationResult
 
allWithName(String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
 
allWithName(String) - Method in interface org.apache.kafka.connect.header.Headers
Get the collection of Header objects whose keys all match the specified key.
AlreadyExistsException - Exception in org.apache.kafka.connect.errors
Indicates the operation tried to create an entity that already exists.
AlreadyExistsException(String) - Constructor for exception org.apache.kafka.connect.errors.AlreadyExistsException
 
AlreadyExistsException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.AlreadyExistsException
 
AlreadyExistsException(Throwable) - Constructor for exception org.apache.kafka.connect.errors.AlreadyExistsException
 
ALTER - org.apache.kafka.common.acl.AclOperation
ALTER operation.
ALTER_CONFIGS - 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.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
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 a 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 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.
alterConfigs(Map<ConfigResource, Config>) - Method in interface org.apache.kafka.clients.admin.Admin
Deprecated.
alterConfigs(Map<ConfigResource, Config>, AlterConfigsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
alterConfigs(Map<ConfigResource, Config>, AlterConfigsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
Deprecated.
AlterConfigsOptions - Class in org.apache.kafka.clients.admin
AlterConfigsOptions() - Constructor for class org.apache.kafka.clients.admin.AlterConfigsOptions
 
AlterConfigsResult - Class in org.apache.kafka.clients.admin
The result of the Admin.alterConfigs(Map) 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.KafkaAdminClient
 
AlterConsumerGroupOffsetsOptions - Class in org.apache.kafka.clients.admin
AlterConsumerGroupOffsetsOptions() - Constructor for class org.apache.kafka.clients.admin.AlterConsumerGroupOffsetsOptions
 
AlterConsumerGroupOffsetsResult - Class in org.apache.kafka.clients.admin
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.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.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
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.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
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 - org.apache.kafka.common.acl.AclOperation
In a filter, matches any AclOperation.
ANY - org.apache.kafka.common.acl.AclPermissionType
In a filter, matches any AclPermissionType.
ANY - org.apache.kafka.common.resource.PatternType
In a filter, matches any resource pattern type.
ANY - org.apache.kafka.common.resource.ResourceType
In a filter, matches any ResourceType.
ANY - Static variable in class org.apache.kafka.common.acl.AccessControlEntryFilter
Matches any access control entry.
ANY - Static variable in class org.apache.kafka.common.acl.AclBindingFilter
A filter which matches any ACL binding.
ANY - Static variable in class org.apache.kafka.common.resource.ResourceFilter
Matches any resource.
ANY - Static variable in class org.apache.kafka.common.resource.ResourcePatternFilter
Matches any resource pattern.
ApiException - Exception in org.apache.kafka.common.errors
Any API exception that is part of the public protocol and should be a subclass of this class and be part of this package.
ApiException() - Constructor for exception org.apache.kafka.common.errors.ApiException
 
ApiException(String) - Constructor for exception org.apache.kafka.common.errors.ApiException
 
ApiException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ApiException
 
ApiException(Throwable) - Constructor for exception org.apache.kafka.common.errors.ApiException
 
appConfigs() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
 
appConfigs() - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
Returns all the application config properties as key/value pairs.
appConfigs() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
appConfigs() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns 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.ProcessorContext
Returns 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
 
appConfigsWithPrefix(String) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns 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(StringBuilder, Object, boolean) - Static method in class org.apache.kafka.connect.data.Values
 
APPEND - 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.
appendIterable(StringBuilder, Iterator<?>) - Static method in class org.apache.kafka.connect.data.Values
 
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
applicationId() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
 
applicationId() - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
Returns the application id.
applicationId() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
applicationId() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the application id.
applicationId() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
Returns the application id.
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 all Headers with the given key, apply the transform to each and store the result in place of the original.
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, VA) - 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
Transform the given Header and return the updated Header.
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 all Headers, 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 the record and return another record object (which may be record itself) or null, 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 of value1 and value2.
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 - 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 of Branched with provided branch name suffix.
as(String) - Static method in class org.apache.kafka.streams.kstream.Consumed
Create an instance of Consumed with provided processor name.
as(String) - Static method in class org.apache.kafka.streams.kstream.Grouped
Create a Grouped instance 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 of Joined with 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 a StateStore with 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 of Produced with provided processor name.
as(String) - Static method in class org.apache.kafka.streams.kstream.Repartitioned
Create a Repartitioned instance with the provided name used as part of the repartition topic.
as(String) - Static method in class org.apache.kafka.streams.kstream.StreamJoined
Creates a StreamJoined instance using the provided name for the state stores and hence the changelog topics for the join stores.
as(KeyValueBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
Materialize a KeyValueStore using the provided KeyValueBytesStoreSupplier.
as(SessionBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
Materialize a SessionStore using the provided SessionBytesStoreSupplier.
as(WindowBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
Materialize a WindowStore using the provided WindowBytesStoreSupplier.
asDouble(Object, Schema, Throwable) - Static method in class org.apache.kafka.connect.data.Values
Convert the specified value with the desired floating point type.
asLong(Object, Schema, Throwable) - Static method in class org.apache.kafka.connect.data.Values
Convert the specified value to the desired scalar value type.
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.CooperativeStickyAssignor
 
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.
assignment() - Method in class org.apache.kafka.clients.admin.MemberDescription
The assignment of the group member.
assignment() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
assignment() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the set of partitions currently assigned to this consumer.
assignment() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
assignment() - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
Get the current set of assigned TopicPartitions for this task.
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
 
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.
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
AuthenticateCallbackHandler - Interface in org.apache.kafka.common.security.auth
 
authenticated() - Method in class org.apache.kafka.common.security.plain.PlainAuthenticateCallback
Returns true if client password matches expected password, false otherwise.
authenticated(boolean) - Method in class org.apache.kafka.common.security.plain.PlainAuthenticateCallback
Sets the authenticated state.
AuthenticationContext - Interface in org.apache.kafka.common.security.auth
An object representing contextual information from the authentication session.
AuthenticationException - Exception in org.apache.kafka.common.errors
This exception indicates that SASL authentication has failed.
AuthenticationException(String) - Constructor for exception org.apache.kafka.common.errors.AuthenticationException
 
AuthenticationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.AuthenticationException
 
AuthenticationException(Throwable) - Constructor for exception org.apache.kafka.common.errors.AuthenticationException
 
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 in org.apache.kafka.common.errors
 
AuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.AuthorizationException
 
AuthorizationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.AuthorizationException
 
AuthorizationResult - Enum 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.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.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.
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
 
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
A SampledStat that 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, 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.
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 a StateStore It is expected that implementations of this class will not call the StateRestoreCallback.restore(byte[], byte[]) method.
before(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Deprecated.
before(Duration) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Changes the start window boundary to timeDifference but 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 given offset
beginningOffsets(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
beginningOffsets(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the first offset for the given partitions.
beginningOffsets(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
beginningOffsets(Collection<TopicPartition>, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
beginningOffsets(Collection<TopicPartition>, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the first offset for the given partitions.
beginningOffsets(Collection<TopicPartition>, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
beginTransaction() - Method in class org.apache.kafka.clients.producer.KafkaProducer
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 - org.apache.kafka.clients.admin.ConfigEntry.ConfigType
 
BOOLEAN - org.apache.kafka.common.config.ConfigDef.Type
 
BOOLEAN - org.apache.kafka.connect.data.Schema.Type
Boolean value (true or false)
BOOLEAN_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
 
bootstrap(List<InetSocketAddress>) - Static method in class org.apache.kafka.common.Cluster
Create a "bootstrap" cluster using the given list of host/ports
BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
bootstrap.servers
BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
bootstrap.servers
BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
bootstrap.servers
BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
bootstrap.servers
bound() - Method in class org.apache.kafka.common.metrics.Quota
 
bound() - Method in exception org.apache.kafka.common.metrics.QuotaViolationException
 
branch(Named, Predicate<? super K, ? super V>...) - Method in interface org.apache.kafka.streams.kstream.KStream
Deprecated.
since 2.8. Use KStream.split(Named) instead.
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>...) - Method in interface org.apache.kafka.streams.kstream.KStream
Deprecated.
since 2.8. Use KStream.split() instead.
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
The Branched class is used to define the optional parameters when building branches with BranchedKStream.
Branched(String, Function<? super KStream<K, V>, ? extends KStream<K, V>>, Consumer<? super KStream<K, V>>) - Constructor for class org.apache.kafka.streams.kstream.Branched
 
Branched(Branched<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Branched
Create an instance of Branched from an existing instance.
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 - org.apache.kafka.common.config.ConfigResource.Type
 
BROKER_LOGGER - org.apache.kafka.common.config.ConfigResource.Type
 
brokerId() - Method in class org.apache.kafka.common.TopicPartitionReplica
 
brokerId() - Method in interface org.apache.kafka.server.authorizer.AuthorizerServerInfo
Returns broker id.
BrokerIdNotRegisteredException - Exception in org.apache.kafka.common.errors
 
BrokerIdNotRegisteredException(String) - Constructor for exception org.apache.kafka.common.errors.BrokerIdNotRegisteredException
 
BrokerIdNotRegisteredException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.BrokerIdNotRegisteredException
 
BrokerNotAvailableException - Exception in org.apache.kafka.common.errors
 
BrokerNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.BrokerNotAvailableException
 
BrokerNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.BrokerNotAvailableException
 
BrokerNotFoundException - Exception in org.apache.kafka.streams.errors
Indicates that none of the specified brokers could be found.
BrokerNotFoundException(String) - Constructor for exception org.apache.kafka.streams.errors.BrokerNotFoundException
 
BrokerNotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.BrokerNotFoundException
 
BrokerNotFoundException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.BrokerNotFoundException
 
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
BufferExhaustedException - Exception 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 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 the Topology that represents the specified processing logic.
build(Properties) - Method in class org.apache.kafka.streams.StreamsBuilder
Returns the Topology that represents the specified processing logic and accepts a Properties instance 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.
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
 
buildPrincipal(TransportLayer, Authenticator) - Method in class org.apache.kafka.common.security.auth.DefaultPrincipalBuilder
Deprecated.
 
buildPrincipal(TransportLayer, Authenticator) - Method in interface org.apache.kafka.common.security.auth.PrincipalBuilder
Deprecated.
Returns Principal.
BUILT_IN_METRICS_VERSION_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
built.in.metrics.version
ByteArray() - Static method in class org.apache.kafka.common.serialization.Serdes
 
ByteArrayDeserializer - Class in org.apache.kafka.common.serialization
 
ByteArrayDeserializer() - Constructor for class org.apache.kafka.common.serialization.ByteArrayDeserializer
 
ByteArraySerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.ByteArraySerde
 
ByteArraySerializer - Class in org.apache.kafka.common.serialization
 
ByteArraySerializer() - Constructor for class org.apache.kafka.common.serialization.ByteArraySerializer
 
ByteBuffer() - Static method in class org.apache.kafka.common.serialization.Serdes
 
ByteBufferDeserializer - Class in org.apache.kafka.common.serialization
 
ByteBufferDeserializer() - Constructor for class org.apache.kafka.common.serialization.ByteBufferDeserializer
 
ByteBufferSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.ByteBufferSerde
 
ByteBufferSerializer - Class in org.apache.kafka.common.serialization
 
ByteBufferSerializer() - Constructor for class org.apache.kafka.common.serialization.ByteBufferSerializer
 
bytes() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
 
Bytes() - Static method in class org.apache.kafka.common.serialization.Serdes
 
BYTES - 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
cache.max.bytes.buffering
cachingEnabled - Variable in class org.apache.kafka.streams.kstream.Materialized
 
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
 
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
cancelled() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedPunctuator
 
cancelled() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedPunctuator
 
canConsume(String) - Method in class org.apache.kafka.connect.data.Values.Parser
 
canConsume(String, boolean) - Method in class org.apache.kafka.connect.data.Values.Parser
 
canConsumeNextToken() - Method in class org.apache.kafka.connect.data.Values.Parser
 
canDetect(Object) - Method in class org.apache.kafka.connect.data.Values.SchemaDetector
 
canParseSingleTokenLiteral(Values.Parser, boolean, String) - Static method in class org.apache.kafka.connect.data.Values
 
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.
chainConsumer - Variable in class org.apache.kafka.streams.kstream.Branched
 
chainFunction - Variable in class org.apache.kafka.streams.kstream.Branched
 
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 from MirrorCheckpointConnector.
Checkpoint(String, TopicPartition, long, long, String) - Constructor for class org.apache.kafka.connect.mirror.Checkpoint
 
checkpointTopics() - Method in class org.apache.kafka.connect.mirror.MirrorClient
Find all checkpoint topics on this cluster.
checkpointTopics(Map<String, Object>) - Static method in class org.apache.kafka.connect.mirror.RemoteClusterUtils
Find all checkpoint 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
 
checksum() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
Deprecated.
As of Kafka 0.11.0. Because of the potential for message format conversion on the broker, the checksum returned by the broker may not match what was computed by the producer. It is therefore unsafe to depend on this checksum for end-to-end delivery guarantees. Additionally, message format v2 does not include a record-level checksum (for performance, the record checksum was replaced with a batch checksum). To maintain compatibility, a partial checksum computed from the record timestamp, serialized key size, and serialized value size is returned instead, but this should not be depended on for end-to-end reliability.
checksum() - Method in class org.apache.kafka.clients.producer.RecordMetadata
Deprecated.
As of Kafka 0.11.0. Because of the potential for message format conversion on the broker, the computed checksum may not match what was stored on the broker, or what will be returned to the consumer. It is therefore unsafe to depend on this checksum for end-to-end delivery guarantees. Additionally, message format v2 does not include a record-level checksum (for performance, the record checksum was replaced with a batch checksum). To maintain compatibility, a partial checksum computed from the record timestamp, serialized key size, and serialized value size is returned instead, but this should not be depended on for end-to-end reliability.
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 - Variable in class org.apache.kafka.streams.processor.To
 
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
The child this data was forwarded to.
CLASS - org.apache.kafka.clients.admin.ConfigEntry.ConfigType
 
CLASS - org.apache.kafka.common.config.ConfigDef.Type
 
cleanUp() - Method in class org.apache.kafka.streams.KafkaStreams
Do a clean up of the local StateStore directory (StreamsConfig.STATE_DIR_CONFIG) by deleting all data with regard to the application 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 - 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.streams.StreamsConfig
client.id
CLIENT_RACK_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
client.rack
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 interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
Returns the client id from the request header.
clientProps() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
Provides Config with prefix producer.override. for ConnectorType.SOURCE.
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 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 in org.apache.kafka.server.quota
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 in org.apache.kafka.server.quota
Types of quotas that may be configured on brokers for client requests.
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.MockConsumer
 
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.clients.producer.UniformStickyPartitioner
 
close() - Method in class org.apache.kafka.common.config.provider.DirectoryConfigProvider
 
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 class org.apache.kafka.common.security.auth.DefaultPrincipalBuilder
Deprecated.
 
close() - Method in interface org.apache.kafka.common.security.auth.Login
Closes this instance.
close() - Method in interface org.apache.kafka.common.security.auth.PrincipalBuilder
Deprecated.
Closes this instance.
close() - Method in interface org.apache.kafka.common.serialization.Deserializer
Close this deserializer.
close() - Method in class org.apache.kafka.common.serialization.ExtendedDeserializer.Wrapper
Deprecated.
 
close() - Method in class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
Deprecated.
 
close() - Method in 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
Close 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 this KafkaStreams instance 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
Close this transformer and clean up any resources.
close() - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
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 class org.apache.kafka.streams.processor.AbstractProcessor
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.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.WindowStoreIterator
 
close() - Method in class org.apache.kafka.streams.TopologyTestDriver
Close the driver, its topology, and all processors.
close(long, TimeUnit) - Method in interface org.apache.kafka.clients.admin.Admin
Deprecated.
close(long, TimeUnit) - Method in interface org.apache.kafka.clients.consumer.Consumer
Deprecated.
close(long, TimeUnit) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
close(long, TimeUnit) - Method in class org.apache.kafka.clients.consumer.MockConsumer
Deprecated.
close(long, TimeUnit) - Method in interface org.apache.kafka.clients.producer.Producer
Deprecated.
close(long, TimeUnit) - Method in class org.apache.kafka.streams.KafkaStreams
Deprecated.
Use KafkaStreams.close(Duration) instead; note, that KafkaStreams.close(Duration) has different semantics and does not block on zero, e.g., `Duration.ofMillis(0)`.
close(String, Options) - Method in interface org.apache.kafka.streams.state.RocksDBConfigSetter
Close any user-constructed objects that inherit from org.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.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.MockConsumer
 
close(Duration) - Method in class org.apache.kafka.clients.producer.KafkaProducer
This method waits up to timeout for the producer to complete the sending of all incomplete requests.
close(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 this KafkaStreams by 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 use this method to close writers for partitions that are no longer assigned to the SinkTask.
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
 
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 - org.apache.kafka.common.resource.ResourceType
The cluster as a whole.
CLUSTER - Static variable in class org.apache.kafka.common.resource.Resource
A resource representing the whole cluster.
CLUSTER_ACTION - org.apache.kafka.common.acl.AclOperation
CLUSTER_ACTION operation.
CLUSTER_NAME - Static variable in class org.apache.kafka.common.resource.Resource
The name of the CLUSTER resource.
ClusterAuthorizationException - Exception in org.apache.kafka.common.errors
 
ClusterAuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.ClusterAuthorizationException
 
ClusterAuthorizationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ClusterAuthorizationException
 
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.DescribeClusterResult
Returns a future which yields the current cluster id.
clusterId() - Method in class org.apache.kafka.common.ClusterResource
Return the cluster id.
clusterResource() - Method in class org.apache.kafka.common.Cluster
 
clusterResource() - 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
The ClusterResource class encapsulates metadata for a Kafka cluster.
ClusterResource(String) - Constructor for class org.apache.kafka.common.ClusterResource
Create ClusterResource with a cluster id.
ClusterResourceListener - Interface in org.apache.kafka.common
A callback interface that users can implement when they wish to get notified about changes in the Cluster metadata.
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 org.apache.kafka.common.acl.AclOperation
Return the code of this operation.
code() - Method in enum org.apache.kafka.common.acl.AclPermissionType
Return the code of this permission type.
code() - Method in enum org.apache.kafka.common.resource.PatternType
 
code() - Method in enum org.apache.kafka.common.resource.ResourceType
Return the code of this resource.
cogroup(Aggregator<? super K, ? super V, VOut>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Create a new CogroupedKStream from the this grouped KStream to allow cogrouping other KGroupedStream to it.
cogroup(KGroupedStream<K, VIn>, Aggregator<? super K, ? super VIn, VOut>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
Add an already grouped KStream to this CogroupedKStream.
CogroupedKStream<K,​VOut> - Interface in org.apache.kafka.streams.kstream
CogroupedKStream is an abstraction of multiple grouped record streams of KeyValue pairs.
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
Commit the offsets, up to the offsets that have been returned by SourceTask.poll().
commit() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
 
commit() - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
Requests a commit.
commit() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
commit() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Requests 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 last KafkaConsumer.poll(Duration) for all the subscribed list of topics and partition.
commitAsync() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commitAsync(Map<TopicPartition, OffsetAndMetadata>, OffsetCommitCallback) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitAsync(Map<TopicPartition, OffsetAndMetadata>, OffsetCommitCallback) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit the specified offsets for the specified list of topics and partitions to Kafka.
commitAsync(Map<TopicPartition, OffsetAndMetadata>, OffsetCommitCallback) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commitAsync(OffsetCommitCallback) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitAsync(OffsetCommitCallback) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit offsets returned on the last poll() for the subscribed list of topics and partitions.
commitAsync(OffsetCommitCallback) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commitCount() - Method in class org.apache.kafka.clients.producer.MockProducer
 
CommitFailedException - Exception in org.apache.kafka.clients.consumer
This exception is raised when an offset commit with KafkaConsumer.commitSync() fails with an unrecoverable error.
CommitFailedException() - Constructor for exception org.apache.kafka.clients.consumer.CommitFailedException
 
CommitFailedException(String) - Constructor for exception org.apache.kafka.clients.consumer.CommitFailedException
 
commitRecord(SourceRecord) - Method in class org.apache.kafka.connect.source.SourceTask
commitRecord(SourceRecord, RecordMetadata) - Method in class org.apache.kafka.connect.source.SourceTask
Commit an individual SourceRecord when the callback from the producer client is received.
commitSync() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitSync() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit offsets returned on the last poll() for all the subscribed list of topics and partitions.
commitSync() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commitSync(Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitSync(Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit offsets returned on the last poll() for all the subscribed list of topics and partitions.
commitSync(Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commitSync(Map<TopicPartition, OffsetAndMetadata>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitSync(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit the specified offsets for the specified list of topics and partitions.
commitSync(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commitSync(Map<TopicPartition, OffsetAndMetadata>, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
commitSync(Map<TopicPartition, OffsetAndMetadata>, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commit the specified offsets for the specified list of topics and partitions.
commitSync(Map<TopicPartition, OffsetAndMetadata>, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
committed() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
Whether ProcessorContext.commit() has been called in this context.
committed() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
Whether ProcessorContext.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
 
committed(TopicPartition) - Method in interface org.apache.kafka.clients.consumer.Consumer
Deprecated.
committed(TopicPartition) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Deprecated.
since 2.4 Use KafkaConsumer.committed(Set) instead
committed(TopicPartition) - Method in class org.apache.kafka.clients.consumer.MockConsumer
Deprecated.
committed(TopicPartition, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
Deprecated.
committed(TopicPartition, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Deprecated.
committed(TopicPartition, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
Deprecated.
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
commitTransactionException - Variable in class org.apache.kafka.clients.producer.MockProducer
 
commonSchemaFor(Schema, SchemaAndValue) - Static method in class org.apache.kafka.connect.data.Values
 
compareKeyValue(ProducerRecord<K, V>, K, V) - Static method in class org.apache.kafka.streams.test.OutputVerifier
Deprecated.
Compares a ProducerRecord with the provided key and value and throws an AssertionError if the ProducerRecord's key or value is not equal to the expected key or value.
compareKeyValue(ProducerRecord<K, V>, ProducerRecord<K, V>) - Static method in class org.apache.kafka.streams.test.OutputVerifier
Deprecated.
Compares the keys and values of two ProducerRecord's and throws an AssertionError if the keys or values are not equal to each other.
compareKeyValueHeaders(ProducerRecord<K, V>, K, V, Headers) - Static method in class org.apache.kafka.streams.test.OutputVerifier
Deprecated.
Compares a ProducerRecord with the provided key, value, and headers and throws an AssertionError if the ProducerRecord's key, value, or headers is not equal to the expected key, value, or headers.
compareKeyValueHeaders(ProducerRecord<K, V>, ProducerRecord<K, V>) - Static method in class org.apache.kafka.streams.test.OutputVerifier
Deprecated.
Compares the keys, values, and headers of two ProducerRecord's and throws an AssertionError if the keys, values, or headers are not equal to each other.
compareKeyValueHeadersTimestamp(ProducerRecord<K, V>, K, V, Headers, long) - Static method in class org.apache.kafka.streams.test.OutputVerifier
Deprecated.
Compares a ProducerRecord with the provided key, value, headers, and timestamp and throws an AssertionError if the ProducerRecord's key, value, headers, or timestamp is not equal to the expected key, value, headers, or timestamp.
compareKeyValueHeadersTimestamp(ProducerRecord<K, V>, ProducerRecord<K, V>) - Static method in class org.apache.kafka.streams.test.OutputVerifier
Deprecated.
Compares the keys, values, headers, and timestamp of two ProducerRecord's and throws an AssertionError if the keys, values, headers, or timestamps are not equal to each other.
compareKeyValueTimestamp(ProducerRecord<K, V>, K, V, long) - Static method in class org.apache.kafka.streams.test.OutputVerifier
Deprecated.
Compares a ProducerRecord with the provided key, value, and timestamp and throws an AssertionError if the ProducerRecord's key, value, or timestamp is not equal to the expected key, value, or timestamp.
compareKeyValueTimestamp(ProducerRecord<K, V>, ProducerRecord<K, V>) - Static method in class org.apache.kafka.streams.test.OutputVerifier
Deprecated.
Compares the keys, values, and timestamps of two ProducerRecord's and throws an AssertionError if the keys, values, or timestamps are not equal to each other.
compareTo(Uuid) - Method in class org.apache.kafka.common.Uuid
 
compareTo(TaskId) - Method in class org.apache.kafka.streams.processor.TaskId
 
compareValue(ProducerRecord<K, V>, ProducerRecord<K, V>) - Static method in class org.apache.kafka.streams.test.OutputVerifier
Deprecated.
Compares the values of two ProducerRecord's and throws an AssertionError if they are not equal to each other.
compareValue(ProducerRecord<K, V>, V) - Static method in class org.apache.kafka.streams.test.OutputVerifier
Deprecated.
Compares a ProducerRecord with the provided value and throws an AssertionError if the ProducerRecord's value is not equal to the expected value.
compareValueHeaders(ProducerRecord<K, V>, ProducerRecord<K, V>) - Static method in class org.apache.kafka.streams.test.OutputVerifier
Deprecated.
Compares the values and headers of two ProducerRecord's and throws an AssertionError if the values or headers are not equal to each other.
compareValueHeaders(ProducerRecord<K, V>, V, Headers) - Static method in class org.apache.kafka.streams.test.OutputVerifier
Deprecated.
Compares a ProducerRecord with the provided value and headers and throws an AssertionError if the ProducerRecord's value or headers is not equal to the expected value or headers.
compareValueTimestamp(ProducerRecord<K, V>, ProducerRecord<K, V>) - Static method in class org.apache.kafka.streams.test.OutputVerifier
Deprecated.
Compares the values and timestamps of two ProducerRecord's and throws an AssertionError if the values or timestamps are not equal to each other.
compareValueTimestamp(ProducerRecord<K, V>, V, long) - Static method in class org.apache.kafka.streams.test.OutputVerifier
Deprecated.
Compares a ProducerRecord with the provided value and timestamp and throws an AssertionError if the ProducerRecord's value or timestamp is not equal to the expected value or timestamp.
compilePredicate(Map<String, ?>) - Static method in class org.apache.kafka.common.metrics.JmxReporter
 
complete(T) - Method in class org.apache.kafka.common.KafkaFuture
If not already completed, sets the value returned by get() and related methods to the given value.
completedFuture(U) - Static method in class org.apache.kafka.common.KafkaFuture
Returns a new KafkaFuture that is already completed with the given value.
completeExceptionally(Throwable) - Method in class org.apache.kafka.common.KafkaFuture
If not already completed, causes invocations of get() and related methods to throw the given exception.
completeNext() - Method in class org.apache.kafka.clients.producer.MockProducer
Complete the earliest uncompleted call successfully.
COMPLETING_REBALANCE - org.apache.kafka.common.ConsumerGroupState
 
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_TYPE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
compression.type
COMPRESSION_TYPE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
COMPRESSION_TYPE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
ConcurrentTransactionsException - Exception in org.apache.kafka.common.errors
 
ConcurrentTransactionsException(String) - Constructor for exception org.apache.kafka.common.errors.ConcurrentTransactionsException
 
config() - Method in class org.apache.kafka.clients.admin.CreateTopicsResult.TopicMetadataAndConfig
 
config() - Method in class org.apache.kafka.common.metrics.KafkaMetric
 
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.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 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
 
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 to ConfigProvider for subscribing to changes.
ConfigData - Class in org.apache.kafka.common.config
Configuration data from a ConfigProvider.
ConfigData(Map<String, String>) - Constructor for class org.apache.kafka.common.config.ConfigData
Creates a new ConfigData with the given data.
ConfigData(Map<String, String>, Long) - Constructor for class org.apache.kafka.common.config.ConfigData
Creates a new ConfigData with the given data and TTL (in milliseconds).
configDef() - 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 in org.apache.kafka.common.config
The importance level for a configuration
ConfigDef.LambdaValidator - 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 the ConfigDef.validate(Map) to get valid values for a configuration given the current configuration values in order to perform full configuration validation and visibility modification.
ConfigDef.Type - Enum in org.apache.kafka.common.config
The config types
ConfigDef.Validator - Interface in org.apache.kafka.common.config
Validation logic the user may provide to perform single configuration validation.
ConfigDef.ValidList - Class in org.apache.kafka.common.config
 
ConfigDef.ValidString - Class in org.apache.kafka.common.config
 
ConfigDef.Width - Enum in org.apache.kafka.common.config
The width of a configuration value
configEntities() - Method in interface org.apache.kafka.server.quota.ClientQuotaEntity
Returns the list of configuration entities that this quota entity is comprised of.
configEntry() - 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, boolean, boolean, boolean) - Constructor for class org.apache.kafka.clients.admin.ConfigEntry
Deprecated.
since 1.1.0. This constructor will be removed in a future release.
ConfigEntry.ConfigSource - Enum in org.apache.kafka.clients.admin
Source of configuration entries.
ConfigEntry.ConfigSynonym - Class in org.apache.kafka.clients.admin
Class representing a configuration synonym of a ConfigEntry.
ConfigEntry.ConfigType - Enum in org.apache.kafka.clients.admin
Data type of configuration entry.
ConfigException - Exception in org.apache.kafka.common.config
Thrown if the user supplies an invalid configuration
ConfigException(String) - Constructor for exception org.apache.kafka.common.config.ConfigException
 
ConfigException(String, Object) - Constructor for exception org.apache.kafka.common.config.ConfigException
 
ConfigException(String, Object, String) - Constructor for exception org.apache.kafka.common.config.ConfigException
 
ConfigKey(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender, boolean) - Constructor for class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
configKeys() - Method in class org.apache.kafka.common.config.ConfigDef
Get the configuration keys
configNames() - Static method in class org.apache.kafka.clients.admin.AdminClientConfig
 
configNames() - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
 
configNames() - Static method in class org.apache.kafka.clients.producer.ProducerConfig
 
ConfigProvider - Interface in org.apache.kafka.common.config.provider
A provider of configuration data, which may optionally support subscriptions to configuration changes.
ConfigResource - Class in org.apache.kafka.common.config
A class representing resources that have configs.
ConfigResource(ConfigResource.Type, String) - Constructor for class org.apache.kafka.common.config.ConfigResource
Create an instance of this class with the provided parameters.
ConfigResource.Type - Enum in org.apache.kafka.common.config
Type of resource.
configs() - Method in class org.apache.kafka.clients.admin.NewTopic
The configuration for the new topic or null if no configs ever specified.
configs() - Method in 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 of ConfigProvider instances and uses them to perform transformations.
ConfigTransformer(Map<String, ConfigProvider>) - Constructor for class org.apache.kafka.common.config.ConfigTransformer
Creates a ConfigTransformer with the default pattern, of the form ${provider:[path:]key}.
ConfigTransformerResult - Class in org.apache.kafka.common.config
The result of a transformation from ConfigTransformer.
ConfigTransformerResult(Map<String, String>, Map<String, Long>) - Constructor for class org.apache.kafka.common.config.ConfigTransformerResult
Creates a new ConfigTransformerResult with the given data and TTL values for a set of paths.
configurable() - Method in interface org.apache.kafka.connect.rest.ConnectRestExtensionContext
Provides an implementation of Configurable that 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.clients.producer.UniformStickyPartitioner
 
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.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 class org.apache.kafka.common.security.auth.DefaultPrincipalBuilder
Deprecated.
 
configure(Map<String, ?>) - Method in interface org.apache.kafka.common.security.auth.PrincipalBuilder
Deprecated.
Configures this class with given key-value pairs.
configure(Map<String, ?>) - 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.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.LogAndFailExceptionHandler
 
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.ExtendedDeserializer.Wrapper
Deprecated.
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
Deprecated.
 
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, 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 of StoreBuilders that will be automatically added to the topology and connected to the associated processor.
ConnectException - Exception 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 org.apache.kafka.connect.errors.ConnectException
 
ConnectException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.ConnectException
 
ConnectException(Throwable) - Constructor for exception org.apache.kafka.connect.errors.ConnectException
 
ConnectHeaders - Class in org.apache.kafka.connect.header
A basic Headers implementation.
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
 
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 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 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 allows Connectors 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.
connectorType() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
Type of the Connector.
ConnectorType - Enum 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
Connects the processor and the state stores.
ConnectRecord<R extends 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 for ConnectRestExtension implementations to access the JAX-RS Configurable and cluster state ConnectClusterState.
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 - 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
The Consumed class is used to define the optional parameters when using StreamsBuilder to build instances of KStream, KTable, and GlobalKTable.
Consumed(Consumed<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Consumed
Create an instance of Consumed from an existing instance.
Consumer<K,​V> - Interface in org.apache.kafka.clients.consumer
 
CONSUMER - 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 isolate consumer configs from other client configs.
consumerClientId() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
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<?, ?>, boolean) - Constructor for class org.apache.kafka.clients.consumer.ConsumerConfig
 
ConsumerConfig(Map<String, Object>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerConfig
 
ConsumerConfig(Properties) - Constructor for class org.apache.kafka.clients.consumer.ConsumerConfig
 
ConsumerGroupDescription - Class in org.apache.kafka.clients.admin
A detailed description of a single consumer group in the cluster.
ConsumerGroupDescription(String, boolean, Collection<MemberDescription>, String, ConsumerGroupState, Node) - Constructor for class org.apache.kafka.clients.admin.ConsumerGroupDescription
 
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
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 to MockProducer.clear()
ConsumerGroupState - Enum in org.apache.kafka.common
The consumer group state.
consumerId() - Method in class org.apache.kafka.clients.admin.MemberDescription
The consumer id of the group member.
ConsumerInterceptor<K,​V> - Interface in org.apache.kafka.clients.consumer
A plugin interface that allows you to intercept (and possibly mutate) records received by the consumer.
ConsumerPartitionAssignor - Interface in org.apache.kafka.clients.consumer
This interface is used to define custom partition assignment for use in KafkaConsumer.
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 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 with StreamsConfig.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, long, int, int, K, V) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
Creates a record to be received from a specified topic and partition (provided for compatibility with Kafka 0.10 before the message format supported headers).
ConsumerRecord(String, int, long, long, TimestampType, Long, int, int, K, V, Headers) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
Creates a record to be received from a specified topic and partition
ConsumerRecord(String, int, long, long, TimestampType, Long, int, int, K, V, Headers, 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, 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).
ConsumerRecordFactory<K,​V> - Class in org.apache.kafka.streams.test
Deprecated.
Since 2.4 use methods of TestInputTopic instead
ConsumerRecordFactory(String, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a new factory for the given topic.
ConsumerRecordFactory(String, Serializer<K>, Serializer<V>, long) - Constructor for class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a new factory for the given topic.
ConsumerRecordFactory(String, Serializer<K>, Serializer<V>, long, long) - Constructor for class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a new factory for the given topic.
ConsumerRecordFactory(Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a new factory for the given topic.
ConsumerRecordFactory(Serializer<K>, Serializer<V>, long) - Constructor for class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a new factory for the given topic.
ConsumerRecordFactory(Serializer<K>, Serializer<V>, long, long) - Constructor for class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a new factory for the given topic.
ConsumerRecords<K,​V> - Class in org.apache.kafka.clients.consumer
A container that holds the list ConsumerRecord per partition for a particular topic.
ConsumerRecords(Map<TopicPartition, List<ConsumerRecord<K, V>>>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecords
 
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.
context - Variable in class org.apache.kafka.connect.connector.Connector
 
context - Variable in class org.apache.kafka.connect.sink.SinkTask
 
context - Variable in class org.apache.kafka.connect.source.SourceTask
 
context - Variable in class org.apache.kafka.streams.processor.AbstractProcessor
 
context() - Method in class org.apache.kafka.connect.connector.Connector
Returns the context object used to interact with the Kafka Connect runtime.
context() - Method in class org.apache.kafka.connect.sink.SinkConnector
 
context() - Method in class org.apache.kafka.connect.source.SourceConnector
 
context() - Method in class org.apache.kafka.streams.processor.AbstractProcessor
Get the processor's context set during initialization.
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.
CONTINUE - org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
 
CONTINUE - org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
 
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_MUTATION - org.apache.kafka.server.quota.ClientQuotaType
 
ControllerMovedException - Exception in org.apache.kafka.common.errors
 
ControllerMovedException(String) - Constructor for exception org.apache.kafka.common.errors.ControllerMovedException
 
ControllerMovedException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ControllerMovedException
 
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 for Converter and HeaderConverter instances.
ConverterConfig(ConfigDef, Map<String, ?>) - Constructor for class org.apache.kafka.connect.storage.ConverterConfig
 
ConverterType - Enum in org.apache.kafka.connect.storage
The type of Converter and HeaderConverter.
convertTo(Schema, Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
Convert the value to the desired type.
convertToBoolean(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
Convert the specified value to an Schema.Type.BOOLEAN value.
convertToByte(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
Convert the specified value to an Schema.Type.INT8 byte value.
convertToDate(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
Convert the specified value to an date value.
convertToDecimal(Schema, Object, int) - Static method in class org.apache.kafka.connect.data.Values
Convert the specified value to an decimal value.
convertToDouble(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
Convert the specified value to an Schema.Type.FLOAT64 double value.
convertToFloat(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
Convert the specified value to an Schema.Type.FLOAT32 float value.
convertToInteger(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
Convert the specified value to an Schema.Type.INT32 int value.
convertToList(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
Convert the specified value to an Schema.Type.ARRAY value.
convertToLong(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
Convert the specified value to an Schema.Type.INT64 long value.
convertToMap(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
Convert the specified value to an Schema.Type.MAP value.
convertToShort(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
Convert the specified value to an Schema.Type.INT16 short 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 an Schema.Type.STRING value.
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 an Schema.Type.STRUCT value.
convertToTime(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
Convert the specified value to an time value.
convertToTimestamp(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
Convert the specified value to an timestamp value.
convertToTimestampedFormat(byte[]) - Static method in interface org.apache.kafka.streams.state.TimestampedBytesStore
 
COOPERATIVE - org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
 
CooperativeStickyAssignor - Class in org.apache.kafka.clients.consumer
A cooperative version of the AbstractStickyAssignor.
CooperativeStickyAssignor() - Constructor for class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
 
coordinator() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
The consumer group coordinator, or null if the coordinator is not known.
CoordinatorLoadInProgressException - Exception in org.apache.kafka.common.errors
In the context of the group coordinator, the broker returns this error code for any coordinator request if it is still loading the group metadata (e.g.
CoordinatorLoadInProgressException(String) - Constructor for exception org.apache.kafka.common.errors.CoordinatorLoadInProgressException
 
CoordinatorLoadInProgressException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.CoordinatorLoadInProgressException
 
CoordinatorNotAvailableException - Exception in org.apache.kafka.common.errors
In the context of the group coordinator, the broker returns this error code for metadata or offset commit requests if the group metadata topic has not been created yet.
CoordinatorNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.CoordinatorNotAvailableException
 
CoordinatorNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.CoordinatorNotAvailableException
 
correlationId() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
Returns the correlation id from the request header.
corruptedTasks() - Method in exception org.apache.kafka.streams.errors.TaskCorruptedException
 
CorruptRecordException - Exception in org.apache.kafka.common.errors
This exception indicates a record has failed its internal CRC check, this generally indicates network or disk corruption.
CorruptRecordException() - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
 
CorruptRecordException(String) - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
 
CorruptRecordException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
 
CorruptRecordException(Throwable) - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
 
count() - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
The number of records for all topics
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 number of records of the original KTable that got mapped to the same key into a new instance of KTable.
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 number of records of the original KTable that got mapped to the same key into a new instance of KTable.
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 number of records of the original KTable that got mapped to the same key into a new instance of KTable.
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 number of records of the original KTable that got mapped to the same key into a new instance of KTable.
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.
Count - Class in org.apache.kafka.common.metrics.stats
Deprecated.
since 2.4 . Use WindowedCount instead
Count() - Constructor for class org.apache.kafka.common.metrics.stats.Count
Deprecated.
 
counts() - Method in class org.apache.kafka.common.metrics.stats.Histogram
 
create(String, List<KeyValue<K, V>>) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Creates consumer records with the given topic name, keys, and values.
create(String, List<KeyValue<K, V>>, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Creates consumer records with the given topic name, keys and values.
create(String, List<KeyValue<K, V>>, long, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Creates consumer records with the given topic name, keys, and values.
create(String, K, V) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a ConsumerRecord with the given topic name, key, and value.
create(String, K, V, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a ConsumerRecord with the given topic name and given topic, key, value, and timestamp.
create(String, K, V, Headers) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a ConsumerRecord with the given topic name, key, value, and headers.
create(String, K, V, Headers, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a ConsumerRecord with the given topic name, key, value, headers, and timestamp.
create(String, V) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a ConsumerRecord with null-key and the given topic name and value.
create(String, V, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a ConsumerRecord with null-key and the given topic name, value, and timestamp.
create(String, V, Headers) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a ConsumerRecord with null-key and the given topic name, value, and headers.
create(String, V, Headers, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a ConsumerRecord with null-key and the given topic name, value, headers, and timestamp.
create(List<KeyValue<K, V>>) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Creates consumer records with default topic name as well as given keys and values.
create(List<KeyValue<K, V>>, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Creates consumer records with the given keys and values.
create(List<KeyValue<K, V>>, long, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Creates consumer records with default topic name as well as given keys and values.
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(K, V) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a ConsumerRecord with default topic name and given key and value.
create(K, V, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a ConsumerRecord with default topic name and given key, value, and timestamp.
create(K, V, Headers) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a ConsumerRecord with default topic name and given key, value, and headers.
create(K, V, Headers, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a ConsumerRecord with default topic name and given key, value, headers, and timestamp.
create(StateStoreProvider, String) - Method in interface org.apache.kafka.streams.state.QueryableStoreType
Create an instance of T (usually a facade) that developers can use to query the underlying StateStores.
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(V) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a ConsumerRecord with default topic name and null-key was well as given value.
create(V, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a ConsumerRecord with default topic name and null-key as well as given value and timestamp.
create(V, Headers) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a ConsumerRecord with default topic name and null-key was well as given value and headers.
create(V, Headers, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
Deprecated.
Create a ConsumerRecord with default topic name and null-key as well as given value, headers, and timestamp.
CREATE - org.apache.kafka.common.acl.AclOperation
CREATE operation.
createAcls(Collection<AclBinding>) - Method in interface org.apache.kafka.clients.admin.Admin
This is a convenience method for Admin.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.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
CreateAclsOptions() - Constructor for class org.apache.kafka.clients.admin.CreateAclsOptions
 
CreateAclsResult - Class in org.apache.kafka.clients.admin
The result of the Admin.createAcls(Collection) call.
createClientSslEngine(String, int, String) - Method in interface org.apache.kafka.common.security.auth.SslEngineFactory
Creates a new SSLEngine object to be used by the client.
CREATED - 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.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
createInputTopic(String, Serializer<K>, Serializer<V>) - Method in class org.apache.kafka.streams.TopologyTestDriver
Create TestInputTopic to 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
Create TestInputTopic to 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
Create TestOutputTopic to 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 of newPartitions according 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 of newPartitions according to the corresponding values.
createPartitions(Map<String, NewPartitions>, CreatePartitionsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
CreatePartitionsOptions - Class in org.apache.kafka.clients.admin
CreatePartitionsOptions() - Constructor for class org.apache.kafka.clients.admin.CreatePartitionsOptions
 
CreatePartitionsResult - Class in org.apache.kafka.clients.admin
The result of the Admin.createPartitions(Map) call.
createServerSslEngine(String, int) - Method in interface org.apache.kafka.common.security.auth.SslEngineFactory
Creates a new SSLEngine object 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.KafkaAdminClient
 
CreateTopicsOptions - Class in org.apache.kafka.clients.admin
CreateTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.CreateTopicsOptions
 
CreateTopicsResult - Class in org.apache.kafka.clients.admin
CreateTopicsResult(Map<String, KafkaFuture<CreateTopicsResult.TopicMetadataAndConfig>>) - Constructor for class org.apache.kafka.clients.admin.CreateTopicsResult
 
CreateTopicsResult.TopicMetadataAndConfig - Class in org.apache.kafka.clients.admin
 
credentialInfo() - Method in class org.apache.kafka.clients.admin.UserScramCredentialUpsertion
 
credentialInfos() - Method in class org.apache.kafka.clients.admin.UserScramCredentialsDescription
 
CumulativeCount - Class in org.apache.kafka.common.metrics.stats
A non-sampled version of WindowedCount maintained 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
 
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.

D

data() - Method in class org.apache.kafka.common.config.ConfigData
Returns the data.
data() - Method in class org.apache.kafka.common.config.ConfigTransformerResult
Returns the transformed data, with variables replaced with corresponding values from the ConfigProvider instances if found.
DataException - Exception in org.apache.kafka.connect.errors
Base class for all Kafka Connect data API exceptions.
DataException(String) - Constructor for exception org.apache.kafka.connect.errors.DataException
 
DataException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.DataException
 
DataException(Throwable) - Constructor for exception 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 - org.apache.kafka.common.ConsumerGroupState
 
DEBUG - org.apache.kafka.common.metrics.Sensor.RecordingLevel
 
DEBUG_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
The DEBUG level 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
 
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 - org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
 
DEFAULT_CONFIG - org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
 
DEFAULT_DESERIALIZATION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
default.deserialization.exception.handler
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_FETCH_MAX_BYTES - 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_PATTERN - Static variable in class org.apache.kafka.common.config.ConfigTransformer
 
DEFAULT_PRINCIPAL_BUILDER_CLASS - Static variable in class org.apache.kafka.common.config.SslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release. In recent versions, the config is optional and there is no default.
DEFAULT_PRODUCTION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
default.production.exception.handler
DEFAULT_SASL_ENABLED_MECHANISMS - Static variable in class org.apache.kafka.common.config.SaslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
DEFAULT_SASL_KERBEROS_PRINCIPAL_TO_LOCAL_RULES - Static variable in class org.apache.kafka.common.config.SaslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
DEFAULT_SASL_MECHANISM - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
DEFAULT_SECURITY_PROTOCOL - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
 
DEFAULT_SSL_ENABLED_PROTOCOLS - Static variable in class org.apache.kafka.common.config.SslConfigs
 
DEFAULT_SSL_ENDPOINT_IDENTIFICATION_ALGORITHM - Static variable in class org.apache.kafka.common.config.SslConfigs
 
DEFAULT_SSL_KEYMANGER_ALGORITHM - Static variable in class org.apache.kafka.common.config.SslConfigs
 
DEFAULT_SSL_KEYSTORE_TYPE - Static variable in class org.apache.kafka.common.config.SslConfigs
 
DEFAULT_SSL_PROTOCOL - Static variable in class org.apache.kafka.common.config.SslConfigs
 
DEFAULT_SSL_TRUSTMANAGER_ALGORITHM - Static variable in class org.apache.kafka.common.config.SslConfigs
 
DEFAULT_SSL_TRUSTSTORE_TYPE - Static variable in class org.apache.kafka.common.config.SslConfigs
 
DEFAULT_TIMESTAMP_EXTRACTOR_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
default.timestamp.extractor
DEFAULT_USER - org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
 
DEFAULT_VALUE_SERDE_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
default value.serde
DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS - Static variable in class org.apache.kafka.streams.StreamsConfig
default.windowed.key.serde.inner
DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS - Static variable in class org.apache.kafka.streams.StreamsConfig
default.windowed.value.serde.inner
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.
defaultDeserializationExceptionHandler() - Method in class org.apache.kafka.streams.StreamsConfig
 
defaultKeySerde() - Method in class org.apache.kafka.streams.StreamsConfig
Return an configured instance of key Serde class.
DefaultPartitionGrouper - Class in org.apache.kafka.streams.processor
Deprecated.
since 2.4 release; will be removed in 3.0.0 via KAFKA-7785
DefaultPartitionGrouper() - Constructor for class org.apache.kafka.streams.processor.DefaultPartitionGrouper
Deprecated.
 
DefaultPrincipalBuilder - Class in org.apache.kafka.common.security.auth
Deprecated.
As of Kafka 1.0.0. This will be removed in a future major release.
DefaultPrincipalBuilder() - Constructor for class org.apache.kafka.common.security.auth.DefaultPrincipalBuilder
Deprecated.
 
defaultProductionExceptionHandler() - Method in class org.apache.kafka.streams.StreamsConfig
 
DefaultProductionExceptionHandler - Class in org.apache.kafka.streams.errors
ProductionExceptionHandler that 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
Defines remote topics like "us-west.topic1".
DefaultReplicationPolicy() - Constructor for class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
 
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 an configured instance of value 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, int, ConfigDef.Width, String) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no special validation logic, not dependents and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no special validation logic and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no special validation logic
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, ConfigDef.Recommender) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no special validation logic and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no group, no order in group, no width, no display name, no dependents and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no dependents and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, ConfigDef.Recommender) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no dependents
define(String, ConfigDef.Type, ConfigDef.Importance, String) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no default value and no special validation logic
define(String, ConfigDef.Type, ConfigDef.Importance, String, String, int, ConfigDef.Width, String) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no default value, no special validation logic, no dependents and no custom recommender
define(String, ConfigDef.Type, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no default value, no special validation logic and no custom recommender
define(String, ConfigDef.Type, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no default value and no special validation logic
define(String, ConfigDef.Type, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, ConfigDef.Recommender) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no default value, no special validation logic and no custom recommender
define(ConfigDef.ConfigKey) - Method in class org.apache.kafka.common.config.ConfigDef
 
defineInternal(String, ConfigDef.Type, Object, ConfigDef.Importance) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new internal configuration.
defineInternal(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new internal configuration.
DELEGATION_TOKEN - org.apache.kafka.common.resource.ResourceType
A token ID.
delegationToken() - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenResult
Returns a future which yields a delegation token
DelegationToken - Class in org.apache.kafka.common.security.token.delegation
A class representing a delegation token.
DelegationToken(TokenInformation, byte[]) - Constructor for class org.apache.kafka.common.security.token.delegation.DelegationToken
 
DelegationTokenAuthorizationException - Exception in org.apache.kafka.common.errors
 
DelegationTokenAuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenAuthorizationException
 
DelegationTokenAuthorizationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenAuthorizationException
 
DelegationTokenDisabledException - Exception in org.apache.kafka.common.errors
 
DelegationTokenDisabledException(String) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenDisabledException
 
DelegationTokenDisabledException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenDisabledException
 
DelegationTokenExpiredException - Exception in org.apache.kafka.common.errors
 
DelegationTokenExpiredException(String) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenExpiredException
 
DelegationTokenExpiredException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenExpiredException
 
DelegationTokenNotFoundException - Exception in org.apache.kafka.common.errors
 
DelegationTokenNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenNotFoundException
 
DelegationTokenNotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenNotFoundException
 
DelegationTokenOwnerMismatchException - Exception in org.apache.kafka.common.errors
 
DelegationTokenOwnerMismatchException(String) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenOwnerMismatchException
 
DelegationTokenOwnerMismatchException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.DelegationTokenOwnerMismatchException
 
delegationTokens() - Method in class org.apache.kafka.clients.admin.DescribeDelegationTokenResult
Returns a future which yields list of delegation tokens
delete(K) - Method in interface org.apache.kafka.streams.state.KeyValueStore
Delete the value from the store (if there is one).
DELETE - org.apache.kafka.clients.admin.AlterConfigOp.OpType
Revert the configuration entry to the default value (possibly null).
DELETE - org.apache.kafka.common.acl.AclOperation
DELETE operation.
DELETE_RETENTION_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
DELETE_RETENTION_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
deleteAcls(Collection<AclBindingFilter>) - Method in interface org.apache.kafka.clients.admin.Admin
This is a convenience method for Admin.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.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 the Admin.deleteAcls(Collection) call.
DeleteAclsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteAclsOptions
 
DeleteAclsResult - Class in org.apache.kafka.clients.admin
The result of the Admin.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.KafkaAdminClient
 
DeleteConsumerGroupOffsetsOptions - Class in org.apache.kafka.clients.admin
DeleteConsumerGroupOffsetsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteConsumerGroupOffsetsOptions
 
DeleteConsumerGroupOffsetsResult - Class in org.apache.kafka.clients.admin
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.KafkaAdminClient
 
DeleteConsumerGroupsOptions - Class in org.apache.kafka.clients.admin
DeleteConsumerGroupsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteConsumerGroupsOptions
 
DeleteConsumerGroupsResult - Class in org.apache.kafka.clients.admin
deletedGroups() - Method in class org.apache.kafka.clients.admin.DeleteConsumerGroupsResult
Return a map from group id to futures which can be used to check the status of individual deletions.
DeletedRecords - Class in org.apache.kafka.clients.admin
Represents information about deleted records The API for this class is still evolving and we may break compatibility in minor releases, if necessary.
DeletedRecords(long) - Constructor for class org.apache.kafka.clients.admin.DeletedRecords
Create an instance of this class with the provided parameters.
deleteRecords(Map<TopicPartition, RecordsToDelete>) - Method in 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.KafkaAdminClient
 
DeleteRecordsOptions - Class in org.apache.kafka.clients.admin
DeleteRecordsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteRecordsOptions
 
DeleteRecordsResult - Class in org.apache.kafka.clients.admin
The result of the Admin.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 for Admin.deleteTopics(Collection, DeleteTopicsOptions) with default options.
deleteTopics(Collection<String>, DeleteTopicsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
Delete a batch of topics.
deleteTopics(Collection<String>, DeleteTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
DeleteTopicsOptions - Class in org.apache.kafka.clients.admin
DeleteTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteTopicsOptions
 
DeleteTopicsResult - Class in org.apache.kafka.clients.admin
The result of the Admin.deleteTopics(Collection) call.
DELIVERY_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
delivery.timeout.ms
DENIED - org.apache.kafka.server.authorizer.AuthorizationResult
 
DENY - org.apache.kafka.common.acl.AclPermissionType
Disallows access.
dependents - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
describe() - Method in class org.apache.kafka.streams.Topology
Returns a description of the specified Topology.
DESCRIBE - org.apache.kafka.common.acl.AclOperation
DESCRIBE operation.
DESCRIBE_CONFIGS - org.apache.kafka.common.acl.AclOperation
DESCRIBE_CONFIGS operation.
describeAcls(AclBindingFilter) - Method in interface org.apache.kafka.clients.admin.Admin
This is a convenience method for Admin.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.KafkaAdminClient
 
DescribeAclsOptions - Class in org.apache.kafka.clients.admin
DescribeAclsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeAclsOptions
 
DescribeAclsResult - Class in org.apache.kafka.clients.admin
The result of the Admin.describeAcls(AclBindingFilter) call.
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.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
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.KafkaAdminClient
 
DescribeClusterOptions - Class in org.apache.kafka.clients.admin
DescribeClusterOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeClusterOptions
 
DescribeClusterResult - Class in org.apache.kafka.clients.admin
The result of the Admin.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.KafkaAdminClient
 
DescribeConfigsOptions - Class in org.apache.kafka.clients.admin
DescribeConfigsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeConfigsOptions
 
DescribeConfigsResult - Class in org.apache.kafka.clients.admin
The result of the Admin.describeConfigs(Collection) call.
describeConsumerGroups(Collection<String>) - Method in interface org.apache.kafka.clients.admin.Admin
Describe some group IDs in the cluster, with the default options.
describeConsumerGroups(Collection<String>, DescribeConsumerGroupsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
Describe some group IDs in the cluster.
describeConsumerGroups(Collection<String>, DescribeConsumerGroupsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
DescribeConsumerGroupsOptions - Class in org.apache.kafka.clients.admin
DescribeConsumerGroupsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeConsumerGroupsOptions
 
DescribeConsumerGroupsResult - Class in org.apache.kafka.clients.admin
DescribeConsumerGroupsResult(Map<String, KafkaFuture<ConsumerGroupDescription>>) - Constructor for class org.apache.kafka.clients.admin.DescribeConsumerGroupsResult
 
describeDelegationToken() - Method in 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.KafkaAdminClient
 
DescribeDelegationTokenOptions - Class in org.apache.kafka.clients.admin
DescribeDelegationTokenOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeDelegationTokenOptions
 
DescribeDelegationTokenResult - Class in org.apache.kafka.clients.admin
describedGroups() - Method in class org.apache.kafka.clients.admin.DescribeConsumerGroupsResult
Return a map from group id to futures which yield group descriptions.
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.KafkaAdminClient
 
DescribeFeaturesOptions - Class in org.apache.kafka.clients.admin
DescribeFeaturesOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeFeaturesOptions
 
DescribeFeaturesResult - Class in org.apache.kafka.clients.admin
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.KafkaAdminClient
 
DescribeLogDirsOptions - Class in org.apache.kafka.clients.admin
Options for Admin.describeLogDirs(Collection) The API of this class is evolving, see Admin for details.
DescribeLogDirsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeLogDirsOptions
 
DescribeLogDirsResult - Class in org.apache.kafka.clients.admin
The result of the Admin.describeLogDirs(Collection) call.
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.KafkaAdminClient
 
DescribeReplicaLogDirsOptions - Class in org.apache.kafka.clients.admin
DescribeReplicaLogDirsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeReplicaLogDirsOptions
 
DescribeReplicaLogDirsResult - Class in org.apache.kafka.clients.admin
DescribeReplicaLogDirsResult.ReplicaLogDirInfo - Class in org.apache.kafka.clients.admin
 
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(Collection<String>, DescribeTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
DescribeTopicsOptions - Class in org.apache.kafka.clients.admin
DescribeTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeTopicsOptions
 
DescribeTopicsResult - Class in org.apache.kafka.clients.admin
The result of the Admin.describeTopics(Collection) call.
DescribeTopicsResult(Map<String, KafkaFuture<TopicDescription>>) - Constructor for class org.apache.kafka.clients.admin.DescribeTopicsResult
 
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.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 the Admin.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.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.
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 in org.apache.kafka.streams.errors
Enumeration that describes the response from the exception handler.
deserialize(byte[]) - Method in interface org.apache.kafka.common.security.auth.KafkaPrincipalSerde
Deserialize a KafkaPrincipal from byte array.
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ByteArrayDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ByteBufferDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.BytesDeserializer
 
deserialize(String, byte[]) - Method in interface org.apache.kafka.common.serialization.Deserializer
Deserialize a record value from a byte array into a value or object.
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.DoubleDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ExtendedDeserializer.Wrapper
Deprecated.
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.FloatDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.IntegerDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.LongDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ShortDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.StringDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.UUIDDeserializer
 
deserialize(String, 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, byte[]) - Method in interface org.apache.kafka.common.serialization.ExtendedDeserializer
Deprecated.
Deserialize a record value from a byte array into a value or object.
deserialize(String, Headers, byte[]) - Method in class org.apache.kafka.common.serialization.ExtendedDeserializer.Wrapper
Deprecated.
 
deserializer() - Method in interface org.apache.kafka.common.serialization.Serde
 
deserializer() - Method in class org.apache.kafka.common.serialization.Serdes.WrapperSerde
 
Deserializer<T> - Interface in org.apache.kafka.common.serialization
An interface for converting bytes to objects.
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
 
DirectoryConfigProvider - Class in org.apache.kafka.common.config.provider
An implementation of ConfigProvider based on a directory of files.
DirectoryConfigProvider() - Constructor for class org.apache.kafka.common.config.provider.DirectoryConfigProvider
 
DisconnectException - Exception in org.apache.kafka.common.errors
Server disconnected before a request could be completed.
DisconnectException() - Constructor for exception org.apache.kafka.common.errors.DisconnectException
 
DisconnectException(String) - Constructor for exception org.apache.kafka.common.errors.DisconnectException
 
DisconnectException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.DisconnectException
 
DisconnectException(Throwable) - Constructor for exception org.apache.kafka.common.errors.DisconnectException
 
displayName - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
divergentOffsets() - Method in exception 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
 
Double() - Static method in class org.apache.kafka.common.serialization.Serdes
 
DOUBLE - org.apache.kafka.clients.admin.ConfigEntry.ConfigType
 
DOUBLE - org.apache.kafka.common.config.ConfigDef.Type
 
DoubleDeserializer - Class in org.apache.kafka.common.serialization
 
DoubleDeserializer() - Constructor for class org.apache.kafka.common.serialization.DoubleDeserializer
 
DoubleSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.DoubleSerde
 
DoubleSerializer - Class in org.apache.kafka.common.serialization
 
DoubleSerializer() - Constructor for class org.apache.kafka.common.serialization.DoubleSerializer
 
DOWNSTREAM_OFFSET_KEY - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
 
downstreamOffset() - Method in class org.apache.kafka.connect.mirror.Checkpoint
 
DUMMY_THREAD_INDEX - Static variable in class org.apache.kafka.streams.StreamsConfig
 
duplicate() - Method in class org.apache.kafka.connect.header.ConnectHeaders
 
duplicate() - Method in interface org.apache.kafka.connect.header.Headers
Create a copy of this Headers object.
DuplicateBrokerRegistrationException - Exception in org.apache.kafka.common.errors
 
DuplicateBrokerRegistrationException(String) - Constructor for exception org.apache.kafka.common.errors.DuplicateBrokerRegistrationException
 
DuplicateBrokerRegistrationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.DuplicateBrokerRegistrationException
 
DuplicateResourceException - Exception 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 org.apache.kafka.common.errors.DuplicateResourceException
Constructor
DuplicateResourceException(String, String) - Constructor for exception org.apache.kafka.common.errors.DuplicateResourceException
Constructor
DuplicateResourceException(String, String, Throwable) - Constructor for exception org.apache.kafka.common.errors.DuplicateResourceException
Constructor
DuplicateResourceException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.DuplicateResourceException
 
DuplicateSequenceException - Exception in org.apache.kafka.common.errors
 
DuplicateSequenceException(String) - Constructor for exception org.apache.kafka.common.errors.DuplicateSequenceException
 
DYNAMIC_BROKER_CONFIG - org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
 
DYNAMIC_BROKER_LOGGER_CONFIG - org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
 
DYNAMIC_DEFAULT_BROKER_CONFIG - org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
 
DYNAMIC_TOPIC_CONFIG - org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
 

E

EAGER - 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 - org.apache.kafka.clients.consumer.OffsetResetStrategy
 
EARLIEST - org.apache.kafka.streams.Topology.AutoOffsetReset
 
EarliestSpec() - Constructor for class org.apache.kafka.clients.admin.OffsetSpec.EarliestSpec
 
ElectionNotNeededException - Exception in org.apache.kafka.common.errors
 
ElectionNotNeededException(String) - Constructor for exception org.apache.kafka.common.errors.ElectionNotNeededException
 
ElectionNotNeededException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ElectionNotNeededException
 
ElectionType - Enum 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 given partitions, or for all partitions if the argument to partitions is null.
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 of Admin.electLeaders(ElectionType, Set, ElectLeadersOptions) The API of this class is evolving, see Admin for details.
electPreferredLeaders(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.admin.Admin
Deprecated.
electPreferredLeaders(Collection<TopicPartition>, ElectPreferredLeadersOptions) - Method in interface org.apache.kafka.clients.admin.Admin
ElectPreferredLeadersOptions - Class in org.apache.kafka.clients.admin
ElectPreferredLeadersOptions() - Constructor for class org.apache.kafka.clients.admin.ElectPreferredLeadersOptions
Deprecated.
 
ElectPreferredLeadersResult - Class in org.apache.kafka.clients.admin
EligibleLeadersNotAvailableException - Exception in org.apache.kafka.common.errors
 
EligibleLeadersNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.EligibleLeadersNotAvailableException
 
EligibleLeadersNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.EligibleLeadersNotAvailableException
 
embed(String, String, int, ConfigDef) - Method in class org.apache.kafka.common.config.ConfigDef
 
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.
empty() - Static method in class org.apache.kafka.clients.consumer.ConsumerRecords
 
empty() - Static method in class org.apache.kafka.common.Cluster
Create an empty cluster instance with no nodes and no topic-partitions.
EMPTY - org.apache.kafka.common.ConsumerGroupState
 
EMPTY - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecords
 
ENABLE_AUTO_COMMIT_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
enable.auto.commit
ENABLE_IDEMPOTENCE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
enable.idempotence
ENABLE_IDEMPOTENCE_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
 
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.
endMs - Variable in class org.apache.kafka.streams.kstream.Window
 
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(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 interface org.apache.kafka.server.authorizer.AuthorizerServerInfo
Returns endpoints for all listeners including the advertised host and port to which the listener is bound.
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
Alert the consumer to trigger a new rebalance by rejoining the group.
enforceRebalance() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
ensureExtended(Deserializer<T>) - Static method in class org.apache.kafka.common.serialization.ExtendedDeserializer.Wrapper
Deprecated.
 
ensureExtended(Serializer<T>) - Static method in class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
Deprecated.
 
ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.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.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
 
equals(Object) - Method in class org.apache.kafka.clients.admin.AlterConfigOp
 
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.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.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.RecordsToDelete
 
equals(Object) - Method in class org.apache.kafka.clients.admin.ScramCredentialInfo
 
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.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.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.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.ResourceFilter
 
equals(Object) - Method in class org.apache.kafka.common.resource.ResourcePattern
 
equals(Object) - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
equals(Object) - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
 
equals(Object) - Method in class org.apache.kafka.common.security.auth.SaslExtensions
 
equals(Object) - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
 
equals(Object) - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
equals(Object) - Method in class org.apache.kafka.common.TopicPartition
 
equals(Object) - Method in class org.apache.kafka.common.TopicPartitionInfo
 
equals(Object) - Method in class org.apache.kafka.common.TopicPartitionReplica
 
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.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.server.authorizer.Action
 
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.MockProcessorContext.CapturedForward
 
equals(Object) - Method in class org.apache.kafka.streams.processor.api.Record
 
equals(Object) - Method in class org.apache.kafka.streams.processor.TaskId
 
equals(Object) - Method in class org.apache.kafka.streams.processor.TaskMetadata
 
equals(Object) - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
equals(Object) - Method in class org.apache.kafka.streams.processor.To
 
equals(Object) - Method in class org.apache.kafka.streams.state.HostInfo
 
equals(Object) - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
equals(Object) - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
 
equals(Object) - Method in class org.apache.kafka.streams.StoreQueryParameters
 
equals(Object) - Method in class org.apache.kafka.streams.test.TestRecord
 
errantRecordReporter() - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
Get the reporter to which the sink task can report problematic or failed records passed to the SinkTask.put(java.util.Collection) method.
ErrantRecordReporter - Interface in org.apache.kafka.connect.sink
Component that the sink task can use as it SinkTask.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
error(String, String, String) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
ERROR - org.apache.kafka.streams.KafkaStreams.State
 
ERROR_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
The ERROR level 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.
errorMessages() - Method in class org.apache.kafka.common.config.ConfigValue
 
errorNext(RuntimeException) - Method in class org.apache.kafka.clients.producer.MockProducer
Complete the earliest uncompleted call with the given error.
errorOpenIDConfiguration() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
Return the (potentially null) error openid-configuration value as per RFC 7628: A Set of Simple Authentication and Security Layer (SASL) Mechanisms for OAuth.
errors() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsResult
Returns a future which yields just the errors which occurred.
errorScope() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
errorStatus() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
errorUri() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback
Return the (potentially null) error URI as per RFC 6749: The OAuth 2.0 Authorization Framework.
escape(String) - Static method in class org.apache.kafka.connect.data.Values
 
eventCount - Variable in class org.apache.kafka.common.metrics.stats.SampledStat.Sample
 
eventWindow() - Method in class org.apache.kafka.common.metrics.MetricConfig
 
eventWindow(long) - Method in class org.apache.kafka.common.metrics.MetricConfig
 
EXACTLY_ONCE - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "processing.guarantee" for exactly-once processing guarantees.
EXACTLY_ONCE_BETA - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "processing.guarantee" for exactly-once processing guarantees.
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_CONFIG_ALIAS - 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
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.KafkaAdminClient
 
ExpireDelegationTokenOptions - Class in org.apache.kafka.clients.admin
ExpireDelegationTokenOptions() - Constructor for class org.apache.kafka.clients.admin.ExpireDelegationTokenOptions
 
ExpireDelegationTokenResult - Class in org.apache.kafka.clients.admin
expiryTimePeriodMs() - Method in class org.apache.kafka.clients.admin.ExpireDelegationTokenOptions
 
expiryTimePeriodMs(long) - Method in class org.apache.kafka.clients.admin.ExpireDelegationTokenOptions
 
expiryTimestamp() - Method in class org.apache.kafka.clients.admin.ExpireDelegationTokenResult
Returns a future which yields expiry timestamp
expiryTimestamp() - Method in class org.apache.kafka.clients.admin.RenewDelegationTokenResult
Returns a future which yields expiry timestamp
expiryTimestamp() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
ExtendedDeserializer<T> - Interface in org.apache.kafka.common.serialization
Deprecated.
This class has been deprecated and will be removed in a future release. Please use Deserializer instead.
ExtendedDeserializer.Wrapper<T> - Class in org.apache.kafka.common.serialization
Deprecated.
 
ExtendedSerializer<T> - Interface in org.apache.kafka.common.serialization
Deprecated.
This class has been deprecated and will be removed in a future release. Please use Serializer instead.
ExtendedSerializer.Wrapper<T> - Class in org.apache.kafka.common.serialization
Deprecated.
 
extensions() - Method in class org.apache.kafka.common.security.auth.SaslExtensionsCallback
Returns always non-null SaslExtensions consisting of the extension names and values that are sent by the client to the server in the initial client SASL authentication message.
extensions() - Method in class org.apache.kafka.common.security.scram.ScramExtensionsCallback
Returns map of the extension names and values that are sent by the client to the server in the initial client SCRAM authentication message.
extensions(Map<String, String>) - Method in class org.apache.kafka.common.security.scram.ScramExtensionsCallback
Sets the SCRAM extensions on this callback.
extensions(SaslExtensions) - Method in class org.apache.kafka.common.security.auth.SaslExtensionsCallback
Sets the SASL extensions on this callback.
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 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 - org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
 
FAIL - org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
 
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
 
FATAL_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
The FATAL level 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, boolean) - Constructor for class org.apache.kafka.clients.admin.FeatureUpdate
 
FeatureUpdateFailedException - Exception in org.apache.kafka.common.errors
 
FeatureUpdateFailedException(String) - Constructor for exception org.apache.kafka.common.errors.FeatureUpdateFailedException
 
FeatureUpdateFailedException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.FeatureUpdateFailedException
 
FencedInstanceIdException - Exception in org.apache.kafka.common.errors
 
FencedInstanceIdException(String) - Constructor for exception org.apache.kafka.common.errors.FencedInstanceIdException
 
FencedInstanceIdException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.FencedInstanceIdException
 
FencedLeaderEpochException - Exception in org.apache.kafka.common.errors
The request contained a leader epoch which is smaller than that on the broker that received the request.
FencedLeaderEpochException(String) - Constructor for exception org.apache.kafka.common.errors.FencedLeaderEpochException
 
FencedLeaderEpochException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.FencedLeaderEpochException
 
fenceProducer() - Method in class org.apache.kafka.clients.producer.MockProducer
 
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.ReadOnlyWindowStore
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.ReadOnlyWindowStore
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 - 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.ReadOnlyWindowStore
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
 
fetchSession(K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
Get the value of key from a single session.
FetchSessionIdNotFoundException - Exception in org.apache.kafka.common.errors
 
FetchSessionIdNotFoundException() - Constructor for exception org.apache.kafka.common.errors.FetchSessionIdNotFoundException
 
FetchSessionIdNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.FetchSessionIdNotFoundException
 
field(String) - Method in class org.apache.kafka.connect.data.ConnectSchema
 
field(String) - Method in interface org.apache.kafka.connect.data.Schema
Get a field for 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 this struct schema.
Field - Class in org.apache.kafka.connect.data
A field in a Struct, consisting of a field name, index, and Schema for the field value.
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 of ConfigProvider that represents a Properties file.
FileConfigProvider() - Constructor for class org.apache.kafka.common.config.provider.FileConfigProvider
 
fillInStackTrace() - Method in exception org.apache.kafka.common.errors.ApiException
 
fillInStackTrace() - Method in exception org.apache.kafka.common.errors.SerializationException
 
fillInStackTrace() - Method in exception org.apache.kafka.common.metrics.QuotaViolationException
 
filter(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Create a new KStream that 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 new KTable that consists of all records of this KTable which 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 new KTable that consists of all records of this KTable which satisfy the given predicate, with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
filter(Predicate<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
Create a new KStream that 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 new KTable that consists of all records of this KTable which 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 new KTable that consists of all records of this KTable which satisfy the given predicate, with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
filterNot(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Create a new KStream that 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 new KTable that consists all records of this KTable which 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 new KTable that consists all records of this KTable which do not satisfy the given predicate, with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
filterNot(Predicate<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
Create a new KStream that 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 new KTable that consists all records of this KTable which 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 new KTable that consists all records of this KTable which do not satisfy the given predicate, with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
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.
findIndefiniteField() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
Returns a string describing an ANY or UNKNOWN field, or null if there is no such field.
findIndefiniteField() - Method in class org.apache.kafka.common.acl.AclBindingFilter
Return a string describing an ANY or UNKNOWN field, or null if there is no such field.
findIndefiniteField() - Method in class org.apache.kafka.common.resource.ResourceFilter
Return a string describing an ANY or UNKNOWN field, or null if there is no such field.
findIndefiniteField() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
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, 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.
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 new KStream by 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 new KStream by 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 new KStream by 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 new KStream by transforming the value of each record in this stream into zero or more values with the same key in the new stream.
flatTransform(TransformerSupplier<? super K, ? super V, Iterable<KeyValue<K1, V1>>>, String...) - 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).
flatTransform(TransformerSupplier<? super K, ? super V, Iterable<KeyValue<K1, V1>>>, Named, String...) - 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).
flatTransformValues(ValueTransformerSupplier<? super V, Iterable<VR>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into zero or more new values (with possibly a new type) and emit for each new value a record with the same key of the input record and the value.
flatTransformValues(ValueTransformerSupplier<? super V, Iterable<VR>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into zero or more new values (with possibly a new type) and emit for each new value a record with the same key of the input record and the value.
flatTransformValues(ValueTransformerWithKeySupplier<? super K, ? super V, Iterable<VR>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into zero or more new values (with possibly a new type) and emit for each new value a record with the same key of the input record and the value.
flatTransformValues(ValueTransformerWithKeySupplier<? super K, ? super V, Iterable<VR>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into zero or more new values (with possibly a new type) and emit for each new value a record with the same key of the input record and the value.
Float() - Static method in class org.apache.kafka.common.serialization.Serdes
 
float32() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
 
FLOAT32 - 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 - 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 if linger.ms is greater than 0) and blocks on the completion of the requests associated with these records.
flush() - Method in class org.apache.kafka.clients.producer.MockProducer
 
flush() - Method in interface org.apache.kafka.clients.producer.Producer
flush() - 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 been SinkTask.put(Collection) for the specified topic-partitions.
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
 
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 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 of KStream.
foreach(ForeachAction<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
Perform an action on each record of KStream.
ForeachAction<K,​V> - Interface in org.apache.kafka.streams.kstream
The ForeachAction interface for performing an action on a key-value pair.
forGroupId(String) - Static method in exception org.apache.kafka.common.errors.GroupAuthorizationException
 
forId(byte) - Static method in enum org.apache.kafka.clients.admin.AlterConfigOp.OpType
 
forId(byte) - Static method in enum org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
 
forId(byte) - Static method in enum org.apache.kafka.common.config.ConfigResource.Type
 
forId(byte) - Static method in enum org.apache.kafka.common.IsolationLevel
 
forId(int) - Static method in enum org.apache.kafka.common.metrics.Sensor.RecordingLevel
 
forId(short) - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
 
formatRemoteTopic(String, String) - Method in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
 
formatRemoteTopic(String, String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
How to rename remote topics; generally should be like us-west.topic1.
forName(String) - Static method in enum org.apache.kafka.common.metrics.Sensor.RecordingLevel
Case insensitive lookup by protocol name
forName(String) - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
Case insensitive lookup by protocol name
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
forward(K, V) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
forward(K, V) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Forwards a key/value pair to all downstream processors.
forward(K, V, int) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
Deprecated.
forward(K, V, int) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Deprecated.
forward(K, V, String) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
Deprecated.
forward(K, V, String) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Deprecated.
forward(K, V, To) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
forward(K, V, To) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Forwards a key/value pair to the specified downstream processors.
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
Forwards 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
Forwards 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
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
Get all the forwarded data this context has observed for a specific child by name.
Frequencies - Class in org.apache.kafka.common.metrics.stats
A CompoundStat that represents a normalized distribution with a Frequency metric 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 a Frequencies compound 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
 
fromCode(byte) - Static method in enum org.apache.kafka.common.acl.AclOperation
Return the AclOperation with the provided code or `AclOperation.UNKNOWN` if one cannot be found.
fromCode(byte) - Static method in enum org.apache.kafka.common.acl.AclPermissionType
Return the AclPermissionType with the provided code or `AclPermissionType.UNKNOWN` if one cannot be found.
fromCode(byte) - Static method in enum org.apache.kafka.common.resource.PatternType
Return the PatternType with the provided code or PatternType.UNKNOWN if one cannot be found.
fromCode(byte) - Static method in enum org.apache.kafka.common.resource.ResourceType
Return the ResourceType with the provided code or `ResourceType.UNKNOWN` if one cannot be found.
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
Convert the Header's value into its byte array representation.
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
 
fromLogical(Schema, BigDecimal) - Static method in class org.apache.kafka.connect.data.Decimal
Convert a value from its logical format (BigDecimal) to it's encoded format.
fromLogical(Schema, Date) - Static method in class org.apache.kafka.connect.data.Date
Convert a value from its logical format (Date) to it's encoded format.
fromLogical(Schema, Date) - Static method in class org.apache.kafka.connect.data.Time
Convert a value from its logical format (Time) to it's encoded format.
fromLogical(Schema, Date) - Static method in class org.apache.kafka.connect.data.Timestamp
Convert a value from its logical format (Date) to it's encoded format.
fromMechanismName(String) - Static method in enum org.apache.kafka.clients.admin.ScramMechanism
 
fromNameAndType(String, QueryableStoreType<T>) - Static method in class org.apache.kafka.streams.StoreQueryParameters
 
fromString(String) - Static method in enum org.apache.kafka.common.acl.AclOperation
Parse the given string as an ACL operation.
fromString(String) - Static method in enum org.apache.kafka.common.acl.AclPermissionType
Parse the given string as an ACL permission.
fromString(String) - Static method in enum org.apache.kafka.common.resource.PatternType
Return the PatternType with the provided name or PatternType.UNKNOWN if one cannot be found.
fromString(String) - Static method in enum org.apache.kafka.common.resource.ResourceType
Parse the given string as an ACL resource type.
fromString(String) - Static method in class org.apache.kafka.common.security.auth.KafkaPrincipal
Deprecated.
As of 1.0.0. This method will be removed in a future major release.
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.
fromType(byte) - Static method in enum org.apache.kafka.clients.admin.ScramMechanism
 
Function() - Constructor for class org.apache.kafka.common.KafkaFuture.Function
 

G

Gauge<T> - Interface in org.apache.kafka.common.metrics
A gauge metric is an instantaneous reading of a particular value.
generationId() - Method in class org.apache.kafka.clients.consumer.ConsumerGroupMetadata
 
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
Return a newly constructed Transformer instance.
get() - Method in interface org.apache.kafka.streams.kstream.ValueTransformerSupplier
Return a newly constructed ValueTransformer instance.
get() - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKeySupplier
Return a newly constructed ValueTransformerWithKey instance.
get() - Method in interface org.apache.kafka.streams.processor.api.ProcessorSupplier
Return a newly constructed Processor instance.
get() - Method in interface org.apache.kafka.streams.processor.ProcessorSupplier
Return a newly constructed Processor instance.
get() - Method in interface org.apache.kafka.streams.state.StoreSupplier
Return a new StateStore instance.
get(long, TimeUnit) - Method in class org.apache.kafka.common.KafkaFuture
Waits if necessary for at most the given time for this future to complete, and then returns its result, if available.
get(String) - Method in class org.apache.kafka.clients.admin.Config
Get the configuration entry with the provided name or null if there isn't one.
get(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
get(String) - Method in interface org.apache.kafka.common.config.provider.ConfigProvider
Retrieves the data at the given path.
get(String) - Method in class org.apache.kafka.common.config.provider.DirectoryConfigProvider
Retrieves the data contained in regular files in the directory given by path.
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 by keys in the directory given by path.
get(String, Set<String>) - Method in class org.apache.kafka.common.config.provider.FileConfigProvider
Retrieves the data with the given keys at the given Properties file.
get(K) - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
Get the value corresponding to this key.
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.
getActiveHost() - Method in class org.apache.kafka.streams.KeyQueryMetadata
Deprecated.
getAdmin(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
Create an Admin which is used for internal topic management.
getAdminClient(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
Deprecated.
Not called by Kafka Streams, which now uses KafkaClientSupplier.getAdmin(java.util.Map<java.lang.String, java.lang.Object>) instead.
getAdminConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
Get the configs for the admin client.
getAllStateStores() - Method in class org.apache.kafka.streams.TopologyTestDriver
Get all StateStores from the topology.
getArray(String) - Method in class org.apache.kafka.connect.data.Struct
Equivalent to calling Struct.get(String) and casting the result to a List.
getBoolean(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getBoolean(String) - Method in class org.apache.kafka.connect.data.Struct
Equivalent to calling Struct.get(String) and casting the result to a Boolean.
getBytes(String) - Method in class org.apache.kafka.connect.data.Struct
Equivalent to calling Struct.get(String) and casting the result to a byte[].
getClass(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getConfiguredInstance(String, Class<T>) - Method in class org.apache.kafka.common.config.AbstractConfig
Get a configured instance of the give class specified by the given configuration key.
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.
getConfigValue(ConfigDef.ConfigKey, String) - Method in class org.apache.kafka.common.config.ConfigDef
 
getConsumer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
Create a Consumer which is used to read records of source topics.
getConsumerConfigs(String, String) - Method in class org.apache.kafka.streams.StreamsConfig
getCurrentReplicaLogDir() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
 
getCurrentReplicaOffsetLag() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
 
getDouble(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getFloat32(String) - Method in class org.apache.kafka.connect.data.Struct
Equivalent to calling Struct.get(String) and casting the result to a Float.
getFloat64(String) - Method in class org.apache.kafka.connect.data.Struct
Equivalent to calling Struct.get(String) and casting the result to a Double.
getFutureReplicaLogDir() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
 
getFutureReplicaOffsetLag() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
 
getGlobalConsumer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
Create a Consumer which is used to consume records for GlobalKTable.
getGlobalConsumerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
Get the configs for the global consumer.
getHeaders() - Method in class org.apache.kafka.streams.test.TestRecord
 
getInt(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getInt16(String) - Method in class org.apache.kafka.connect.data.Struct
Equivalent to calling Struct.get(String) and casting the result to a Short.
getInt32(String) - Method in class org.apache.kafka.connect.data.Struct
Equivalent to calling Struct.get(String) and casting the result to a Integer.
getInt64(String) - Method in class org.apache.kafka.connect.data.Struct
Equivalent to calling Struct.get(String) and casting the result to a Long.
getInt8(String) - Method in class org.apache.kafka.connect.data.Struct
Equivalent to calling Struct.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
 
getKey() - Method in class org.apache.kafka.streams.test.TestRecord
 
getKeyValueStore(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
Get the KeyValueStore or TimestampedKeyValueStore with 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
 
getMainConsumerConfigs(String, String, int) - Method in class org.apache.kafka.streams.StreamsConfig
Get the configs to the main consumer.
getMap(String) - Method in class org.apache.kafka.connect.data.Struct
Equivalent to calling Struct.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 org.apache.kafka.connect.data.Schema.Type
 
getName() - Method in enum 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.
getPartition() - Method in class org.apache.kafka.streams.KeyQueryMetadata
Deprecated.
getPassword(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getPrincipalType() - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
 
getProducer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
Create a Producer which is used to write records to sink topics.
getProducerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
Get the configs for the producer.
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
 
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 a Consumer which is used to read records to restore StateStores.
getRestoreConsumerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
Get the configs for the restore-consumer.
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 the SessionStore with the given name.
getShort(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getStandbyHosts() - Method in class org.apache.kafka.streams.KeyQueryMetadata
Deprecated.
getStateStore(String) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
 
getStateStore(String) - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
Get the state store given the store name.
getStateStore(String) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
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 the StateStore with the given name.
getStateStoreContext() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
Used to get a StateStoreContext for use with StateStore.init(StateStoreContext, StateStore) if you need to initialize a store for your tests.
getString(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getString(String) - Method in class org.apache.kafka.connect.data.Struct
Equivalent to calling Struct.get(String) and casting the result to a String.
getStruct(String) - Method in class org.apache.kafka.connect.data.Struct
Equivalent to calling Struct.get(String) and casting the result to a Struct.
getTimestampedKeyValueStore(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
Get the TimestampedKeyValueStore with the given name.
getTimestampedWindowStore(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
Get the TimestampedWindowStore with the given name.
getType() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedPunctuator
 
getType() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedPunctuator
 
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 wrapped value of the given valueAndTimestamp parameter if the parameter is not null.
getWindowSize() - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
 
getWindowStore(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
Get the WindowStore or TimestampedWindowStore with 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 override consumer configs 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 with StreamsConfig.GLOBAL_CONSUMER_PREFIX.
GlobalKTable<K,​V> - Interface in org.apache.kafka.streams.kstream
GlobalKTable is 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 a GlobalKTable for the specified topic.
globalTable(String, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a GlobalKTable for the specified topic.
globalTable(String, Consumed<K, V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a GlobalKTable for the specified topic.
globalTable(String, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a GlobalKTable for the specified topic.
grace(Duration) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Reject out-of-order events that are delayed more than afterWindowEnd after the end of its window.
grace(Duration) - Method in class org.apache.kafka.streams.kstream.SessionWindows
Reject out-of-order events that arrive more than afterWindowEnd after the end of its window.
grace(Duration) - Method in class org.apache.kafka.streams.kstream.TimeWindows
Reject out-of-order events that arrive more than millisAfterWindowEnd after the end of its window.
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 - 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
groupAssignment() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.GroupAssignment
 
GroupAssignment(Map<String, ConsumerPartitionAssignor.Assignment>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.GroupAssignment
 
GroupAuthorizationException - Exception in org.apache.kafka.common.errors
 
GroupAuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.GroupAuthorizationException
 
GroupAuthorizationException(String, String) - Constructor for exception 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 this KStream on a new key that is selected using the provided KeyValueMapper and 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 this KStream on a new key that is selected using the provided KeyValueMapper and Serdes as specified by Grouped.
groupBy(KeyValueMapper<? super K, ? super V, KR>, Serialized<KR, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Deprecated.
groupBy(KeyValueMapper<? super K, ? super V, KeyValue<KR, VR>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Re-groups the records of this KTable using the provided KeyValueMapper and 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 this KTable using the provided KeyValueMapper and Serdes as specified by Grouped.
groupBy(KeyValueMapper<? super K, ? super V, KeyValue<KR, VR>>, Serialized<KR, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Deprecated.
groupByKey() - Method in interface org.apache.kafka.streams.kstream.KStream
Group the records by their current key into a KGroupedStream while 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 a KGroupedStream while preserving the original values and using the serializers as defined by Grouped.
groupByKey(Serialized<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Deprecated.
since 2.1. Use KStream.groupByKey(Grouped) instead
Grouped<K,​V> - Class in org.apache.kafka.streams.kstream
The class that is used to capture the key and value Serdes and set the part of name used for repartition topics when performing KStream.groupBy(KeyValueMapper, Grouped), KStream.groupByKey(Grouped), or KTable.groupBy(KeyValueMapper, Grouped) operations.
Grouped(Grouped<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Grouped
 
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.consumer.ConsumerGroupMetadata
 
groupId() - Method in exception org.apache.kafka.common.errors.GroupAuthorizationException
Return the group ID that failed authorization.
GroupIdNotFoundException - Exception in org.apache.kafka.common.errors
 
GroupIdNotFoundException(String) - Constructor for exception 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
 
GroupMaxSizeReachedException - Exception 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 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 in org.apache.kafka.common.errors
 
GroupNotEmptyException(String) - Constructor for exception 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.
groups() - Method in class org.apache.kafka.common.config.ConfigDef
Get the groups for the configuration
GroupSubscribedToTopicException - Exception in org.apache.kafka.common.errors
 
GroupSubscribedToTopicException(String) - Constructor for exception 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
 
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(ProducerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.DefaultProductionExceptionHandler
 
handle(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 whether or not to continue processing.
handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in interface org.apache.kafka.streams.errors.DeserializationExceptionHandler
Inspect a record and the exception received.
handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndContinueExceptionHandler
 
handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndFailExceptionHandler
 
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.AlterConfigOp
 
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.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.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.RecordsToDelete
 
hashCode() - Method in class org.apache.kafka.clients.admin.ScramCredentialInfo
 
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.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.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.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.ResourceFilter
 
hashCode() - Method in class org.apache.kafka.common.resource.ResourcePattern
 
hashCode() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
hashCode() - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
 
hashCode() - Method in class org.apache.kafka.common.security.auth.SaslExtensions
 
hashCode() - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
 
hashCode() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
hashCode() - Method in class org.apache.kafka.common.TopicPartition
 
hashCode() - Method in class org.apache.kafka.common.TopicPartitionInfo
 
hashCode() - Method in class org.apache.kafka.common.TopicPartitionReplica
 
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.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.server.authorizer.Action
 
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.MockProcessorContext.CapturedForward
 
hashCode() - Method in class org.apache.kafka.streams.processor.api.Record
 
hashCode() - Method in class org.apache.kafka.streams.processor.TaskId
 
hashCode() - Method in class org.apache.kafka.streams.processor.TaskMetadata
 
hashCode() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
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.state.HostInfo
 
hashCode() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
hashCode() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
 
hashCode() - Method in class org.apache.kafka.streams.StoreQueryParameters
 
hashCode() - Method in class org.apache.kafka.streams.test.TestRecord
 
hasMetrics() - Method in class org.apache.kafka.common.metrics.Sensor
Return if metrics were registered with this sensor.
hasNext() - Method in class org.apache.kafka.connect.data.Values.Parser
 
hasOffset() - Method in class org.apache.kafka.clients.producer.RecordMetadata
Indicates whether the record metadata includes the offset.
hasRack() - Method in class org.apache.kafka.common.Node
True if this node has a defined rack
hasTimestamp() - Method in class org.apache.kafka.clients.producer.RecordMetadata
Indicates whether the record metadata includes the timestamp.
Header - Interface in org.apache.kafka.common.header
 
Header - Interface in org.apache.kafka.connect.header
A Header is a key-value pair, and multiple headers can be included with the key, value, and timestamp in each Kafka message.
HEADER - 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
 
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 class org.apache.kafka.common.config.ConfigDef
 
headers() - Method in class org.apache.kafka.connect.connector.ConnectRecord
Get the headers for this 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
 
headers() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the headers of the current input record; could be null if it is not available (for example, if this method is invoked from the punctuate call).
headers() - Method in interface org.apache.kafka.streams.processor.RecordContext
 
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 of Header objects.
Headers.HeaderTransform - Interface in org.apache.kafka.connect.header
A function to transform the supplied Header.
Heartbeat - Class in org.apache.kafka.connect.mirror
Heartbeat message sent from MirrorHeartbeatTask to target cluster.
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
heartbeatTopics() - Method in class org.apache.kafka.connect.mirror.MirrorClient
Find all heartbeat topics on this cluster.
heartbeatTopics(Map<String, Object>) - Static method in class org.apache.kafka.connect.mirror.RemoteClusterUtils
Find all heartbeat topics
HIGH - org.apache.kafka.common.config.ConfigDef.Importance
 
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 to MockProducer.clear()
hmac() - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
 
hmacAsBase64String() - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
 
host() - Method in class org.apache.kafka.clients.admin.MemberDescription
The host where the group member is running.
host() - Method in class org.apache.kafka.common.acl.AccessControlEntry
Return the host or `*` for all hosts.
host() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
Return the host or null.
host() - Method in class org.apache.kafka.common.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 class org.apache.kafka.streams.state.StreamsMetadata
 
hostInfo() - Method in class org.apache.kafka.streams.state.StreamsMetadata
The value of StreamsConfig.APPLICATION_SERVER_CONFIG configured for the streams instance, which is typically host/port
HostInfo - Class in org.apache.kafka.streams.state
Represents a user defined endpoint in a KafkaStreams application.
HostInfo(String, int) - Constructor for class org.apache.kafka.streams.state.HostInfo
 

I

id - Variable in enum org.apache.kafka.common.metrics.Sensor.RecordingLevel
the permanent and immutable id of an API--this can't change ever
id - Variable in enum org.apache.kafka.common.security.auth.SecurityProtocol
The permanent and immutable id of a security protocol -- this can't change, and must match kafka.cluster.SecurityProtocol
id - Variable in enum org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
the permanent and immutable id of an API--this can't change ever
id - Variable in enum org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
the permanent and immutable id of an API--this can't change ever
id - Variable in enum org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
the permanent and immutable id of an API--this can't change ever
id() - Method in enum org.apache.kafka.clients.admin.AlterConfigOp.OpType
 
id() - Method in enum org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
 
id() - Method in enum org.apache.kafka.common.config.ConfigResource.Type
 
id() - Method in enum org.apache.kafka.common.IsolationLevel
 
id() - Method in class org.apache.kafka.common.Node
The node id of this node
id() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
 
id() - Method in interface org.apache.kafka.streams.TopologyDescription.Subtopology
Internally assigned unique ID.
IDEMPOTENT_WRITE - org.apache.kafka.common.acl.AclOperation
IDEMPOTENT_WRITE operation.
idString() - Method in class org.apache.kafka.common.Node
String representation of the node id.
ignore(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
ignoredExtensions() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
 
IllegalGenerationException - Exception in org.apache.kafka.common.errors
 
IllegalGenerationException() - Constructor for exception org.apache.kafka.common.errors.IllegalGenerationException
 
IllegalGenerationException(String) - Constructor for exception org.apache.kafka.common.errors.IllegalGenerationException
 
IllegalGenerationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.IllegalGenerationException
 
IllegalGenerationException(Throwable) - Constructor for exception org.apache.kafka.common.errors.IllegalGenerationException
 
IllegalSaslStateException - Exception in org.apache.kafka.common.errors
This exception indicates unexpected requests prior to SASL authentication.
IllegalSaslStateException(String) - Constructor for exception org.apache.kafka.common.errors.IllegalSaslStateException
 
IllegalSaslStateException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.IllegalSaslStateException
 
IllegalWorkerStateException - Exception 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 org.apache.kafka.connect.errors.IllegalWorkerStateException
 
IllegalWorkerStateException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.IllegalWorkerStateException
 
IllegalWorkerStateException(Throwable) - Constructor for exception org.apache.kafka.connect.errors.IllegalWorkerStateException
 
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
 
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
 
INCLUDE_CONFIG_ALIAS - Static variable in class org.apache.kafka.common.metrics.JmxReporter
 
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.DescribeTopicsOptions
 
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.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.
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 in org.apache.kafka.common.errors
 
InconsistentClusterIdException(String) - Constructor for exception org.apache.kafka.common.errors.InconsistentClusterIdException
 
InconsistentClusterIdException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InconsistentClusterIdException
 
InconsistentGroupProtocolException - Exception in org.apache.kafka.common.errors
 
InconsistentGroupProtocolException(String) - Constructor for exception org.apache.kafka.common.errors.InconsistentGroupProtocolException
 
InconsistentGroupProtocolException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InconsistentGroupProtocolException
 
InconsistentTopicIdException - Exception in org.apache.kafka.common.errors
 
InconsistentTopicIdException(String) - Constructor for exception org.apache.kafka.common.errors.InconsistentTopicIdException
 
InconsistentVoterSetException - Exception in org.apache.kafka.common.errors
 
InconsistentVoterSetException(String) - Constructor for exception org.apache.kafka.common.errors.InconsistentVoterSetException
 
InconsistentVoterSetException(String, Throwable) - Constructor for exception 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 given totalCount.
increaseTo(int, List<List<Integer>>) - Static method in class org.apache.kafka.clients.admin.NewPartitions
Increase the partition count for a topic to the given totalCount assigning the new partitions according to the given newAssignments.
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.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_DOCS - Static variable in class org.apache.kafka.common.config.TopicConfig
 
inferSchema(Object) - Static method in class org.apache.kafka.connect.data.Values
If possible infer a schema for the given value.
INFO - org.apache.kafka.common.metrics.Sensor.RecordingLevel
 
INFO_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
The INFO level designates informational messages that highlight normal Kafka events at a coarse-grained level
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(Properties) - Method in interface org.apache.kafka.common.MessageFormatter
Deprecated.
Use MessageFormatter.configure(Map) instead, this method is for backward compatibility with the older Formatter interface
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
Initialize this transformer.
init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
Initialize this transformer.
init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKey
Initialize this transformer.
init(ProcessorContext) - Method in class org.apache.kafka.streams.processor.AbstractProcessor
 
init(ProcessorContext) - Method in interface org.apache.kafka.streams.processor.Processor
Initialize this processor with the given context.
init(ProcessorContext, StateStore) - Method in interface org.apache.kafka.streams.processor.StateStore
Deprecated.
Since 2.7.0. Callers should invoke StateStore.init(StateStoreContext, StateStore) instead. Implementers may choose to implement this method for backward compatibility or to throw an informative exception instead.
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, 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(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<VA> - Interface in org.apache.kafka.streams.kstream
The Initializer interface for creating an initial value in aggregations.
initialValue - Variable in class org.apache.kafka.common.metrics.stats.SampledStat.Sample
 
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 the transactional.id is set in the configuration.
initTransactions() - Method in class org.apache.kafka.clients.producer.MockProducer
 
initTransactions() - Method in interface org.apache.kafka.clients.producer.Producer
inMemoryKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
Create an in-memory KeyValueBytesStoreSupplier.
inMemorySessionStore(String, Duration) - Static method in class org.apache.kafka.streams.state.Stores
Create an in-memory SessionBytesStoreSupplier.
inMemoryWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
Create an in-memory WindowBytesStoreSupplier.
inputExtensions() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
 
INSTANCE - Static variable in exception org.apache.kafka.common.errors.CoordinatorNotAvailableException
 
INSTANCE - Static variable in exception org.apache.kafka.common.errors.DisconnectException
 
inStates(Set<ConsumerGroupState>) - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsOptions
If states is set, only groups in these states will be returned by listConsumerGroups() Otherwise, all groups are returned.
inSyncReplicas() - Method in class org.apache.kafka.common.PartitionInfo
The subset of the replicas that are in sync, that is caught-up to the leader and ready to take over as leader if the leader should fail
INT - org.apache.kafka.clients.admin.ConfigEntry.ConfigType
 
INT - org.apache.kafka.common.config.ConfigDef.Type
 
int16() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
 
INT16 - org.apache.kafka.connect.data.Schema.Type
16-bit signed integer Note that if you have an unsigned 16-bit data source, Schema.Type.INT32 will be required to safely capture all valid values
INT16_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
 
int32() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
 
INT32 - org.apache.kafka.connect.data.Schema.Type
32-bit signed integer Note that if you have an unsigned 32-bit data source, Schema.Type.INT64 will be required to safely capture all valid values
INT32_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
 
int64() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
 
INT64 - org.apache.kafka.connect.data.Schema.Type
64-bit signed integer Note that if you have an unsigned 64-bit data source, the Decimal logical type (encoded as Schema.Type.BYTES) will be required to safely capture all valid values
INT64_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
 
int8() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
 
INT8 - org.apache.kafka.connect.data.Schema.Type
8-bit signed integer Note that if you have an unsigned 8-bit data source, Schema.Type.INT16 will be required to safely capture all valid values
INT8_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
 
Integer() - Static method in class org.apache.kafka.common.serialization.Serdes
 
IntegerDeserializer - Class in org.apache.kafka.common.serialization
 
IntegerDeserializer() - Constructor for class org.apache.kafka.common.serialization.IntegerDeserializer
 
IntegerSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.IntegerSerde
 
IntegerSerializer - Class in org.apache.kafka.common.serialization
 
IntegerSerializer() - Constructor for class org.apache.kafka.common.serialization.IntegerSerializer
 
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 Type in org.apache.kafka.common.annotation
Compatibility may be broken at minor release (i.e.
InterfaceStability.Stable - Annotation Type in org.apache.kafka.common.annotation
Compatibility is maintained in major, minor and patch releases with one exception: compatibility may be broken in a major release (i.e.
InterfaceStability.Unstable - Annotation Type in org.apache.kafka.common.annotation
No guarantee is provided as to reliability or stability across any level of release granularity.
INTERNAL_TASK_ASSIGNOR_CLASS - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
 
internalConfig - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
InternalConfig() - Constructor for class org.apache.kafka.streams.StreamsConfig.InternalConfig
 
internalTopics() - Method in class org.apache.kafka.common.Cluster
 
InterruptException - Exception in org.apache.kafka.common.errors
An unchecked wrapper for InterruptedException
InterruptException(InterruptedException) - Constructor for exception org.apache.kafka.common.errors.InterruptException
 
InterruptException(String) - Constructor for exception org.apache.kafka.common.errors.InterruptException
 
InterruptException(String, InterruptedException) - Constructor for exception org.apache.kafka.common.errors.InterruptException
 
InvalidCommitOffsetSizeException - Exception in org.apache.kafka.common.errors
 
InvalidCommitOffsetSizeException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidCommitOffsetSizeException
 
InvalidCommitOffsetSizeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidCommitOffsetSizeException
 
InvalidConfigurationException - Exception in org.apache.kafka.common.errors
 
InvalidConfigurationException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidConfigurationException
 
InvalidConfigurationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidConfigurationException
 
invalidExtensions() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
 
InvalidFetchSessionEpochException - Exception in org.apache.kafka.common.errors
 
InvalidFetchSessionEpochException() - Constructor for exception org.apache.kafka.common.errors.InvalidFetchSessionEpochException
 
InvalidFetchSessionEpochException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidFetchSessionEpochException
 
InvalidFetchSizeException - Exception in org.apache.kafka.common.errors
 
InvalidFetchSizeException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidFetchSizeException
 
InvalidFetchSizeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidFetchSizeException
 
InvalidGroupIdException - Exception in org.apache.kafka.common.errors
 
InvalidGroupIdException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidGroupIdException
 
InvalidGroupIdException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidGroupIdException
 
InvalidMetadataException - Exception in org.apache.kafka.common.errors
An exception that may indicate the client's metadata is out of date
InvalidMetadataException() - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
 
InvalidMetadataException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
 
InvalidMetadataException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
 
InvalidMetadataException(Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
 
InvalidOffsetException - Exception in org.apache.kafka.clients.consumer
Thrown when the offset for a set of partitions is invalid (either undefined or out of range), and no reset policy has been configured.
InvalidOffsetException - Exception in org.apache.kafka.common.errors
Thrown when the offset for a set of partitions is invalid (either undefined or out of range), and no reset policy has been configured.
InvalidOffsetException(String) - Constructor for exception org.apache.kafka.clients.consumer.InvalidOffsetException
 
InvalidOffsetException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidOffsetException
 
InvalidOffsetException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidOffsetException
 
InvalidPartitionsException - Exception in org.apache.kafka.common.errors
 
InvalidPartitionsException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidPartitionsException
 
InvalidPartitionsException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidPartitionsException
 
InvalidPidMappingException - Exception in org.apache.kafka.common.errors
 
InvalidPidMappingException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidPidMappingException
 
InvalidPrincipalTypeException - Exception in org.apache.kafka.common.errors
 
InvalidPrincipalTypeException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidPrincipalTypeException
 
InvalidPrincipalTypeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidPrincipalTypeException
 
InvalidProducerEpochException - Exception 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 org.apache.kafka.common.errors.InvalidProducerEpochException
 
InvalidRecordException - Exception in org.apache.kafka.common
 
InvalidRecordException(String) - Constructor for exception org.apache.kafka.common.InvalidRecordException
 
InvalidRecordException(String, Throwable) - Constructor for exception org.apache.kafka.common.InvalidRecordException
 
InvalidReplicaAssignmentException - Exception in org.apache.kafka.common.errors
 
InvalidReplicaAssignmentException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidReplicaAssignmentException
 
InvalidReplicaAssignmentException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidReplicaAssignmentException
 
InvalidReplicationFactorException - Exception in org.apache.kafka.common.errors
 
InvalidReplicationFactorException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidReplicationFactorException
 
InvalidReplicationFactorException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidReplicationFactorException
 
InvalidRequestException - Exception in org.apache.kafka.common.errors
Thrown when a request breaks basic wire protocol rules.
InvalidRequestException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidRequestException
 
InvalidRequestException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidRequestException
 
InvalidRequiredAcksException - Exception in org.apache.kafka.common.errors
 
InvalidRequiredAcksException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidRequiredAcksException
 
InvalidSessionTimeoutException - Exception in org.apache.kafka.common.errors
 
InvalidSessionTimeoutException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidSessionTimeoutException
 
InvalidSessionTimeoutException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidSessionTimeoutException
 
InvalidStateStoreException - Exception in org.apache.kafka.streams.errors
Indicates that there was a problem when trying to access a StateStore.
InvalidStateStoreException(String) - Constructor for exception org.apache.kafka.streams.errors.InvalidStateStoreException
 
InvalidStateStoreException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.InvalidStateStoreException
 
InvalidStateStoreException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.InvalidStateStoreException
 
InvalidStateStorePartitionException - Exception in org.apache.kafka.streams.errors
Indicates that the specific state store being queried via StoreQueryParameters used a partitioning that is not assigned to this instance.
InvalidStateStorePartitionException(String) - Constructor for exception org.apache.kafka.streams.errors.InvalidStateStorePartitionException
 
InvalidStateStorePartitionException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.InvalidStateStorePartitionException
 
InvalidTimestampException - Exception in org.apache.kafka.common.errors
Indicate the timestamp of a record is invalid.
InvalidTimestampException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidTimestampException
 
InvalidTimestampException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidTimestampException
 
InvalidTopicException - Exception in org.apache.kafka.common.errors
The client has attempted to perform an operation on an invalid topic.
InvalidTopicException() - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
InvalidTopicException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
InvalidTopicException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
InvalidTopicException(Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
InvalidTopicException(Set<String>) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
invalidTopics() - Method in class org.apache.kafka.common.Cluster
 
invalidTopics() - Method in exception org.apache.kafka.common.errors.InvalidTopicException
 
InvalidTxnStateException - Exception in org.apache.kafka.common.errors
 
InvalidTxnStateException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidTxnStateException
 
InvalidTxnTimeoutException - Exception in org.apache.kafka.common.errors
The transaction coordinator returns this error code if the timeout received via the InitProducerIdRequest is larger than the `transaction.max.timeout.ms` config value.
InvalidTxnTimeoutException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidTxnTimeoutException
 
InvalidTxnTimeoutException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidTxnTimeoutException
 
InvalidUpdateVersionException - Exception in org.apache.kafka.common.errors
 
InvalidUpdateVersionException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidUpdateVersionException
 
InvalidUpdateVersionException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidUpdateVersionException
 
IP - Static variable in class org.apache.kafka.common.quota.ClientQuotaEntity
 
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.
isComplete(long, MetricConfig) - Method in class org.apache.kafka.common.metrics.stats.SampledStat.Sample
 
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.TestOutputTopic
Verify if the topic queue is empty.
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.
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
Internal topics are never replicated.
isNext(String, boolean) - Method in class org.apache.kafka.connect.data.Values.Parser
 
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 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
 
isPrimitive() - Method in enum 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.
isRunningOrRebalancing() - Method in enum 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 org.apache.kafka.common.config.ConfigDef.Type
 
isSimpleConsumerGroup() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
If consumer group is simple or not.
isSimpleConsumerGroup() - Method in class org.apache.kafka.clients.admin.ConsumerGroupListing
If Consumer Group is simple or not.
isSpecific() - Method in enum org.apache.kafka.common.resource.PatternType
 
issueTimestamp() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
isUnknown() - Method in class org.apache.kafka.common.acl.AccessControlEntry
Return true if this AclResource has any UNKNOWN components.
isUnknown() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
Return true if there are any UNKNOWN components.
isUnknown() - Method in class org.apache.kafka.common.acl.AclBinding
 
isUnknown() - Method in class org.apache.kafka.common.acl.AclBindingFilter
 
isUnknown() - Method in enum org.apache.kafka.common.acl.AclOperation
Return true if this operation is UNKNOWN.
isUnknown() - Method in enum org.apache.kafka.common.acl.AclPermissionType
Return true if this permission type is UNKNOWN.
isUnknown() - Method in enum org.apache.kafka.common.resource.PatternType
 
isUnknown() - Method in class org.apache.kafka.common.resource.Resource
Return true if this Resource has any UNKNOWN components.
isUnknown() - Method in class org.apache.kafka.common.resource.ResourceFilter
Return true if this ResourceFilter has any UNKNOWN components.
isUnknown() - Method in class org.apache.kafka.common.resource.ResourcePattern
 
isUnknown() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
isUnknown() - Method in enum org.apache.kafka.common.resource.ResourceType
Return whether this resource type is UNKNOWN.
isUpperBound() - Method in class org.apache.kafka.common.metrics.Quota
 
isValidEntityType(String) - Static method in class org.apache.kafka.common.quota.ClientQuotaEntity
 
isValidTransition(KafkaStreams.State) - Method in enum 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
 
JmxReporter(String) - Constructor for class org.apache.kafka.common.metrics.JmxReporter
Deprecated.
Since 2.6.0. Use JmxReporter() Initialize JmxReporter with JmxReporter.contextChange(MetricsContext) Populate prefix by adding _namespace/prefix key value pair to MetricsContext
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 with GlobalKTable'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 with GlobalKTable'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 another KStream's records using windowed inner equi join with default serializers and deserializers.
join(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, Joined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
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 another KStream's records using windowed inner equi join using the StreamJoined instance for configuration of the key 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 this KTable with another KTable'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 this KTable with another KTable's records using non-windowed inner equi join, with the Materialized instance for configuration of the key serde, the result table's value serde, and state 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 this KTable with another KTable'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 this KTable with another KTable's records using non-windowed inner equi join, with the Materialized instance for configuration of the key serde, the result table's value serde, and state 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 with KTable'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 with KTable's records using non-windowed inner equi join with default serializers and deserializers.
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable using 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 this KTable with another KTable using non-windowed inner join.
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable using non-windowed inner join.
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable using non-windowed inner join.
Joined<K,​V,​VO> - Class in org.apache.kafka.streams.kstream
The Joined class represents optional params that can be passed to KStream#join(KTable,...) and KStream#leftJoin(KTable,...) operations.
Joined(Joined<K, V, VO>) - Constructor for class org.apache.kafka.streams.kstream.Joined
 
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 of Admin.
KafkaClientSupplier - Interface in org.apache.kafka.streams
KafkaClientSupplier can be used to provide custom Kafka clients to a KafkaStreams instance.
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 value Deserializer.
KafkaConsumer(Properties) - Constructor for class org.apache.kafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a Properties object as configuration.
KafkaConsumer(Properties, Deserializer<K>, Deserializer<V>) - Constructor for class org.apache.kafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a Properties object as configuration, and a key and a value Deserializer.
KafkaException - Exception in org.apache.kafka.common
The base class of all other Kafka exceptions
KafkaException() - Constructor for exception org.apache.kafka.common.KafkaException
 
KafkaException(String) - Constructor for exception org.apache.kafka.common.KafkaException
 
KafkaException(String, Throwable) - Constructor for exception org.apache.kafka.common.KafkaException
 
KafkaException(Throwable) - Constructor for exception org.apache.kafka.common.KafkaException
 
KafkaFuture<T> - Class in org.apache.kafka.common
A flexible future which supports call chaining and other asynchronous programming patterns.
KafkaFuture() - Constructor for class org.apache.kafka.common.KafkaFuture
 
KafkaFuture.BaseFunction<A,​B> - Interface in org.apache.kafka.common
A function which takes objects of type A and returns objects of type B.
KafkaFuture.BiConsumer<A,​B> - Interface in org.apache.kafka.common
A consumer of two different types of object.
KafkaFuture.Function<A,​B> - Class in org.apache.kafka.common
A function which takes objects of type A and returns objects of type B.
KafkaMetric - Class in org.apache.kafka.common.metrics
 
KafkaMetric(Object, MetricName, MetricValueProvider<?>, MetricConfig, Time) - Constructor for class org.apache.kafka.common.metrics.KafkaMetric
 
KafkaMetricsContext - Class in org.apache.kafka.common.metrics
A 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 through SslAuthenticationContext and SASL through SaslAuthenticationContext.
KafkaPrincipalSerde - Interface in org.apache.kafka.common.security.auth
Serializer/Deserializer interface for KafkaPrincipal for the 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 value Serializer.
KafkaProducer(Properties) - Constructor for class org.apache.kafka.clients.producer.KafkaProducer
A producer is instantiated by providing a set of key-value pairs as configuration.
KafkaProducer(Properties, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.KafkaProducer
A producer is instantiated by providing a set of key-value pairs as configuration, a key and a value Serializer.
KafkaStorageException - Exception in org.apache.kafka.common.errors
Miscellaneous disk-related IOException occurred when handling a request.
KafkaStorageException() - Constructor for exception org.apache.kafka.common.errors.KafkaStorageException
 
KafkaStorageException(String) - Constructor for exception org.apache.kafka.common.errors.KafkaStorageException
 
KafkaStorageException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.KafkaStorageException
 
KafkaStorageException(Throwable) - Constructor for exception org.apache.kafka.common.errors.KafkaStorageException
 
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 a KafkaStreams instance.
KafkaStreams(Topology, Properties, Time) - Constructor for class org.apache.kafka.streams.KafkaStreams
Create a KafkaStreams instance.
KafkaStreams(Topology, Properties, KafkaClientSupplier) - Constructor for class org.apache.kafka.streams.KafkaStreams
Create a KafkaStreams instance.
KafkaStreams(Topology, Properties, KafkaClientSupplier, Time) - Constructor for class org.apache.kafka.streams.KafkaStreams
Create a KafkaStreams instance.
KafkaStreams(Topology, StreamsConfig) - Constructor for class org.apache.kafka.streams.KafkaStreams
Deprecated.
KafkaStreams(Topology, StreamsConfig, Time) - Constructor for class org.apache.kafka.streams.KafkaStreams
KafkaStreams(Topology, StreamsConfig, KafkaClientSupplier) - Constructor for class org.apache.kafka.streams.KafkaStreams
KafkaStreams.State - Enum 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 to KafkaStreams.State change events.
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.Record
The key of the record.
key() - Method in class org.apache.kafka.streams.test.TestRecord
 
KEY - org.apache.kafka.connect.storage.ConverterType
 
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
 
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.
KeyQueryMetadata - Class in org.apache.kafka.streams
Represents all the metadata related to a key, where a particular key resides in a KafkaStreams application.
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 - Variable in class org.apache.kafka.streams.kstream.Consumed
 
keySerde - Variable in class org.apache.kafka.streams.kstream.Grouped
 
keySerde - Variable in class org.apache.kafka.streams.kstream.Joined
 
keySerde - Variable in class org.apache.kafka.streams.kstream.Materialized
 
keySerde - Variable in class org.apache.kafka.streams.kstream.Produced
 
keySerde - Variable in class org.apache.kafka.streams.kstream.Repartitioned
 
keySerde - Variable in class org.apache.kafka.streams.kstream.Serialized
Deprecated.
 
keySerde - Variable in class org.apache.kafka.streams.kstream.StreamJoined
 
keySerde() - Method in class org.apache.kafka.streams.kstream.Joined
 
keySerde() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
 
keySerde() - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
Returns the default key serde.
keySerde() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
keySerde() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns 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 a Grouped instance with the provided keySerde.
keySerde(Serde<K>) - Static method in class org.apache.kafka.streams.kstream.Joined
Create an instance of Joined with a key Serde.
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
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 more KeyValueStore<Bytes, byte[]> instances of type <Bytes, byte[]>.
KeyValueIterator<K,​V> - Interface in org.apache.kafka.streams.state
Iterator interface of KeyValue.
KeyValueMapper<K,​V,​VR> - Interface in org.apache.kafka.streams.kstream
The KeyValueMapper interface for mapping a key-value pair to a new value of arbitrary type.
keyValueStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
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 a StoreBuilder that can be used to build a KeyValueStore.
KGroupedStream<K,​V> - Interface in org.apache.kafka.streams.kstream
KGroupedStream is an abstraction of a grouped record stream of KeyValue pairs.
KGroupedTable<K,​V> - Interface in org.apache.kafka.streams.kstream
KGroupedTable is 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
KStream is an abstraction of a record stream of KeyValue pairs, i.e., each record is an independent entity/event in the real world.
KTable<K,​V> - Interface in org.apache.kafka.streams.kstream
KTable is an abstraction of a changelog stream from a primary-keyed table.

L

label - Variable in class org.apache.kafka.streams.kstream.Printed
 
LagInfo - Class in org.apache.kafka.streams
Encapsulates information about lag, at a store partition replica (active or standby).
lastHeader(String) - Method in interface org.apache.kafka.common.header.Headers
Returns just one (the very last) header for the given key, if present.
lastPollTimeout() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
lastWindowMs - Variable in class org.apache.kafka.common.metrics.stats.SampledStat.Sample
 
lastWithName(String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
 
lastWithName(String) - Method in interface org.apache.kafka.connect.header.Headers
Return the last Header with the specified key.
latest() - Static method in class org.apache.kafka.clients.admin.OffsetSpec
Used to retrieve the latest offset of a partition
LATEST - org.apache.kafka.clients.consumer.OffsetResetStrategy
 
LATEST - org.apache.kafka.streams.Topology.AutoOffsetReset
 
LatestSpec() - Constructor for class org.apache.kafka.clients.admin.OffsetSpec.LatestSpec
 
leader() - Method in class org.apache.kafka.common.PartitionInfo
The node id of the node currently acting as a leader for this partition or null if there is no leader
leader() - Method in class org.apache.kafka.common.TopicPartitionInfo
Return the leader of the partition or null if there is none.
leaderEpoch() - Method in class org.apache.kafka.clients.admin.ListOffsetsResult.ListOffsetsResultInfo
 
leaderEpoch() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
Get the leader epoch for the record if available
leaderEpoch() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
Get the leader epoch of the previously consumed record (if one is known).
leaderEpoch() - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
Get the leader epoch corresponding to the offset that was found (if one exists).
leaderFor(TopicPartition) - Method in class org.apache.kafka.common.Cluster
Get the current leader for the given topic-partition
LeaderNotAvailableException - Exception in org.apache.kafka.common.errors
There is no currently available leader for the given partition (either because a leadership election is in progress or because all replicas are down).
LeaderNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.LeaderNotAvailableException
 
LeaderNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.LeaderNotAvailableException
 
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 with GlobalKTable'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 with GlobalKTable'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 another KStream's records using windowed left equi join with default serializers and deserializers.
leftJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, Joined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
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 another KStream's records using windowed left equi join using the StreamJoined instance for configuration of the key 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 this KTable (left input) with another KTable'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 this KTable (left input) with another KTable's (right input) records using non-windowed left equi join, with the Materialized instance for configuration of the key serde, the result table's value serde, and state 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 this KTable (left input) with another KTable'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 this KTable (left input) with another KTable's (right input) records using non-windowed left equi join, with the Materialized instance for configuration of the key serde, the result table's value serde, and state 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 with KTable'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 with KTable's records using non-windowed left equi join with default serializers and deserializers.
leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable using 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 this KTable with another KTable using non-windowed left join.
leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable using non-windowed left join.
leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable using non-windowed left 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 - 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 - org.apache.kafka.clients.admin.ConfigEntry.ConfigType
 
LIST - org.apache.kafka.common.config.ConfigDef.Type
 
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(String, ListConsumerGroupOffsetsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
 
ListConsumerGroupOffsetsOptions - Class in org.apache.kafka.clients.admin
ListConsumerGroupOffsetsOptions() - Constructor for class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsOptions
 
ListConsumerGroupOffsetsResult - Class in org.apache.kafka.clients.admin
listConsumerGroups() - Method in 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.KafkaAdminClient
 
ListConsumerGroupsOptions - Class in org.apache.kafka.clients.admin
ListConsumerGroupsOptions() - Constructor for class org.apache.kafka.clients.admin.ListConsumerGroupsOptions
 
ListConsumerGroupsResult - Class in org.apache.kafka.clients.admin
The result of the Admin.listConsumerGroups() call.
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 in org.apache.kafka.common.errors
The leader does not have an endpoint corresponding to the listener on which metadata was requested.
ListenerNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.ListenerNotFoundException
 
ListenerNotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ListenerNotFoundException
 
listings() - Method in class org.apache.kafka.clients.admin.ListTopicsResult
Return a future which yields a collection of TopicListing objects.
listInternal(boolean) - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
Set whether we should list internal topics.
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.KafkaAdminClient
 
ListOffsetsOptions - Class in org.apache.kafka.clients.admin
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 the Admin.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 for Admin.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.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 for Admin.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
Options for Admin.listPartitionReassignments(ListPartitionReassignmentsOptions) The API of this class is evolving.
ListPartitionReassignmentsOptions() - Constructor for class org.apache.kafka.clients.admin.ListPartitionReassignmentsOptions
 
ListPartitionReassignmentsResult - Class in org.apache.kafka.clients.admin
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.KafkaAdminClient
 
ListTopicsOptions - Class in org.apache.kafka.clients.admin
Options for Admin.listTopics().
ListTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.ListTopicsOptions
 
ListTopicsResult - Class in org.apache.kafka.clients.admin
The result of the Admin.listTopics() call.
LITERAL - org.apache.kafka.common.resource.PatternType
A literal resource name.
localThreadsMetadata() - Method in class org.apache.kafka.streams.KafkaStreams
Returns runtime information about the local threads of this KafkaStreams instance.
LockException - Exception 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 org.apache.kafka.streams.errors.LockException
 
LockException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.LockException
 
LockException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.LockException
 
LOG - Static variable in interface org.apache.kafka.streams.state.RocksDBConfigSetter
 
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
 
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
 
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 the StateStore.
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
 
LogDirNotFoundException - Exception in org.apache.kafka.common.errors
Thrown when a request is made for a log directory that is not present on the broker
LogDirNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.LogDirNotFoundException
 
LogDirNotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.LogDirNotFoundException
 
LogDirNotFoundException(Throwable) - Constructor for exception org.apache.kafka.common.errors.LogDirNotFoundException
 
loggingEnabled - Variable in class org.apache.kafka.streams.kstream.Materialized
 
loggingEnabled - Variable in class org.apache.kafka.streams.kstream.StreamJoined
 
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
 
LogTruncationException - Exception 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 org.apache.kafka.clients.consumer.LogTruncationException
 
logUnused() - Method in class org.apache.kafka.common.config.AbstractConfig
Log warnings for any unused configurations
Long() - Static method in class org.apache.kafka.common.serialization.Serdes
 
LONG - org.apache.kafka.clients.admin.ConfigEntry.ConfigType
 
LONG - org.apache.kafka.common.config.ConfigDef.Type
 
LONG - org.apache.kafka.common.config.ConfigDef.Width
 
LongDeserializer - Class in org.apache.kafka.common.serialization
 
LongDeserializer() - Constructor for class org.apache.kafka.common.serialization.LongDeserializer
 
LongSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.LongSerde
 
LongSerializer - Class in org.apache.kafka.common.serialization
 
LongSerializer() - Constructor for class org.apache.kafka.common.serialization.LongSerializer
 
LOW - org.apache.kafka.common.config.ConfigDef.Importance
 
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 Map KeyValueBytesStoreSupplier.

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 override consumer configs 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 with StreamsConfig.MAIN_CONSUMER_PREFIX.
maintainMs() - Method in class org.apache.kafka.streams.kstream.JoinWindows
Deprecated.
since 2.1. This function should not be used anymore, since JoinWindows.until(long) is deprecated in favor of JoinWindows.grace(Duration).
maintainMs() - Method in class org.apache.kafka.streams.kstream.SessionWindows
Deprecated.
since 2.1. Use Materialized.retention instead.
maintainMs() - Method in class org.apache.kafka.streams.kstream.TimeWindows
Deprecated.
since 2.1. Use Materialized.retention instead.
maintainMs() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
Deprecated.
since 2.1. Use Materialized.retention instead.
maintainMs() - Method in class org.apache.kafka.streams.kstream.Windows
Deprecated.
since 2.1. Use Materialized.retention instead.
make(V, long) - Static method in class org.apache.kafka.streams.state.ValueAndTimestamp
Create a new ValueAndTimestamp instance if the provide value is not null.
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 - org.apache.kafka.connect.data.Schema.Type
A mapping from keys to values.
mapper - Variable in class org.apache.kafka.streams.kstream.Printed
 
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 new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type) in the new KTable, 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 new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type) in the new KTable, with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
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 new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type) in the new KTable, 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 new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type) in the new KTable, with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
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 new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type) in the new KTable, 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 new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type) in the new KTable, with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
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 new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type) in the new KTable, 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 new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type) in the new KTable, with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
mark() - Method in class org.apache.kafka.connect.data.Values.Parser
 
match() - Method in class org.apache.kafka.common.quota.ClientQuotaFilterComponent
 
MATCH - org.apache.kafka.common.resource.PatternType
In a filter, will perform pattern matching.
matches(AccessControlEntry) - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
Returns true if this filter matches the given AccessControlEntry.
matches(AclBinding) - Method in class org.apache.kafka.common.acl.AclBindingFilter
Return true if the resource filter matches the binding's resource and the entry filter matches binding's entry.
matches(Resource) - Method in class org.apache.kafka.common.resource.ResourceFilter
Return true if this filter matches the given Resource.
matches(ResourcePattern) - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
matchesAtMostOne() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
Returns true if this filter could only match one ACE -- in other words, if there are no ANY or UNKNOWN fields.
matchesAtMostOne() - Method in class org.apache.kafka.common.acl.AclBindingFilter
Return true if the resource and entry filters can only match one ACE.
matchesAtMostOne() - Method in class org.apache.kafka.common.resource.ResourceFilter
Return true if this filter could only match one ACE.
matchesAtMostOne() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
Materialized<K,​V,​S extends StateStore> - Class in org.apache.kafka.streams.kstream
Used to describe how a StateStore should be materialized.
Materialized(Materialized<K, V, S>) - Constructor for class org.apache.kafka.streams.kstream.Materialized
Copy constructor.
Max - Class in org.apache.kafka.common.metrics.stats
A SampledStat that 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_RECORDING_LEVEL_KEY - Static variable in enum 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_WARMUP_REPLICAS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
max.warmup.replicas
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
 
maxlifeTimeMs(long) - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
 
maxNumPartitions(Cluster, Set<String>) - Method in class org.apache.kafka.streams.processor.DefaultPartitionGrouper
Deprecated.
 
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.
maxTimestamp() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
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
 
measurable() - Method in class org.apache.kafka.common.metrics.KafkaMetric
 
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 a Stat that is also Measurable (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 org.apache.kafka.clients.admin.ScramMechanism
 
MEDIUM - org.apache.kafka.common.config.ConfigDef.Importance
 
MEDIUM - org.apache.kafka.common.config.ConfigDef.Width
 
MemberAssignment - Class in org.apache.kafka.clients.admin
A description of the assignments of a specific group member.
MemberAssignment(Set<TopicPartition>) - Constructor for class org.apache.kafka.clients.admin.MemberAssignment
Creates an instance with the specified parameters.
memberData(ConsumerPartitionAssignor.Subscription) - Method in class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
 
memberData(ConsumerPartitionAssignor.Subscription) - Method in class org.apache.kafka.clients.consumer.StickyAssignor
 
MemberDescription - Class in org.apache.kafka.clients.admin
A detailed description of a single group instance in the cluster.
MemberDescription(String, String, String, MemberAssignment) - Constructor for class org.apache.kafka.clients.admin.MemberDescription
 
MemberDescription(String, Optional<String>, String, String, MemberAssignment) - Constructor for class org.apache.kafka.clients.admin.MemberDescription
 
memberId() - Method in class org.apache.kafka.clients.consumer.ConsumerGroupMetadata
 
MemberIdRequiredException - Exception in org.apache.kafka.common.errors
 
MemberIdRequiredException(String) - Constructor for exception org.apache.kafka.common.errors.MemberIdRequiredException
 
MemberIdRequiredException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.MemberIdRequiredException
 
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.ConsumerGroupDescription
A list of the members of the consumer group.
members() - Method in class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupOptions
 
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.
Merger<K,​V> - Interface in org.apache.kafka.streams.kstream
The interface for merging aggregate values for SessionWindows with the given key.
MESSAGE_DOWNCONVERSION_ENABLE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MESSAGE_DOWNCONVERSION_ENABLE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MESSAGE_FORMAT_VERSION_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MESSAGE_FORMAT_VERSION_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MESSAGE_TIMESTAMP_DIFFERENCE_MAX_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MESSAGE_TIMESTAMP_DIFFERENCE_MAX_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MESSAGE_TIMESTAMP_TYPE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
 
MESSAGE_TIMESTAMP_TYPE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
 
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
metadataForKey(String, K, Serializer<K>) - Method in class org.apache.kafka.streams.KafkaStreams
metadataForKey(String, K, StreamPartitioner<? super K, ?>) - Method in class org.apache.kafka.streams.KafkaStreams
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 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
 
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
The MetricName class encapsulates a metric's name, logical group and its related attributes.
MetricName(String, String, String, Map<String, String>) - Constructor for class org.apache.kafka.common.MetricName
Please create MetricName by method Metrics.metricName(String, String, String, Map)
MetricNameTemplate - Class in org.apache.kafka.common
A template for a MetricName.
MetricNameTemplate(String, String, String, String...) - Constructor for class org.apache.kafka.common.MetricNameTemplate
Create a new template.
MetricNameTemplate(String, String, String, Set<String>) - Constructor for class org.apache.kafka.common.MetricNameTemplate
Create a new template.
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.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.MockConsumer
 
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.ProcessorContext
Returns Metrics instance.
metrics() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
metrics() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns 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_0100_TO_24 - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "built.in.metrics.version" for built-in metrics from version 0.10.0.
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 a MetricsReporter The contextLabels map provides following information: - a _namespace field indicating the component exposing metrics e.g.
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
 
MetricValueProvider<T> - Interface in org.apache.kafka.common.metrics
Super-interface for Measurable or Gauge that provides metric values.
Min - Class in org.apache.kafka.common.metrics.stats
A SampledStat that 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
Interprets MM2's 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 for MirrorClient to talk to a given target cluster.
MissingSourceTopicException - Exception in org.apache.kafka.streams.errors
 
MissingSourceTopicException(String) - Constructor for exception org.apache.kafka.streams.errors.MissingSourceTopicException
 
MockConsumer<K,​V> - Class in org.apache.kafka.clients.consumer
A mock of the Consumer interface you can use for testing code that uses Kafka.
MockConsumer(OffsetResetStrategy) - Constructor for class org.apache.kafka.clients.consumer.MockConsumer
 
MockProcessorContext<KForward,​VForward> - Class in org.apache.kafka.streams.processor.api
MockProcessorContext is a mock of ProcessorContext for users to test their Processor, Transformer, and ValueTransformer implementations.
MockProcessorContext - Class in org.apache.kafka.streams.processor
MockProcessorContext is a mock of ProcessorContext for users to test their Processor, Transformer, and ValueTransformer implementations.
MockProcessorContext() - Constructor for class org.apache.kafka.streams.processor.api.MockProcessorContext
Create a MockProcessorContext with dummy config and taskId and null stateDir.
MockProcessorContext() - Constructor for class org.apache.kafka.streams.processor.MockProcessorContext
Create a MockProcessorContext with dummy config and taskId and null stateDir.
MockProcessorContext(Properties) - Constructor for class org.apache.kafka.streams.processor.api.MockProcessorContext
Create a MockProcessorContext with dummy taskId and null stateDir.
MockProcessorContext(Properties) - Constructor for class org.apache.kafka.streams.processor.MockProcessorContext
Create a MockProcessorContext with dummy taskId and null stateDir.
MockProcessorContext(Properties, TaskId, File) - Constructor for class org.apache.kafka.streams.processor.api.MockProcessorContext
Create a MockProcessorContext with a specified taskId and null stateDir.
MockProcessorContext(Properties, TaskId, File) - Constructor for class org.apache.kafka.streams.processor.MockProcessorContext
Create a MockProcessorContext with 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
 
MockProcessorContext.CapturedPunctuator - Class in org.apache.kafka.streams.processor.api
MockProcessorContext.CapturedPunctuator holds captured punctuators, along with their scheduling information.
MockProcessorContext.CapturedPunctuator - Class in org.apache.kafka.streams.processor
MockProcessorContext.CapturedPunctuator holds 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(boolean, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.MockProducer
Create a new mock producer with invented metadata the given autoComplete setting and key\value serializers.
MockProducer(Cluster, boolean, Partitioner, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.MockProducer
Create a mock producer

N

name - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
 
name - Variable in enum org.apache.kafka.common.metrics.Sensor.RecordingLevel
an english description of the api--this is for debugging and can change
name - Variable in enum org.apache.kafka.common.security.auth.SecurityProtocol
Name of the security protocol.
name - Variable in enum org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
an english description of the api--this is for debugging and can change
name - Variable in enum org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
an english description of the api--this is for debugging and can change
name - Variable in enum org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
an english description of the api--this is for debugging and can change
name - Variable in class org.apache.kafka.streams.kstream.Branched
 
name - Variable in class org.apache.kafka.streams.kstream.Grouped
 
name - Variable in class org.apache.kafka.streams.kstream.Joined
 
name - Variable in class org.apache.kafka.streams.kstream.Named
 
name - Variable in class org.apache.kafka.streams.kstream.Repartitioned
 
name - Variable in class org.apache.kafka.streams.kstream.StreamJoined
 
name() - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
Returns the name of this configuration.
name() - Method in class org.apache.kafka.clients.admin.ConfigEntry
Return the config name.
name() - Method in class org.apache.kafka.clients.admin.NewTopic
The name of the topic to be created.
name() - Method in class org.apache.kafka.clients.admin.TopicDescription
The name of the topic.
name() - Method in class org.apache.kafka.clients.admin.TopicListing
The name of the topic.
name() - Method in class org.apache.kafka.clients.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.ResourceFilter
Return the resource name or null.
name() - Method in class org.apache.kafka.common.resource.ResourcePattern
 
name() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
name() - Method in 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.server.quota.ClientQuotaEntity.ConfigEntity
Returns the name of this entity.
name() - Method in class org.apache.kafka.streams.kstream.Joined
Deprecated.
this method will be removed in a in a future release
name() - Method in interface org.apache.kafka.streams.processor.StateStore
The name of this store.
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.
named(String) - Static method in class org.apache.kafka.streams.kstream.Joined
Deprecated.
use Joined.as(String) instead
Named - Class in org.apache.kafka.streams.kstream
 
Named(String) - Constructor for class org.apache.kafka.streams.kstream.Named
 
Named(Named) - Constructor for class org.apache.kafka.streams.kstream.Named
 
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 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 in org.apache.kafka.common.errors
A misc.
NetworkException() - Constructor for exception org.apache.kafka.common.errors.NetworkException
 
NetworkException(String) - Constructor for exception org.apache.kafka.common.errors.NetworkException
 
NetworkException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NetworkException
 
NetworkException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NetworkException
 
newConfigDef() - Static method in class org.apache.kafka.connect.storage.ConverterConfig
Create a new ConfigDef instance containing the configurations defined by ConverterConfig.
NewPartitionReassignment - Class in org.apache.kafka.clients.admin
A new partition reassignment, which can be applied via Admin.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 to Admin.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
 
newSample(long) - Method in class org.apache.kafka.common.metrics.stats.Frequencies
 
newSample(long) - Method in class org.apache.kafka.common.metrics.stats.Percentiles
 
newSample(long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
 
NewTopic - Class in org.apache.kafka.clients.admin
A new topic to be created via Admin.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 defaults numPartitions and replicationFactor to the broker configurations for num.partitions and default.replication.factor respectively.
next() - Method in class org.apache.kafka.connect.data.Values.Parser
 
next(int) - Method in class org.apache.kafka.connect.data.Values.Parser
 
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_SASL_EXTENSIONS - Static variable in class org.apache.kafka.common.security.auth.SaslExtensions
An "empty" instance indicating no SASL extensions
NO_TIMESTAMP - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecord
 
Node - Class in org.apache.kafka.common
Information about a Kafka node
Node(int, String, int) - Constructor for class org.apache.kafka.common.Node
 
Node(int, String, int, String) - Constructor for class org.apache.kafka.common.Node
 
nodeById(int) - Method in class org.apache.kafka.common.Cluster
Get the node by the node id (or null if 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.
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.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 - org.apache.kafka.clients.consumer.OffsetResetStrategy
 
NONE - org.apache.kafka.common.config.ConfigDef.Width
 
NONE - org.apache.kafka.common.config.SslClientAuth
 
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 in org.apache.kafka.clients.consumer
Indicates that there is no stored offset for a partition and no defined offset reset policy.
NoOffsetForPartitionException(Collection<TopicPartition>) - Constructor for exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
 
NoOffsetForPartitionException(TopicPartition) - Constructor for exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
 
NoReassignmentInProgressException - Exception in org.apache.kafka.common.errors
Thrown if a reassignment cannot be cancelled because none is in progress.
NoReassignmentInProgressException(String) - Constructor for exception org.apache.kafka.common.errors.NoReassignmentInProgressException
 
NoReassignmentInProgressException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NoReassignmentInProgressException
 
NOT_AVAILABLE - Static variable in class org.apache.kafka.streams.KeyQueryMetadata
Sentinel to indicate that the KeyQueryMetadata is currently unavailable.
NOT_AVAILABLE - Static variable in class org.apache.kafka.streams.state.StreamsMetadata
Sentinel to indicate that the StreamsMetadata is currently unavailable.
NOT_RUNNING - org.apache.kafka.streams.KafkaStreams.State
 
NotControllerException - Exception in org.apache.kafka.common.errors
 
NotControllerException(String) - Constructor for exception org.apache.kafka.common.errors.NotControllerException
 
NotControllerException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotControllerException
 
NotCoordinatorException - Exception in org.apache.kafka.common.errors
In the context of the group coordinator, the broker returns this error code if it receives an offset fetch or commit request for a group it's not the coordinator of.
NotCoordinatorException(String) - Constructor for exception org.apache.kafka.common.errors.NotCoordinatorException
 
NotCoordinatorException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotCoordinatorException
 
NotEnoughReplicasAfterAppendException - Exception in org.apache.kafka.common.errors
Number of insync replicas for the partition is lower than min.insync.replicas This exception is raised when the low ISR size is discovered *after* the message was already appended to the log.
NotEnoughReplicasAfterAppendException(String) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasAfterAppendException
 
NotEnoughReplicasException - Exception in org.apache.kafka.common.errors
Number of insync replicas for the partition is lower than min.insync.replicas
NotEnoughReplicasException() - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
 
NotEnoughReplicasException(String) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
 
NotEnoughReplicasException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
 
NotEnoughReplicasException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
 
NotFoundException - Exception 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 org.apache.kafka.connect.errors.NotFoundException
 
NotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.NotFoundException
 
NotFoundException(Throwable) - Constructor for exception org.apache.kafka.connect.errors.NotFoundException
 
NotLeaderForPartitionException - Exception in org.apache.kafka.common.errors
Deprecated.
NotLeaderForPartitionException() - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
Deprecated.
 
NotLeaderForPartitionException(String) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
Deprecated.
 
NotLeaderForPartitionException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
Deprecated.
 
NotLeaderForPartitionException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
Deprecated.
 
NotLeaderOrFollowerException - Exception 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 org.apache.kafka.common.errors.NotLeaderOrFollowerException
 
NotLeaderOrFollowerException(String) - Constructor for exception org.apache.kafka.common.errors.NotLeaderOrFollowerException
 
NotLeaderOrFollowerException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotLeaderOrFollowerException
 
NotLeaderOrFollowerException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NotLeaderOrFollowerException
 
NULL - Static variable in class org.apache.kafka.connect.data.SchemaAndValue
 
NULL_CHECKSUM - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecord
 
NULL_SIZE - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecord
 
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 - Variable in class org.apache.kafka.streams.kstream.Repartitioned
 
numberOfPartitions(int) - Static method in class org.apache.kafka.streams.kstream.Repartitioned
Create a Repartitioned instance 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.

O

OAUTHBEARER_MECHANISM - Static variable in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
The SASL Mechanism name for OAuth 2: OAUTHBEARER
OAuthBearerExtensionsValidatorCallback - Class in org.apache.kafka.common.security.oauthbearer
A Callback for use by the SaslServer implementation when it needs to validate the SASL extensions for the OAUTHBEARER mechanism Callback handlers should use the OAuthBearerExtensionsValidatorCallback.valid(String) method to communicate valid extensions back to the SASL server.
OAuthBearerExtensionsValidatorCallback(OAuthBearerToken, SaslExtensions) - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
 
OAuthBearerLoginModule - Class in org.apache.kafka.common.security.oauthbearer
The LoginModule for the SASL/OAUTHBEARER mechanism.
OAuthBearerLoginModule() - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
 
OAuthBearerToken - Interface in org.apache.kafka.common.security.oauthbearer
The b64token value as defined in RFC 6750 Section 2.1 along with the token's specific scope and lifetime and principal name.
OAuthBearerTokenCallback - Class in org.apache.kafka.common.security.oauthbearer
A Callback for use by the SaslClient and Login implementations when they require an OAuth 2 bearer token.
OAuthBearerTokenCallback() - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback
 
OAuthBearerValidatorCallback - Class in org.apache.kafka.common.security.oauthbearer
A Callback for use by the SaslServer implementation when it needs to provide an OAuth 2 bearer token compact serialization for validation.
OAuthBearerValidatorCallback(String) - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
Constructor
of() - Static method in class org.apache.kafka.streams.kstream.UnlimitedWindows
Return an unlimited window starting at timestamp zero.
of(long) - Static method in class org.apache.kafka.streams.kstream.JoinWindows
Deprecated.
of(long) - Static method in class org.apache.kafka.streams.kstream.TimeWindows
Deprecated.
of(Duration) - Static method in class org.apache.kafka.streams.kstream.JoinWindows
Specifies that records of the same key are joinable if their timestamps are within timeDifference, i.e., the timestamp of a record from the secondary stream is max timeDifference earlier or later than the timestamp of the record from the primary stream.
of(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.
of(ConfigDef.Validator...) - Static method in class org.apache.kafka.common.config.ConfigDef.CompositeValidator
 
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 interface org.apache.kafka.streams.processor.api.RecordMetadata
 
offset() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
offset() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the offset of the current input record; could be -1 if it is not available (for example, if this method is invoked from the punctuate call).
offset() - Method in interface org.apache.kafka.streams.processor.RecordContext
 
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.
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 through KafkaConsumer.
OffsetAndMetadata(long, String) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndMetadata
Construct a new OffsetAndMetadata object for committing through KafkaConsumer.
OffsetAndMetadata(long, Optional<Integer>, String) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndMetadata
Construct a new OffsetAndMetadata object for committing through KafkaConsumer.
OffsetAndTimestamp - Class in org.apache.kafka.clients.consumer
A container class for offset and timestamp.
OffsetAndTimestamp(long, long) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndTimestamp
 
OffsetAndTimestamp(long, long, Optional<Integer>) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndTimestamp
 
OffsetCommitCallback - Interface in org.apache.kafka.clients.consumer
A callback interface that the user can implement to trigger custom actions when a commit request completes.
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 in org.apache.kafka.common.errors
The client has tried to save its offset with associated metadata larger than the maximum size allowed by the server.
OffsetMetadataTooLarge() - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
 
OffsetMetadataTooLarge(String) - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
 
OffsetMetadataTooLarge(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
 
OffsetMetadataTooLarge(Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
 
OffsetNotAvailableException - Exception 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 org.apache.kafka.common.errors.OffsetNotAvailableException
 
OffsetOutOfRangeException - Exception in org.apache.kafka.clients.consumer
No reset policy has been defined, and the offsets for these partitions are either larger or smaller than the range of offsets the server has for the given partition.
OffsetOutOfRangeException - Exception in org.apache.kafka.common.errors
No reset policy has been defined, and the offsets for these partitions are either larger or smaller than the range of offsets the server has for the given partition.
OffsetOutOfRangeException(String) - Constructor for exception org.apache.kafka.common.errors.OffsetOutOfRangeException
 
OffsetOutOfRangeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetOutOfRangeException
 
OffsetOutOfRangeException(String, Map<TopicPartition, Long>) - Constructor for exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
 
OffsetOutOfRangeException(Map<TopicPartition, Long>) - Constructor for exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
 
offsetOutOfRangePartitions() - Method in exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
Get a map of the topic partitions and the respective out-of-range fetch offsets.
OffsetResetStrategy - Enum in org.apache.kafka.clients.consumer
 
offsets(Collection<Map<String, T>>) - Method in interface org.apache.kafka.connect.storage.OffsetStorageReader
Get a set of offsets for the specified partition identifiers.
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 using KafkaAdminClient.listOffsets(Map, ListOffsetsOptions)
OffsetSpec() - Constructor for class org.apache.kafka.clients.admin.OffsetSpec
 
OffsetSpec.EarliestSpec - Class in org.apache.kafka.clients.admin
 
OffsetSpec.LatestSpec - 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 the OffsetStorageReader for 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.
oldest(long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
 
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
 
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(Map<TopicPartition, OffsetAndMetadata>) - Method in interface org.apache.kafka.clients.consumer.ConsumerInterceptor
This is called when offsets get committed.
onComplete(Map<TopicPartition, OffsetAndMetadata>, Exception) - Method in interface org.apache.kafka.clients.consumer.OffsetCommitCallback
A callback method the user can implement to provide asynchronous handling of commit request completion.
onCompletion(RecordMetadata, Exception) - Method in interface org.apache.kafka.clients.producer.Callback
A callback method the user can implement to provide asynchronous handling of request completion.
onConsume(ConsumerRecords<K, V>) - Method in interface org.apache.kafka.clients.consumer.ConsumerInterceptor
This is called just before the records are returned by KafkaConsumer.poll(java.time.Duration)
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.
onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestamp
Deprecated.
Returns the current stream-time as new timestamp for the record.
onNewBatch(String, Cluster, int) - Method in interface org.apache.kafka.clients.producer.Partitioner
Notifies the partitioner a new batch is about to be created.
onNewBatch(String, Cluster, int) - Method in class org.apache.kafka.clients.producer.UniformStickyPartitioner
If a batch completed for the current sticky partition, change the sticky partition.
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.
onPartitionsAssigned(Collection<TopicPartition>) - Method in class org.apache.kafka.connect.sink.SinkTask
Deprecated.
Use SinkTask.open(Collection) for partition initialization.
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.
onPartitionsRevoked(Collection<TopicPartition>) - Method in class org.apache.kafka.connect.sink.SinkTask
Deprecated.
Use SinkTask.close(Collection) instead for partition cleanup.
onRestoreEnd(TopicPartition, String, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
Method called when restoring the StateStore is complete.
onRestoreStart(TopicPartition, String, long, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
Method called at the very beginning of StateStore restoration.
onSend(ProducerRecord<K, V>) - Method in interface org.apache.kafka.clients.producer.ProducerInterceptor
This is called from KafkaProducer.send(ProducerRecord) and KafkaProducer.send(ProducerRecord, Callback) methods, before key and value get serialized and partition is assigned (if partition is not specified in ProducerRecord).
onUpdate(ClusterResource) - Method in interface org.apache.kafka.common.ClusterResourceListener
A callback method that a user can implement to get updates for ClusterResource.
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 use 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
Operation being performed.
OperationNotAttemptedException - Exception in org.apache.kafka.common.errors
Indicates that the broker did not attempt to execute this operation.
OperationNotAttemptedException(String) - Constructor for exception org.apache.kafka.common.errors.OperationNotAttemptedException
 
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
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
 
org.apache.kafka.clients.consumer - package org.apache.kafka.clients.consumer
 
org.apache.kafka.clients.producer - package org.apache.kafka.clients.producer
 
org.apache.kafka.common - package org.apache.kafka.common
 
org.apache.kafka.common.acl - package org.apache.kafka.common.acl
 
org.apache.kafka.common.annotation - package org.apache.kafka.common.annotation
 
org.apache.kafka.common.config - package org.apache.kafka.common.config
 
org.apache.kafka.common.config.provider - package org.apache.kafka.common.config.provider
 
org.apache.kafka.common.errors - package org.apache.kafka.common.errors
 
org.apache.kafka.common.header - package org.apache.kafka.common.header
 
org.apache.kafka.common.metrics - package org.apache.kafka.common.metrics
 
org.apache.kafka.common.metrics.stats - package org.apache.kafka.common.metrics.stats
 
org.apache.kafka.common.quota - package org.apache.kafka.common.quota
 
org.apache.kafka.common.resource - package org.apache.kafka.common.resource
 
org.apache.kafka.common.security.auth - package org.apache.kafka.common.security.auth
 
org.apache.kafka.common.security.oauthbearer - package org.apache.kafka.common.security.oauthbearer
 
org.apache.kafka.common.security.plain - package org.apache.kafka.common.security.plain
 
org.apache.kafka.common.security.scram - package org.apache.kafka.common.security.scram
 
org.apache.kafka.common.security.token.delegation - package org.apache.kafka.common.security.token.delegation
 
org.apache.kafka.common.serialization - package org.apache.kafka.common.serialization
 
org.apache.kafka.connect.components - package org.apache.kafka.connect.components
 
org.apache.kafka.connect.connector - package org.apache.kafka.connect.connector
 
org.apache.kafka.connect.connector.policy - package org.apache.kafka.connect.connector.policy
 
org.apache.kafka.connect.data - package org.apache.kafka.connect.data
 
org.apache.kafka.connect.errors - package org.apache.kafka.connect.errors
 
org.apache.kafka.connect.header - package org.apache.kafka.connect.header
 
org.apache.kafka.connect.health - package org.apache.kafka.connect.health
 
org.apache.kafka.connect.mirror - package org.apache.kafka.connect.mirror
 
org.apache.kafka.connect.rest - package org.apache.kafka.connect.rest
 
org.apache.kafka.connect.sink - package org.apache.kafka.connect.sink
 
org.apache.kafka.connect.source - package org.apache.kafka.connect.source
 
org.apache.kafka.connect.storage - package org.apache.kafka.connect.storage
 
org.apache.kafka.connect.transforms - package org.apache.kafka.connect.transforms
 
org.apache.kafka.connect.transforms.predicates - package org.apache.kafka.connect.transforms.predicates
 
org.apache.kafka.connect.util - package org.apache.kafka.connect.util
 
org.apache.kafka.server.authorizer - package org.apache.kafka.server.authorizer
 
org.apache.kafka.server.policy - package org.apache.kafka.server.policy
 
org.apache.kafka.server.quota - package org.apache.kafka.server.quota
 
org.apache.kafka.streams - package org.apache.kafka.streams
 
org.apache.kafka.streams.errors - package org.apache.kafka.streams.errors
 
org.apache.kafka.streams.kstream - package org.apache.kafka.streams.kstream
 
org.apache.kafka.streams.processor - package org.apache.kafka.streams.processor
 
org.apache.kafka.streams.processor.api - package org.apache.kafka.streams.processor.api
 
org.apache.kafka.streams.state - package org.apache.kafka.streams.state
 
org.apache.kafka.streams.test - package org.apache.kafka.streams.test
 
original() - Method in class org.apache.kafka.connect.data.Values.Parser
 
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(String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
The name of the original source-topic, which may have been replicated multiple hops.
otherStoreSupplier - Variable in class org.apache.kafka.streams.kstream.StreamJoined
 
otherValueSerde - Variable in class org.apache.kafka.streams.kstream.Joined
 
otherValueSerde - Variable in class org.apache.kafka.streams.kstream.StreamJoined
 
otherValueSerde() - Method in class org.apache.kafka.streams.kstream.Joined
 
otherValueSerde(Serde<VO>) - Static method in class org.apache.kafka.streams.kstream.Joined
Create an instance of Joined with an other value Serde.
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 another KStream's records using windowed outer equi join with default serializers and deserializers.
outerJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, Joined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
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 another KStream's records using windowed outer equi join using the StreamJoined instance for configuration of the key 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 this KTable (left input) with another KTable'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 this KTable (left input) with another KTable's (right input) records using non-windowed outer equi join, with the Materialized instance for configuration of the key serde, the result table's value serde, and state 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 this KTable (left input) with another KTable'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 this KTable (left input) with another KTable's (right input) records using non-windowed outer equi join, with the Materialized instance for configuration of the key serde, the result table's value serde, and state store.
OutOfOrderSequenceException - Exception in org.apache.kafka.common.errors
This exception indicates that the broker received an unexpected sequence number from the producer, which means that data may have been lost.
OutOfOrderSequenceException(String) - Constructor for exception org.apache.kafka.common.errors.OutOfOrderSequenceException
 
outputStream - Variable in class org.apache.kafka.streams.kstream.Printed
 
OutputVerifier - Class in org.apache.kafka.streams.test
Deprecated.
Since 2.4 use methods of TestOutputTopic and standard assertion libraries instead
OutputVerifier() - Constructor for class org.apache.kafka.streams.test.OutputVerifier
Deprecated.
 
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.common.security.token.delegation.TokenInformation
 
ownerAsString() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
ownerOrRenewer(KafkaPrincipal) - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
owners() - Method in class org.apache.kafka.clients.admin.DescribeDelegationTokenOptions
 
owners(List<KafkaPrincipal>) - Method in class org.apache.kafka.clients.admin.DescribeDelegationTokenOptions
if owners is null, all the user owned tokens and tokens where user have Describe permission will be returned.

P

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 org.apache.kafka.common.ConsumerGroupState
Parse a string into a consumer group state.
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.
parse(Values.Parser, boolean) - Static method in class org.apache.kafka.connect.data.Values
 
Parser(String) - Constructor for class org.apache.kafka.connect.data.Values.Parser
 
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 - Variable in class org.apache.kafka.streams.processor.TaskId
The ID of the partition.
partition() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The partition from which this record is received
partition() - Method in exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
partition() - Method in class org.apache.kafka.clients.producer.ProducerRecord
 
partition() - Method in class org.apache.kafka.clients.producer.RecordMetadata
The partition the record was sent to
partition() - Method in class org.apache.kafka.common.PartitionInfo
The partition id
partition() - Method in class org.apache.kafka.common.TopicPartition
 
partition() - Method in class org.apache.kafka.common.TopicPartitionInfo
Return the partition id.
partition() - Method in class org.apache.kafka.common.TopicPartitionReplica
 
partition() - 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
 
partition() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
partition() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the partition id of the current input record; could be -1 if it is not available (for example, if this method is invoked from the punctuate call).
partition() - Method in interface org.apache.kafka.streams.processor.RecordContext
 
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(String, Object, byte[], Object, byte[], Cluster) - Method in class org.apache.kafka.clients.producer.UniformStickyPartitioner
Compute the partition for the given record.
partition(String, K, V, int) - Method in interface org.apache.kafka.streams.processor.StreamPartitioner
Determine the partition number for a record with the given key and value and the current number of partitions.
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_GROUPER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
Deprecated.
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.
partitionCountForTopic(String) - Method in class org.apache.kafka.common.Cluster
Get the number of partitions for the given topic.
partitioner - Variable in class org.apache.kafka.streams.kstream.Produced
 
partitioner - Variable in class org.apache.kafka.streams.kstream.Repartitioned
 
Partitioner - Interface in org.apache.kafka.clients.producer
Partitioner Interface
PARTITIONER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
partitioner.class
PartitionGrouper - Interface in org.apache.kafka.streams.processor
Deprecated.
since 2.4 release; will be removed in 3.0.0 via KAFKA-7785
partitionGroups(Map<Integer, Set<String>>, Cluster) - Method in class org.apache.kafka.streams.processor.DefaultPartitionGrouper
Deprecated.
Generate tasks with the assigned topic partitions.
partitionGroups(Map<Integer, Set<String>>, Cluster) - Method in interface org.apache.kafka.streams.processor.PartitionGrouper
Deprecated.
Returns a map of task ids to groups of partitions.
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
 
PartitionReassignment - Class in org.apache.kafka.clients.admin
A partition reassignment, which has been listed via Admin.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.ElectPreferredLeadersResult
Deprecated.
Get the result of the election for the given partition.
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.ElectPreferredLeadersResult
Deprecated.
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 org.apache.kafka.clients.consumer.InvalidOffsetException
 
partitions() - Method in exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
returns all partitions for which no offests are defined.
partitions() - Method in exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
 
partitionsFor(String) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
partitionsFor(String) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get metadata about the partitions for a given topic.
partitionsFor(String) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
partitionsFor(String) - Method in class org.apache.kafka.clients.producer.KafkaProducer
Get the partition metadata for the given topic.
partitionsFor(String) - Method in class org.apache.kafka.clients.producer.MockProducer
 
partitionsFor(String) - Method in interface org.apache.kafka.clients.producer.Producer
partitionsFor(String, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
partitionsFor(String, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get metadata about the partitions for a given topic.
partitionsFor(String, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
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
partitionsToOffsetAndMetadata() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsResult
Return a future which yields a map of topic partitions to OffsetAndMetadata objects.
password() - Method in class org.apache.kafka.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 - org.apache.kafka.clients.admin.ConfigEntry.ConfigType
 
PASSWORD - org.apache.kafka.common.config.ConfigDef.Type
 
pattern() - Method in class org.apache.kafka.common.acl.AclBinding
 
patternFilter() - Method in class org.apache.kafka.common.acl.AclBindingFilter
 
patternType() - Method in class org.apache.kafka.common.resource.ResourcePattern
 
patternType() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
PatternType - Enum in org.apache.kafka.common.resource
Resource pattern type.
pause(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
pause(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Suspend fetching from the requested partitions.
pause(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
pause(TopicPartition...) - Method in interface org.apache.kafka.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 to KafkaConsumer.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 of KStream.
peek(ForeachAction<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
Perform an action on each record of KStream.
peekNextKey() - Method in interface org.apache.kafka.streams.state.KeyValueIterator
Peek at the next key without advancing the iterator
PENDING_ERROR - org.apache.kafka.streams.KafkaStreams.State
 
PENDING_SHUTDOWN - 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 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.
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 persistent KeyValueBytesStoreSupplier.
persistentSessionStore(String, long) - Static method in class org.apache.kafka.streams.state.Stores
Deprecated.
persistentSessionStore(String, Duration) - Static method in class org.apache.kafka.streams.state.Stores
Create a persistent SessionBytesStoreSupplier.
persistentTimestampedKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
Create a persistent KeyValueBytesStoreSupplier.
persistentTimestampedWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
Create a persistent WindowBytesStoreSupplier.
persistentWindowStore(String, long, int, long, boolean) - Static method in class org.apache.kafka.streams.state.Stores
persistentWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
Create a persistent WindowBytesStoreSupplier.
pipeInput(List<ConsumerRecord<byte[], byte[]>>) - Method in class org.apache.kafka.streams.TopologyTestDriver
Deprecated.
Since 2.4 use methods of TestInputTopic instead
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(ConsumerRecord<byte[], byte[]>) - Method in class org.apache.kafka.streams.TopologyTestDriver
Deprecated.
Since 2.4 use methods of TestInputTopic instead
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 given KeyValue list 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 - org.apache.kafka.common.security.auth.SecurityProtocol
Un-authenticated, non-encrypted channel
PlaintextAuthenticationContext - Class in org.apache.kafka.common.security.auth
 
PlaintextAuthenticationContext(InetAddress, String) - Constructor for class org.apache.kafka.common.security.auth.PlaintextAuthenticationContext
 
PolicyViolationException - Exception in org.apache.kafka.common.errors
Exception thrown if a create topics request does not satisfy the configured policy for a topic.
PolicyViolationException(String) - Constructor for exception org.apache.kafka.common.errors.PolicyViolationException
 
PolicyViolationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.PolicyViolationException
 
poll() - Method in class org.apache.kafka.connect.source.SourceTask
Poll this source task for new records.
poll(long) - Method in interface org.apache.kafka.clients.consumer.Consumer
Deprecated.
poll(long) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Deprecated.
Since 2.0. Use KafkaConsumer.poll(Duration), which does not block beyond the timeout awaiting partition assignment. See KIP-266 for more information.
poll(long) - Method in class org.apache.kafka.clients.consumer.MockConsumer
Deprecated.
poll(Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
poll(Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Fetch data for the topics or partitions specified using one of the subscribe/assign APIs.
poll(Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
POLL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
poll.ms
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 class org.apache.kafka.streams.state.StreamsMetadata
 
position() - Method in class org.apache.kafka.connect.data.Values.Parser
 
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
 
PositionOutOfRangeException - Exception in org.apache.kafka.common.errors
 
PositionOutOfRangeException(String) - Constructor for exception org.apache.kafka.common.errors.PositionOutOfRangeException
 
PositionOutOfRangeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.PositionOutOfRangeException
 
postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.clients.admin.AdminClientConfig
 
postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.clients.consumer.ConsumerConfig
 
postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.clients.producer.ProducerConfig
 
postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.common.config.AbstractConfig
Called directly after user configs got parsed (and thus default values got set).
postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.streams.StreamsConfig
 
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 extends ConnectRecord<R>> - Interface in org.apache.kafka.connect.transforms.predicates
A predicate on records.
Predicate<K,​V> - Interface in org.apache.kafka.streams.kstream
The Predicate interface represents a predicate (boolean-valued function) of a KeyValue pair.
PREFERRED - org.apache.kafka.common.ElectionType
 
PreferredLeaderNotAvailableException - Exception in org.apache.kafka.common.errors
 
PreferredLeaderNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.PreferredLeaderNotAvailableException
 
PreferredLeaderNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.PreferredLeaderNotAvailableException
 
PREFIXED - 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.
PREPARING_REBALANCE - org.apache.kafka.common.ConsumerGroupState
 
previous() - Method in class org.apache.kafka.connect.data.Values.Parser
 
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.
PRINCIPAL_BUILDER_CLASS_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
PRINCIPAL_BUILDER_CLASS_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
PrincipalBuilder - Interface in org.apache.kafka.common.security.auth
Deprecated.
As of Kafka 1.0.0, use KafkaPrincipalBuilder instead. This will be removed in a future major release.
PrincipalDeserializationException - Exception in org.apache.kafka.common.errors
Exception used to indicate a kafka principal deserialization failure during request forwarding.
PrincipalDeserializationException(String) - Constructor for exception org.apache.kafka.common.errors.PrincipalDeserializationException
 
PrincipalDeserializationException(String, Throwable) - Constructor for exception 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 by Printed Note 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 a KStream.
Printed(Printed<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Printed
Copy constructor.
PROBING_REBALANCE_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
probing.rebalance.interval.ms
process(K, V) - Method in interface org.apache.kafka.streams.processor.Processor
Process the record with the given key and value.
process(Record<KIn, VIn>) - Method in interface org.apache.kafka.streams.processor.api.Processor
Process the record.
process(ProcessorSupplier<? super K, ? super V>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Process all records in this stream, one record at a time, by applying a Processor (provided by the given ProcessorSupplier).
process(ProcessorSupplier<? super K, ? super V>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Process all records in this stream, one record at a time, by applying a Processor (provided by the given ProcessorSupplier).
PROCESSING_GUARANTEE_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
processing.guarantee
processor() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
The processor node maintaining the global store.
Processor<KIn,​VIn,​KOut,​VOut> - Interface in org.apache.kafka.streams.processor.api
A processor of key-value pair records.
Processor<K,​V> - Interface in org.apache.kafka.streams.processor
A processor of key-value pair records.
ProcessorContext<KForward,​VForward> - Interface in org.apache.kafka.streams.processor.api
Processor context interface.
ProcessorContext - Interface in org.apache.kafka.streams.processor
Processor context interface.
processorName - Variable in class org.apache.kafka.streams.kstream.Consumed
 
processorName - Variable in class org.apache.kafka.streams.kstream.Printed
 
processorName - Variable in class org.apache.kafka.streams.kstream.Produced
 
ProcessorStateException - Exception in org.apache.kafka.streams.errors
Indicates a processor state operation (e.g.
ProcessorStateException(String) - Constructor for exception org.apache.kafka.streams.errors.ProcessorStateException
 
ProcessorStateException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.ProcessorStateException
 
ProcessorStateException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.ProcessorStateException
 
ProcessorSupplier<KIn,​VIn,​KOut,​VOut> - Interface in org.apache.kafka.streams.processor.api
A processor supplier that can create one or more Processor instances.
ProcessorSupplier<K,​V> - Interface in org.apache.kafka.streams.processor
A processor supplier that can create one or more Processor instances.
PRODUCE - 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 using KStream.through(String, Produced) or KStream.to(String, Produced).
Produced(Produced<K, V>) - Constructor for class org.apache.kafka.streams.kstream.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 the KafkaProducer
PRODUCER - 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 isolate producer configs from other client configs.
producerClientIds() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
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
 
ProducerFencedException - Exception in org.apache.kafka.common.errors
This fatal exception indicates that another producer with the same transactional.id has been started.
ProducerFencedException(String) - Constructor for exception org.apache.kafka.common.errors.ProducerFencedException
 
ProducerInterceptor<K,​V> - Interface in org.apache.kafka.clients.producer
A plugin interface that allows you to intercept (and possibly mutate) the records received by the producer before they are published to the Kafka cluster.
producerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
Prefix a property with StreamsConfig.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
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 in org.apache.kafka.streams.errors
 
project(Schema, Object, Schema) - Static method in class org.apache.kafka.connect.data.SchemaProjector
This method project a value between compatible schemas and throw exceptions when non compatible schemas are provided
punctuate(long) - Method in interface org.apache.kafka.streams.processor.Punctuator
Perform the scheduled periodic operation.
PunctuationType - Enum in org.apache.kafka.streams.processor
Controls what notion of time is used for punctuation scheduled via ProcessorContext.schedule(Duration, PunctuationType, Punctuator) schedule}: STREAM_TIME - uses "stream time", which is advanced by the processing of messages in accordance with the timestamp as extracted by the TimestampExtractor in use.
Punctuator - Interface in org.apache.kafka.streams.processor
A functional interface used as an argument to ProcessorContext.schedule(Duration, PunctuationType, Punctuator).
purgeObsoleteSamples(MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
 
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(K, V) - Method in interface org.apache.kafka.streams.state.KeyValueStore
Update the value associated with this key.
put(K, V) - Method in interface org.apache.kafka.streams.state.WindowStore
Deprecated.
as timestamp is not provided for the key-value pair, this causes inconsistency to identify the window frame to which the key belongs. Use WindowStore.put(Object, Object, long) instead.
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(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
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.

Q

queryableStoreName() - Method in interface org.apache.kafka.streams.kstream.GlobalKTable
Get the name of the local state store that can be used to query this GlobalKTable.
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 this KTable.
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 custom StateStore types via the KafkaStreams API.
QueryableStoreTypes - Class in org.apache.kafka.streams.state
Provides access to the QueryableStoreTypes provided with KafkaStreams.
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
 
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.
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 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 org.apache.kafka.common.metrics.QuotaViolationException
 

R

rack() - Method in class org.apache.kafka.common.Node
The rack for this node
raiseError(Exception) - Method in interface org.apache.kafka.connect.connector.ConnectorContext
Raise an unrecoverable exception to the Connect framework.
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.
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
 
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
 
Rate.SampledTotal - Class in org.apache.kafka.common.metrics.stats
Deprecated.
since 2.4 Use WindowedSum instead.
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 - org.apache.kafka.common.acl.AclOperation
READ operation.
READ_COMMITTED - org.apache.kafka.common.IsolationLevel
 
READ_UNCOMMITTED - org.apache.kafka.common.IsolationLevel
 
reader(String) - Method in class org.apache.kafka.common.config.provider.FileConfigProvider
 
readFrom(DataInputStream) - Static method in class org.apache.kafka.streams.processor.TaskId
 
readFrom(ByteBuffer) - Static method in class org.apache.kafka.streams.processor.TaskId
 
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.
readOutput(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
Deprecated.
Since 2.4 use methods of TestOutputTopic instead
readOutput(String, Deserializer<K>, Deserializer<V>) - Method in class org.apache.kafka.streams.TopologyTestDriver
Deprecated.
Since 2.4 use methods of TestOutputTopic instead
readRecord() - Method in class org.apache.kafka.streams.TestOutputTopic
Read one Record from output topic.
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.
ReassignmentInProgressException - Exception in org.apache.kafka.common.errors
Thrown if a request cannot be completed because a partition reassignment is in progress.
ReassignmentInProgressException(String) - Constructor for exception org.apache.kafka.common.errors.ReassignmentInProgressException
 
ReassignmentInProgressException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ReassignmentInProgressException
 
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 in org.apache.kafka.common.errors
 
RebalanceInProgressException() - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
 
RebalanceInProgressException(String) - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
 
RebalanceInProgressException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
 
RebalanceInProgressException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
 
REBALANCING - org.apache.kafka.streams.KafkaStreams.State
 
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
 
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.
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 for record(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 a Processor or a record to forward to downstream processors via ProcessorContext.
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 in org.apache.kafka.common.errors
This record batch is larger than the maximum allowable size
RecordBatchTooLargeException() - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
 
RecordBatchTooLargeException(String) - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
 
RecordBatchTooLargeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
 
RecordBatchTooLargeException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
 
recordCollector() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
 
recordCollector() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
RecordContext - Interface in org.apache.kafka.streams.processor
The context associated with the current record being processed by an Processor
recordLatency(Sensor, long, long) - Method in interface org.apache.kafka.streams.StreamsMetrics
Deprecated.
since 2.5. Use Sensor#record() instead.
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.ProcessorContext
The metadata of the source record, if is one.
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, long, long, Long, int, int) - Constructor for class org.apache.kafka.clients.producer.RecordMetadata
 
records(String) - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
Get just the records for the given topic
records(TopicPartition) - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
Get just the records for the given partition
RecordsToDelete - Class in org.apache.kafka.clients.admin
Describe records to delete in a call to Admin.deleteRecords(Map) The API of this class is evolving, see Admin for details.
recordThroughput(Sensor, long) - Method in interface org.apache.kafka.streams.StreamsMetrics
Deprecated.
since 2.5. Use Sensor#record() instead.
RecordTooLargeException - Exception in org.apache.kafka.common.errors
This record is larger than the maximum allowable size
RecordTooLargeException() - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
 
RecordTooLargeException(String) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
 
RecordTooLargeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
 
RecordTooLargeException(String, Map<TopicPartition, Long>) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
 
RecordTooLargeException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
 
recordTooLargePartitions() - Method in exception org.apache.kafka.common.errors.RecordTooLargeException
 
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
Combine the value of records of the original KTable that got mapped to the same key into a new instance of KTable.
reduce(Reducer<V>, Reducer<V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
Combine the value of records of the original KTable that got mapped to the same key into a new instance of KTable.
reduce(Reducer<V>, Reducer<V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
Combine the value of records of the original KTable that got mapped to the same key into a new instance of KTable.
Reducer<V> - Interface in org.apache.kafka.streams.kstream
The Reducer interface 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 the ConnectRestExtension.register(ConnectRestExtensionContext) method.
register(StateStore, StateRestoreCallback) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
register(StateStore, StateRestoreCallback) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Registers 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.
RemoteClusterUtils - Class in org.apache.kafka.connect.mirror
Convenience methods for multi-cluster environments.
remoteConsumerOffsets(String, String, Duration) - Method in class org.apache.kafka.connect.mirror.MirrorClient
Translate a remote consumer group's offsets into corresponding local offsets.
remoteTopics() - Method in class org.apache.kafka.connect.mirror.MirrorClient
Find all remote topics on this cluster.
remoteTopics(String) - Method in class org.apache.kafka.connect.mirror.MirrorClient
Find 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
Removes all Header objects whose key matches the specified key.
remove(Windowed<K>) - Method in interface org.apache.kafka.streams.state.SessionStore
Remove the session aggregated with provided Windowed key 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.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
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 ZooKeeper.
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.
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 new Header object 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.KafkaAdminClient
 
RenewDelegationTokenOptions - Class in org.apache.kafka.clients.admin
RenewDelegationTokenOptions() - Constructor for class org.apache.kafka.clients.admin.RenewDelegationTokenOptions
 
RenewDelegationTokenResult - Class in org.apache.kafka.clients.admin
renewers() - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
 
renewers() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
renewers(List<KafkaPrincipal>) - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
 
renewersAsString() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
renewTimePeriodMs() - Method in class org.apache.kafka.clients.admin.RenewDelegationTokenOptions
 
renewTimePeriodMs(long) - Method in class org.apache.kafka.clients.admin.RenewDelegationTokenOptions
 
repartition() - Method in interface org.apache.kafka.streams.kstream.KStream
Materialize this stream to an auto-generated repartition topic and create a new KStream from the auto-generated topic using default serializers, deserializers, and producer's DefaultPartitioner.
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 new KStream from the auto-generated topic using key serde, value serde, StreamPartitioner, number of partitions, and topic name part as defined by Repartitioned.
Repartitioned<K,​V> - Class in org.apache.kafka.streams.kstream
This class is used to provide the optional parameters for internal repartition topics.
Repartitioned(Repartitioned<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Repartitioned
 
REPLACE_THREAD - org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
 
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 in org.apache.kafka.common.errors
The replica is not available for the requested topic partition.
ReplicaNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.ReplicaNotAvailableException
 
ReplicaNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ReplicaNotAvailableException
 
ReplicaNotAvailableException(Throwable) - Constructor for exception org.apache.kafka.common.errors.ReplicaNotAvailableException
 
replicas() - Method in class org.apache.kafka.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
Compute shortest number of hops from an upstream source cluster.
replicationHops(Map<String, Object>, String) - Static method in class org.apache.kafka.connect.mirror.RemoteClusterUtils
Find shortest number of hops from an upstream cluster.
replicationPolicy() - Method in class org.apache.kafka.connect.mirror.MirrorClient
Get the ReplicationPolicy instance used to interpret remote topics.
replicationPolicy() - Method in class org.apache.kafka.connect.mirror.MirrorClientConfig
 
ReplicationPolicy - Interface in org.apache.kafka.connect.mirror
Defines which topics are "remote topics".
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 - 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 - 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.
required() - Method in class org.apache.kafka.connect.data.SchemaBuilder
Set this schema as required.
REQUIRED - org.apache.kafka.common.config.SslClientAuth
 
reset(long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat.Sample
 
resetCommit() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
Reset the commit capture to false (whether or not it was previously true).
resetCommit() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
Reset the commit capture to false (whether or not it was previously true).
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
Clear the captured forwarded data.
resetPolicy - Variable in class org.apache.kafka.streams.kstream.Consumed
 
resetShouldRebalance() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
resource() - Method in exception org.apache.kafka.common.errors.DuplicateResourceException
 
resource() - Method in exception 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.
ResourceFilter - Class in org.apache.kafka.common.resource
A filter which matches Resource objects.
ResourceFilter(ResourceType, String) - Constructor for class org.apache.kafka.common.resource.ResourceFilter
Create an instance of this class with the provided parameters.
ResourceNotFoundException - Exception in org.apache.kafka.common.errors
Exception thrown due to a request for a resource that does not exist.
ResourceNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.ResourceNotFoundException
Constructor
ResourceNotFoundException(String, String) - Constructor for exception org.apache.kafka.common.errors.ResourceNotFoundException
Constructor
ResourceNotFoundException(String, String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ResourceNotFoundException
Constructor
ResourceNotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ResourceNotFoundException
 
resourcePattern() - Method in class org.apache.kafka.server.authorizer.Action
Resource on which action is being performed.
ResourcePattern - Class in org.apache.kafka.common.resource
Represents a pattern that is used by ACLs to match zero or more Resources.
ResourcePattern(ResourceType, String, PatternType) - Constructor for class org.apache.kafka.common.resource.ResourcePattern
Create a pattern using the supplied parameters.
ResourcePatternFilter - Class in org.apache.kafka.common.resource
Represents a filter that can match ResourcePattern.
ResourcePatternFilter(ResourceType, String, PatternType) - Constructor for class org.apache.kafka.common.resource.ResourcePatternFilter
Create a filter using the supplied parameters.
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.ResourceFilter
Return the resource type.
resourceType() - Method in class org.apache.kafka.common.resource.ResourcePattern
 
resourceType() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
ResourceType - Enum in org.apache.kafka.common.resource
Represents a type of resource which an ACL can be applied to.
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 override consumer configs 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 class org.apache.kafka.streams.processor.ThreadMetadata
 
restoreConsumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
resume(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
resume(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Resume specified partitions which have been paused with KafkaConsumer.pause(Collection).
resume(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
resume(TopicPartition...) - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
Resume consumption of messages from previously paused TopicPartitions.
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 last Header object 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
Removes all but the latest Header objects whose key matches the specified key.
retention - Variable in class org.apache.kafka.streams.kstream.Materialized
 
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 interface org.apache.kafka.streams.state.SessionBytesStoreSupplier
The time period for which the SessionStore will retain historic data.
retentionPeriod() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
The time period for which the WindowStore will retain historic data.
RetriableCommitFailedException - Exception in org.apache.kafka.clients.consumer
 
RetriableCommitFailedException(String) - Constructor for exception org.apache.kafka.clients.consumer.RetriableCommitFailedException
 
RetriableCommitFailedException(String, Throwable) - Constructor for exception org.apache.kafka.clients.consumer.RetriableCommitFailedException
 
RetriableCommitFailedException(Throwable) - Constructor for exception org.apache.kafka.clients.consumer.RetriableCommitFailedException
 
RetriableException - Exception in org.apache.kafka.common.errors
A retriable exception is a transient exception that if retried may succeed.
RetriableException - Exception in org.apache.kafka.connect.errors
An exception that indicates the operation can be reattempted.
RetriableException() - Constructor for exception org.apache.kafka.common.errors.RetriableException
 
RetriableException(String) - Constructor for exception org.apache.kafka.common.errors.RetriableException
 
RetriableException(String) - Constructor for exception org.apache.kafka.connect.errors.RetriableException
 
RetriableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RetriableException
 
RetriableException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.RetriableException
 
RetriableException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RetriableException
 
RetriableException(Throwable) - Constructor for exception 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
RETRIES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
Deprecated.
since 2.7
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.
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.
rewindTo(int) - Method in class org.apache.kafka.connect.data.Values.Parser
 
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.
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
 
RUNNING - org.apache.kafka.streams.KafkaStreams.State
 

S

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.
Sample(double, long) - Constructor for class org.apache.kafka.common.metrics.stats.SampledStat.Sample
 
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
 
SampledStat.Sample - Class in org.apache.kafka.common.metrics.stats
 
SampledTotal() - Constructor for class org.apache.kafka.common.metrics.stats.Rate.SampledTotal
Deprecated.
 
samples - Variable in 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_ENABLED_MECHANISMS - Static variable in class org.apache.kafka.common.config.SaslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
SASL_ENABLED_MECHANISMS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
SASL_JAAS_CONFIG - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_JAAS_CONFIG_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_KINIT_CMD - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_KINIT_CMD_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_MIN_TIME_BEFORE_RELOGIN - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_MIN_TIME_BEFORE_RELOGIN_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_PRINCIPAL_TO_LOCAL_RULES - Static variable in class org.apache.kafka.common.config.SaslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
SASL_KERBEROS_PRINCIPAL_TO_LOCAL_RULES_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
SASL_KERBEROS_SERVICE_NAME - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_SERVICE_NAME_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_TICKET_RENEW_JITTER - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_TICKET_RENEW_JITTER_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_TICKET_RENEW_WINDOW_FACTOR - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_KERBEROS_TICKET_RENEW_WINDOW_FACTOR_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_CALLBACK_HANDLER_CLASS - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_CALLBACK_HANDLER_CLASS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_CLASS - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_CLASS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_REFRESH_BUFFER_SECONDS - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_REFRESH_BUFFER_SECONDS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_REFRESH_MIN_PERIOD_SECONDS - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_REFRESH_MIN_PERIOD_SECONDS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_REFRESH_WINDOW_FACTOR - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_REFRESH_WINDOW_FACTOR_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_REFRESH_WINDOW_JITTER - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_LOGIN_REFRESH_WINDOW_JITTER_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_MECHANISM - Static variable in class org.apache.kafka.common.config.SaslConfigs
SASL mechanism configuration - standard mechanism names are listed here.
SASL_MECHANISM_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
 
SASL_PLAINTEXT - org.apache.kafka.common.security.auth.SecurityProtocol
SASL authenticated, non-encrypted channel
SASL_SSL - org.apache.kafka.common.security.auth.SecurityProtocol
SASL authenticated, SSL channel
SaslAuthenticationContext - Class in org.apache.kafka.common.security.auth
 
SaslAuthenticationContext(SaslServer, SecurityProtocol, InetAddress, String) - Constructor for class org.apache.kafka.common.security.auth.SaslAuthenticationContext
 
SaslAuthenticationContext(SaslServer, SecurityProtocol, InetAddress, String, Optional<SSLSession>) - Constructor for class org.apache.kafka.common.security.auth.SaslAuthenticationContext
 
SaslAuthenticationException - Exception in org.apache.kafka.common.errors
This exception indicates that SASL authentication has failed.
SaslAuthenticationException(String) - Constructor for exception org.apache.kafka.common.errors.SaslAuthenticationException
 
SaslAuthenticationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SaslAuthenticationException
 
SaslConfigs - Class in org.apache.kafka.common.config
 
SaslConfigs() - Constructor for class org.apache.kafka.common.config.SaslConfigs
 
SaslExtensions - Class in org.apache.kafka.common.security.auth
A simple immutable value object class holding customizable SASL extensions
SaslExtensions(Map<String, String>) - Constructor for class org.apache.kafka.common.security.auth.SaslExtensions
 
SaslExtensionsCallback - Class in org.apache.kafka.common.security.auth
Optional callback used for SASL mechanisms if any extensions need to be set in the SASL exchange.
SaslExtensionsCallback() - Constructor for class org.apache.kafka.common.security.auth.SaslExtensionsCallback
 
SCALE_FIELD - Static variable in class org.apache.kafka.connect.data.Decimal
 
schedule(long, PunctuationType, Punctuator) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
Deprecated.
schedule(long, PunctuationType, Punctuator) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
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.ProcessorContext
Schedules a periodic operation for processors.
schedule(Duration, PunctuationType, Punctuator) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
schedule(Duration, PunctuationType, Punctuator) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Schedules 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
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 the Schema
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 the Schema specified by this builder
schema() - Method in class org.apache.kafka.connect.data.Struct
Get the schema for this Struct.
schema() - Method in class org.apache.kafka.connect.data.Values.SchemaDetector
 
schema() - Method in interface org.apache.kafka.connect.header.Header
Return the Schema associated 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 in org.apache.kafka.connect.data
The type of a schema.
SchemaAndValue - Class in org.apache.kafka.connect.data
 
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 constructing Schema objects.
SchemaBuilder(Schema.Type) - Constructor for class org.apache.kafka.connect.data.SchemaBuilder
 
SchemaBuilderException - Exception in org.apache.kafka.connect.errors
 
SchemaBuilderException(String) - Constructor for exception org.apache.kafka.connect.errors.SchemaBuilderException
 
SchemaBuilderException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.SchemaBuilderException
 
SchemaBuilderException(Throwable) - Constructor for exception org.apache.kafka.connect.errors.SchemaBuilderException
 
SchemaDetector() - Constructor for class org.apache.kafka.connect.data.Values.SchemaDetector
 
SchemaProjector - Class in org.apache.kafka.connect.data
SchemaProjector is 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 in org.apache.kafka.connect.errors
 
SchemaProjectorException(String) - Constructor for exception org.apache.kafka.connect.errors.SchemaProjectorException
 
SchemaProjectorException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.SchemaProjectorException
 
SchemaProjectorException(Throwable) - Constructor for exception org.apache.kafka.connect.errors.SchemaProjectorException
 
schemaType(Class<?>) - Static method in class org.apache.kafka.connect.data.ConnectSchema
Get the Schema.Type associated 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
SCRAM_SHA_256 - org.apache.kafka.clients.admin.ScramMechanism
 
SCRAM_SHA_512 - 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 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 in org.apache.kafka.common.errors
An error indicating that security is disabled on the broker.
SecurityDisabledException(String) - Constructor for exception org.apache.kafka.common.errors.SecurityDisabledException
 
SecurityDisabledException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SecurityDisabledException
 
securityProtocol() - Method in 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 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 next poll(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 next poll(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.
segments - Variable in class org.apache.kafka.streams.kstream.Windows
Deprecated.
segments() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
Deprecated.
segments(int) - Method in class org.apache.kafka.streams.kstream.Windows
Deprecated.
since 2.1 Override segmentInterval() instead.
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>, String) - 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>, String) - Method in class org.apache.kafka.clients.producer.MockProducer
 
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in interface org.apache.kafka.clients.producer.Producer
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.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, 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, 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, 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(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 - 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 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.ByteArraySerde - Class in org.apache.kafka.common.serialization
 
Serdes.ByteBufferSerde - Class in org.apache.kafka.common.serialization
 
Serdes.BytesSerde - Class in org.apache.kafka.common.serialization
 
Serdes.DoubleSerde - Class in org.apache.kafka.common.serialization
 
Serdes.FloatSerde - Class in org.apache.kafka.common.serialization
 
Serdes.IntegerSerde - Class in org.apache.kafka.common.serialization
 
Serdes.LongSerde - Class in org.apache.kafka.common.serialization
 
Serdes.ShortSerde - Class in org.apache.kafka.common.serialization
 
Serdes.StringSerde - Class in org.apache.kafka.common.serialization
 
Serdes.UUIDSerde - Class in org.apache.kafka.common.serialization
 
Serdes.VoidSerde - Class in org.apache.kafka.common.serialization
 
Serdes.WrapperSerde<T> - Class in org.apache.kafka.common.serialization
 
SerializationException - Exception in org.apache.kafka.common.errors
Any exception during serialization in the producer
SerializationException() - Constructor for exception org.apache.kafka.common.errors.SerializationException
 
SerializationException(String) - Constructor for exception org.apache.kafka.common.errors.SerializationException
 
SerializationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SerializationException
 
SerializationException(Throwable) - Constructor for exception org.apache.kafka.common.errors.SerializationException
 
serialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ByteArraySerializer
 
serialize(String, Double) - Method in class org.apache.kafka.common.serialization.DoubleSerializer
 
serialize(String, Float) - Method in class org.apache.kafka.common.serialization.FloatSerializer
 
serialize(String, Integer) - Method in class org.apache.kafka.common.serialization.IntegerSerializer
 
serialize(String, Long) - Method in class org.apache.kafka.common.serialization.LongSerializer
 
serialize(String, Short) - Method in class org.apache.kafka.common.serialization.ShortSerializer
 
serialize(String, String) - Method in class org.apache.kafka.common.serialization.StringSerializer
 
serialize(String, Void) - Method in class org.apache.kafka.common.serialization.VoidSerializer
 
serialize(String, ByteBuffer) - Method in class org.apache.kafka.common.serialization.ByteBufferSerializer
 
serialize(String, UUID) - Method in class org.apache.kafka.common.serialization.UUIDSerializer
 
serialize(String, Headers, T) - Method in interface org.apache.kafka.common.serialization.ExtendedSerializer
Deprecated.
Convert data into a byte array.
serialize(String, Headers, T) - Method in class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
Deprecated.
 
serialize(String, Headers, T) - Method in interface org.apache.kafka.common.serialization.Serializer
Convert data into a byte array.
serialize(String, Bytes) - Method in class org.apache.kafka.common.serialization.BytesSerializer
 
serialize(String, 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 class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
Deprecated.
 
serialize(String, T) - Method in interface org.apache.kafka.common.serialization.Serializer
Convert data into a byte array.
serialize(KafkaPrincipal) - Method in interface org.apache.kafka.common.security.auth.KafkaPrincipalSerde
Serialize a KafkaPrincipal into 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
 
Serialized<K,​V> - Class in org.apache.kafka.streams.kstream
Deprecated.
since 2.1. Use Grouped instead
Serialized(Serialized<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Serialized
Deprecated.
 
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 more SessionStore<Byte, byte[]> instances.
sessionStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
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 a StoreBuilder that can be used to build a SessionStore.
SessionWindowedCogroupedKStream<K,​V> - Interface in org.apache.kafka.streams.kstream
SessionWindowedCogroupKStream is an abstraction of a windowed record stream of KeyValue pairs.
SessionWindowedDeserializer<T> - Class in org.apache.kafka.streams.kstream
The inner serde class can be specified by setting the property StreamsConfig.DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS or StreamsConfig.DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS if the no-arg constructor is called and hence it is not passed during initialization.
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
SessionWindowedKStream is an abstraction of a windowed record stream of KeyValue pairs.
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 a SessionWindowedSerde object for the specified inner class type.
SessionWindowedSerializer<T> - Class in org.apache.kafka.streams.kstream
The inner serde class can be specified by setting the property StreamsConfig.DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS or StreamsConfig.DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS if the no-arg constructor is called and hence it is not passed during initialization.
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 - org.apache.kafka.clients.admin.AlterConfigOp.OpType
Set the value of the configuration entry.
setConfig(String, Options, Map<String, Object>) - Method in interface org.apache.kafka.streams.state.RocksDBConfigSetter
Set the rocks db options for the provided storeName.
setException(KafkaException) - Method in class org.apache.kafka.clients.consumer.MockConsumer
setExpiryTimestamp(long) - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
setGlobalStateRestoreListener(StateRestoreListener) - Method in class org.apache.kafka.streams.KafkaStreams
Set the listener which is triggered whenever a StateStore is 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
The context exposes this metadata for use in the processor.
setIsChangelogTopic(boolean) - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
 
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
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
The context exposes this metadata for use in the processor.
setPollException(KafkaException) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
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
The context exposes these metadata for use in the processor.
setStateListener(KafkaStreams.StateListener) - Method in class org.apache.kafka.streams.KafkaStreams
An app can set a single KafkaStreams.StateListener so that the app is notified when state changes.
setTimestamp(long) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
The context exposes this metadata for use in the processor.
setTopic(String) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
The context exposes this metadata for use in the processor.
setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.kafka.streams.KafkaStreams
setUncaughtExceptionHandler(StreamsUncaughtExceptionHandler) - Method in class org.apache.kafka.streams.KafkaStreams
Set the handler invoked when an internal stream thread throws an unexpected exception.
Short() - Static method in class org.apache.kafka.common.serialization.Serdes
 
SHORT - org.apache.kafka.clients.admin.ConfigEntry.ConfigType
 
SHORT - org.apache.kafka.common.config.ConfigDef.Type
 
SHORT - org.apache.kafka.common.config.ConfigDef.Width
 
ShortDeserializer - Class in org.apache.kafka.common.serialization
 
ShortDeserializer() - Constructor for class org.apache.kafka.common.serialization.ShortDeserializer
 
ShortSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.ShortSerde
 
ShortSerializer - Class in org.apache.kafka.common.serialization
 
ShortSerializer() - Constructor for class org.apache.kafka.common.serialization.ShortSerializer
 
shouldBeRebuilt(Map<String, Object>) - Method in interface org.apache.kafka.common.security.auth.SslEngineFactory
Returns true if SSLEngine needs 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 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 - org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
 
SHUTDOWN_CLIENT - org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
 
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 This buffer is "strict" in the sense that it will enforce the time bound or shut down.
SimpleHeaderConverter - Class in org.apache.kafka.connect.storage
A HeaderConverter that 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
 
SINK - 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 a SinkConnector to interact with the Kafka Connect runtime.
SinkRecord - Class in org.apache.kafka.connect.sink
SinkRecord is a ConnectRecord that has been read from Kafka and includes the kafkaOffset of the record in the Kafka topic-partition 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
 
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 to SinkTasks, 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.
SlidingWindows - Class in org.apache.kafka.streams.kstream
A sliding window used for aggregating events.
SnapshotNotFoundException - Exception in org.apache.kafka.common.errors
 
SnapshotNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.SnapshotNotFoundException
 
SnapshotNotFoundException(String, Throwable) - Constructor for exception 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 - org.apache.kafka.connect.health.ConnectorType
Identifies a source connector
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 clustes, where source is replicated 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 a SourceConnector to 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 by SourceTasks 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
 
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 - org.apache.kafka.common.security.auth.SecurityProtocol
SSL channel
SSL_CIPHER_SUITES_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_CIPHER_SUITES_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
 
SSL_CLIENT_AUTH_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
SSL_CLIENT_AUTH_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
Deprecated.
As of 1.0.0. This field will be removed in a future major release.
SSL_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 in org.apache.kafka.common.errors
This exception indicates that SSL handshake has failed.
SslAuthenticationException(String) - Constructor for exception org.apache.kafka.common.errors.SslAuthenticationException
 
SslAuthenticationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SslAuthenticationException
 
SslClientAuth - Enum 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 of SSLEngine object 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 - org.apache.kafka.common.ConsumerGroupState
 
StaleBrokerEpochException - Exception in org.apache.kafka.common.errors
 
StaleBrokerEpochException(String) - Constructor for exception org.apache.kafka.common.errors.StaleBrokerEpochException
 
StaleBrokerEpochException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.StaleBrokerEpochException
 
staleStoresEnabled() - Method in class org.apache.kafka.streams.StoreQueryParameters
Get the flag staleStores.
standbyHosts() - Method in class org.apache.kafka.streams.KeyQueryMetadata
Get the Kafka Streams instances that host the key as standbys.
standbyStateStoreNames() - Method in class org.apache.kafka.streams.state.StreamsMetadata
State stores owned by the instance as a standby replica
standbyTasks() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
standbyTopicPartitions() - Method in class org.apache.kafka.streams.state.StreamsMetadata
(Source) Topic partitions for which the instance acts as standby.
start() - Method in class org.apache.kafka.streams.KafkaStreams
Start the KafkaStreams instance 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(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.
startMs - Variable in class org.apache.kafka.streams.kstream.Window
 
startOn(long) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
Deprecated.
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 - Variable in class org.apache.kafka.common.metrics.stats.Rate
 
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 - Variable in class org.apache.kafka.streams.KafkaStreams
 
state() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
The consumer group state, or UNKNOWN if the state is too new for us to parse.
state() - Method in class org.apache.kafka.clients.admin.ConsumerGroupListing
Consumer Group state
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.streams.KafkaStreams
Return the current KafkaStreams.State of this KafkaStreams instance.
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
stateDir() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
 
stateDir() - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
Returns the state directory for the partition.
stateDir() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
stateDir() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the state directory for the partition.
stateDir() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
Returns the state directory for the partition.
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
Returns the list of States that are requested or empty if no states have been specified
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.
StateStoreContext - Interface in org.apache.kafka.streams.processor
State store context interface.
StateStoreMigratedException - Exception in org.apache.kafka.streams.errors
Indicates that the state store being queried is closed although the Kafka Streams state is RUNNING or REBALANCING.
StateStoreMigratedException(String) - Constructor for exception org.apache.kafka.streams.errors.StateStoreMigratedException
 
StateStoreMigratedException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.StateStoreMigratedException
 
stateStoreNames() - Method in class org.apache.kafka.streams.state.StreamsMetadata
State stores owned by the instance as an active replica
StateStoreNotAvailableException - Exception in org.apache.kafka.streams.errors
Indicates that the state store being queried is already closed.
StateStoreNotAvailableException(String) - Constructor for exception org.apache.kafka.streams.errors.StateStoreNotAvailableException
 
StateStoreNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.StateStoreNotAvailableException
 
STATIC_BROKER_CONFIG - 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
 
StickyAssignor - Class in org.apache.kafka.clients.consumer
The sticky assignor serves two purposes.
StickyAssignor() - Constructor for class org.apache.kafka.clients.consumer.StickyAssignor
 
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.
store(String, QueryableStoreType<T>) - Method in class org.apache.kafka.streams.KafkaStreams
Deprecated.
since 2.5 release; use KafkaStreams.store(StoreQueryParameters) instead
store(StoreQueryParameters<T>) - Method in class org.apache.kafka.streams.KafkaStreams
Get a facade wrapping the local StateStore instances with the provided StoreQueryParameters.
StoreBuilder<T extends StateStore> - Interface in org.apache.kafka.streams.state
Build a StateStore wrapped 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 - Variable in class org.apache.kafka.streams.kstream.Materialized
 
storeName - Variable in class org.apache.kafka.streams.kstream.StreamJoined
 
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
StoreQueryParameters allows 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 - Variable in class org.apache.kafka.streams.kstream.Materialized
 
StoreSupplier<T extends StateStore> - Interface in org.apache.kafka.streams.state
A state store supplier which can create one or more StateStore instances.
stream(String) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KStream from the specified topic.
stream(String, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KStream from the specified topic.
stream(Collection<String>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KStream from the specified topics.
stream(Collection<String>, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KStream from the specified topics.
stream(Pattern) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KStream from the specified topic pattern.
stream(Pattern, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KStream from the specified topic pattern.
STREAM_TIME - org.apache.kafka.streams.processor.PunctuationType
 
StreamJoined<K,​V1,​V2> - Class in org.apache.kafka.streams.kstream
Class used to configure the name of the join processor, the repartition topic name, state stores or state store names in Stream-Stream join.
StreamJoined(StreamJoined<K, V1, V2>) - Constructor for class org.apache.kafka.streams.kstream.StreamJoined
 
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 a Repartitioned instance 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
StreamsBuilder provide the high-level Kafka Streams DSL to specify a Kafka Streams topology.
StreamsBuilder() - Constructor for class org.apache.kafka.streams.StreamsBuilder
 
StreamsConfig - Class in org.apache.kafka.streams
Configuration for a KafkaStreams instance.
StreamsConfig(Map<?, ?>) - Constructor for class org.apache.kafka.streams.StreamsConfig
Create a new StreamsConfig using the given properties.
StreamsConfig(Map<?, ?>, boolean) - Constructor for class org.apache.kafka.streams.StreamsConfig
 
StreamsConfig.InternalConfig - Class in org.apache.kafka.streams
 
StreamsException - Exception in org.apache.kafka.streams.errors
StreamsException is the top-level exception type generated by Kafka Streams.
StreamsException(String) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
 
StreamsException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
 
StreamsException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
 
StreamsMetadata - Class in org.apache.kafka.streams.state
Represents the state of an instance (process) in a KafkaStreams application.
StreamsMetadata(HostInfo, Set<String>, Set<TopicPartition>, Set<String>, Set<TopicPartition>) - Constructor for class org.apache.kafka.streams.state.StreamsMetadata
 
StreamsMetrics - Interface in org.apache.kafka.streams
The Kafka Streams metrics interface for adding metric sensors and collecting metric values.
StreamsNotStartedException - Exception in org.apache.kafka.streams.errors
Indicates that Kafka Streams is in state CREATED and thus state stores cannot be queries yet.
StreamsNotStartedException(String) - Constructor for exception org.apache.kafka.streams.errors.StreamsNotStartedException
 
StreamsNotStartedException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.StreamsNotStartedException
 
StreamsRebalancingException - Exception in org.apache.kafka.streams.errors
Indicates that Kafka Streams is in state REBALANCING and thus cannot be queried by default.
StreamsRebalancingException(String) - Constructor for exception org.apache.kafka.streams.errors.StreamsRebalancingException
 
StreamsRebalancingException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.StreamsRebalancingException
 
StreamsUncaughtExceptionHandler - Interface in org.apache.kafka.streams.errors
 
StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse - Enum 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
 
STRING - org.apache.kafka.clients.admin.ConfigEntry.ConfigType
 
STRING - org.apache.kafka.common.config.ConfigDef.Type
 
STRING - 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
Converter and HeaderConverter implementation 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 for StringConverter instances.
StringConverterConfig(Map<String, ?>) - Constructor for class org.apache.kafka.connect.storage.StringConverterConfig
 
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 independent Schema.
Struct(Schema) - Constructor for class org.apache.kafka.connect.data.Struct
Create a new Struct for this Schema
STRUCT - org.apache.kafka.connect.data.Schema.Type
A structured record containing a set of named fields, each field using a fixed, independent Schema.
subject() - Method in interface org.apache.kafka.common.security.auth.Login
Returns the authenticated subject of this login context.
subscribe(String, Set<String>, ConfigChangeCallback) - Method in interface org.apache.kafka.common.config.provider.ConfigProvider
Subscribes to changes for the given keys at the given path (optional operation).
subscribe(Collection<String>) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
subscribe(Collection<String>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Subscribe to the given list of topics to get dynamically assigned partitions.
subscribe(Collection<String>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
subscribe(Collection<String>, ConsumerRebalanceListener) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
subscribe(Collection<String>, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Subscribe to the given list of topics to get dynamically assigned partitions.
subscribe(Collection<String>, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
subscribe(Pattern) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
subscribe(Pattern) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Subscribe to all topics matching specified pattern to get dynamically assigned partitions.
subscribe(Pattern) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
subscribe(Pattern, ConsumerRebalanceListener) - Method in interface org.apache.kafka.clients.consumer.Consumer
 
subscribe(Pattern, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Subscribe to all topics matching specified pattern to get dynamically assigned partitions.
subscribe(Pattern, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
subscription() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
subscription() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Get the current subscription.
subscription() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
Subscription(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
 
subscriptionUserData(Set<String>) - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
Return serialized data that will be included in the ConsumerPartitionAssignor.Subscription sent to the leader and can be leveraged in ConsumerPartitionAssignor.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.
SUBTRACT - 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.
Sum - Class in org.apache.kafka.common.metrics.stats
Deprecated.
since 2.4 . Use WindowedSum instead
Sum() - Constructor for class org.apache.kafka.common.metrics.stats.Sum
Deprecated.
 
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 with ConsumerPartitionAssignor.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.
suppress(Suppressed<? super K>) - Method in interface org.apache.kafka.streams.kstream.KTable
Suppress some updates from this changelog stream, determined by the supplied Suppressed configuration.
Suppressed<K> - Interface in org.apache.kafka.streams.kstream
 
Suppressed.BufferConfig<BC extends 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 a KTable for the specified topic.
table(String, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KTable for the specified topic.
table(String, Consumed<K, V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KTable for the specified topic.
table(String, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KTable for the specified topic.
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
 
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_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
 
TaskAssignmentException - Exception in org.apache.kafka.streams.errors
Indicates a run time error incurred while trying to assign stream tasks to threads.
TaskAssignmentException(String) - Constructor for exception org.apache.kafka.streams.errors.TaskAssignmentException
 
TaskAssignmentException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskAssignmentException
 
TaskAssignmentException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskAssignmentException
 
taskClass() - Method in class org.apache.kafka.connect.connector.Connector
Returns the Task implementation for this Connector.
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 most count configurations.
TaskCorruptedException - Exception in org.apache.kafka.streams.errors
Indicates a specific task is corrupted and need to be re-initialized.
TaskCorruptedException(Set<TaskId>) - Constructor for exception org.apache.kafka.streams.errors.TaskCorruptedException
 
TaskCorruptedException(Set<TaskId>, InvalidOffsetException) - Constructor for exception 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 class org.apache.kafka.streams.processor.api.MockProcessorContext
 
taskId() - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
Returns the task id.
taskId() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
taskId() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the task id.
taskId() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
Returns the task id.
taskId() - Method in class org.apache.kafka.streams.processor.TaskMetadata
 
TaskId - Class in org.apache.kafka.streams.processor
The task ID representation composed as topic group ID plus the assigned partition ID.
TaskId(int, int) - Constructor for class org.apache.kafka.streams.processor.TaskId
 
TaskIdFormatException - Exception in org.apache.kafka.streams.errors
Indicates a run time error incurred while trying parse the task id from the read string.
TaskIdFormatException(String) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
 
TaskIdFormatException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
 
TaskIdFormatException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
 
TaskMetadata - Class in org.apache.kafka.streams.processor
Represents the state of a single task running within a KafkaStreams application.
TaskMetadata(String, Set<TopicPartition>) - Constructor for class org.apache.kafka.streams.processor.TaskMetadata
 
TaskMigratedException - Exception in org.apache.kafka.streams.errors
Indicates that all tasks belongs to the thread have migrated to another thread.
TaskMigratedException(String) - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
 
TaskMigratedException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
 
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 of TaskState.
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
TestInputTopic is used to pipe records to topic in TopologyTestDriver.
TestOutputTopic<K,​V> - Class in org.apache.kafka.streams
TestOutputTopic is used to read records from a topic in TopologyTestDriver.
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 from TopologyTestDriver.
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 a TestRecord from a ConsumerRecord.
TestRecord(ProducerRecord<K, V>) - Constructor for class org.apache.kafka.streams.test.TestRecord
Create a TestRecord from a ProducerRecord.
TestRecord(V) - Constructor for class org.apache.kafka.streams.test.TestRecord
Create a record with null key.
thenApply(KafkaFuture.BaseFunction<T, R>) - Method in class org.apache.kafka.common.KafkaFuture
Returns a new KafkaFuture that, when this future completes normally, is executed with this futures's result as the argument to the supplied function.
thenApply(KafkaFuture.Function<T, R>) - Method in class org.apache.kafka.common.KafkaFuture
 
thisStoreSupplier - Variable in class org.apache.kafka.streams.kstream.StreamJoined
 
ThreadMetadata - Class in org.apache.kafka.streams.processor
Represents the state of a single thread running within a KafkaStreams application.
ThreadMetadata(String, String, String, String, Set<String>, String, Set<TaskMetadata>, Set<TaskMetadata>) - Constructor for class org.apache.kafka.streams.processor.ThreadMetadata
 
threadName() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
threads - Variable in class org.apache.kafka.streams.KafkaStreams
 
threadState() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
throttleTimeMs() - Method in exception org.apache.kafka.common.errors.ThrottlingQuotaExceededException
 
ThrottlingQuotaExceededException - Exception in org.apache.kafka.common.errors
Exception thrown if an operation on a resource exceeds the throttling quota.
ThrottlingQuotaExceededException(int, String) - Constructor for exception org.apache.kafka.common.errors.ThrottlingQuotaExceededException
 
ThrottlingQuotaExceededException(String) - Constructor for exception org.apache.kafka.common.errors.ThrottlingQuotaExceededException
 
through(String) - Method in interface org.apache.kafka.streams.kstream.KStream
Deprecated.
since 2.6; use KStream.repartition() instead
through(String, Produced<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Deprecated.
since 2.6; use KStream.repartition(Repartitioned) instead
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
 
timeDifferenceMs() - Method in class org.apache.kafka.streams.kstream.SlidingWindows
 
timeout(long) - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
Set the timeout in milliseconds.
TimeoutException - Exception in org.apache.kafka.common.errors
Indicates that a request timed out.
TimeoutException() - Constructor for exception org.apache.kafka.common.errors.TimeoutException
 
TimeoutException(String) - Constructor for exception org.apache.kafka.common.errors.TimeoutException
 
TimeoutException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.TimeoutException
 
TimeoutException(Throwable) - Constructor for exception org.apache.kafka.common.errors.TimeoutException
 
timeoutMs - Variable in class org.apache.kafka.clients.admin.AbstractOptions
 
timeoutMs() - Method in class org.apache.kafka.clients.admin.AbstractOptions
The timeout in milliseconds for this operation or null if 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 or null if 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 or null if 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 or null if 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 or null if 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 or null if 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 or null if 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 or null if 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 or null if 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 or null if 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 or null if 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 or null if the default api timeout for the AdminClient should be used.
timestamp - Variable in class org.apache.kafka.streams.processor.To
 
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
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 class org.apache.kafka.connect.connector.ConnectRecord
 
timestamp() - Method in class org.apache.kafka.connect.mirror.Heartbeat
 
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
The timestamp attached to the forwarded record.
timestamp() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
timestamp() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the current timestamp.
timestamp() - Method in interface org.apache.kafka.streams.processor.RecordContext
 
timestamp() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
 
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_KEY - Static variable in class org.apache.kafka.connect.mirror.Heartbeat
 
TimestampedBytesStore - Interface in org.apache.kafka.streams.state
 
timestampedKeyValueStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
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 a StoreBuilder that can be used to build a TimestampedKeyValueStore.
timestampedWindowStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
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 a StoreBuilder that can be used to build a TimestampedWindowStore.
timestampExtractor - Variable in class org.apache.kafka.streams.kstream.Consumed
 
TimestampExtractor - Interface in org.apache.kafka.streams.processor
An interface that allows the Kafka Streams framework to extract a timestamp from an instance of ConsumerRecord.
timestampType() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The timestamp type of this record
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
TimeWindowedCogroupKStream is an abstraction of a windowed record stream of KeyValue pairs.
TimeWindowedDeserializer<T> - Class in org.apache.kafka.streams.kstream
The inner serde class can be specified by setting the property StreamsConfig.DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS or StreamsConfig.DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS if the no-arg constructor is called and hence it is not passed during initialization.
TimeWindowedDeserializer() - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
 
TimeWindowedDeserializer(Deserializer<T>) - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
Deprecated.
TimeWindowedDeserializer(Deserializer<T>, Long) - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
 
TimeWindowedKStream<K,​V> - Interface in org.apache.kafka.streams.kstream
TimeWindowedKStream is an abstraction of a windowed record stream of KeyValue pairs.
TimeWindowedSerde() - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
 
TimeWindowedSerde(Serde<T>) - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
Deprecated.
TimeWindowedSerde(Serde<T>, long) - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
 
timeWindowedSerdeFrom(Class<T>) - Static method in class org.apache.kafka.streams.kstream.WindowedSerdes
Deprecated.
timeWindowedSerdeFrom(Class<T>, long) - Static method in class org.apache.kafka.streams.kstream.WindowedSerdes
Construct a TimeWindowedSerde object to deserialize changelog topic for the specified inner class type and window size.
TimeWindowedSerializer<T> - Class in org.apache.kafka.streams.kstream
The inner serde class can be specified by setting the property StreamsConfig.DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS or StreamsConfig.DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS if the no-arg constructor is called and hence it is not passed during initialization.
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 DefaultPartitioner.
to(String, Produced<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Materialize this stream to a topic using the provided Produced instance.
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 DefaultPartitioner.
to(TopicNameExtractor<K, V>, Produced<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Dynamically materialize this stream to topics using the provided Produced instance.
To - Class in org.apache.kafka.streams.processor
This class is used to provide the optional parameters when sending output records to downstream processor using ProcessorContext.forward(Object, Object, To).
To(To) - Constructor for class org.apache.kafka.streams.processor.To
 
toArray() - Method in interface org.apache.kafka.common.header.Headers
Returns all headers as an array, in the order they were added in.
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
 
toConnectData(String, byte[]) - Method in interface org.apache.kafka.connect.storage.Converter
Convert a native object to a Kafka Connect data object.
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, 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 a Header object.
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 a KStream to 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.Resource
Create a filter which matches only this Resource.
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
The TokenBucket is a MeasurableStat implementing a token bucket algorithm that is usable within a Sensor.
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
 
tokenValue() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
Return the (always non-null) token value
toLogical(Schema, byte[]) - Static method in class org.apache.kafka.connect.data.Decimal
 
toLogical(Schema, int) - Static method in class org.apache.kafka.connect.data.Date
 
toLogical(Schema, int) - Static method in class org.apache.kafka.connect.data.Time
 
toLogical(Schema, long) - Static method in class org.apache.kafka.connect.data.Timestamp
 
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.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.processor.api.RecordMetadata
 
topic() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
topic() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the topic name of the current input record; could be null if it is not available (for example, if this method is invoked from the punctuate call).
topic() - Method in interface org.apache.kafka.streams.processor.RecordContext
 
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 - org.apache.kafka.common.config.ConfigResource.Type
 
TOPIC - org.apache.kafka.common.resource.ResourceType
A Kafka topic.
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.
TopicAuthorizationException - Exception in org.apache.kafka.common.errors
 
TopicAuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.TopicAuthorizationException
 
TopicAuthorizationException(String, Set<String>) - Constructor for exception org.apache.kafka.common.errors.TopicAuthorizationException
 
TopicAuthorizationException(Set<String>) - Constructor for exception org.apache.kafka.common.errors.TopicAuthorizationException
 
topicConfig - Variable in class org.apache.kafka.streams.kstream.Materialized
 
topicConfig - Variable in class org.apache.kafka.streams.kstream.StreamJoined
 
TopicConfig - Class in org.apache.kafka.common.config
Keys that can be used to configure a topic.
TopicConfig() - Constructor for class org.apache.kafka.common.config.TopicConfig
 
TopicDeletionDisabledException - Exception in org.apache.kafka.common.errors
 
TopicDeletionDisabledException() - Constructor for exception org.apache.kafka.common.errors.TopicDeletionDisabledException
 
TopicDeletionDisabledException(String) - Constructor for exception org.apache.kafka.common.errors.TopicDeletionDisabledException
 
TopicDescription - Class in org.apache.kafka.clients.admin
A detailed description of a single topic in the cluster.
TopicDescription(String, boolean, List<TopicPartitionInfo>) - Constructor for class org.apache.kafka.clients.admin.TopicDescription
Create an instance with the specified parameters.
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
 
TopicExistsException - Exception in org.apache.kafka.common.errors
 
TopicExistsException(String) - Constructor for exception org.apache.kafka.common.errors.TopicExistsException
 
TopicExistsException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.TopicExistsException
 
topicGroupId - Variable in class org.apache.kafka.streams.processor.TaskId
The ID of the topic group.
topicId() - Method in class org.apache.kafka.clients.admin.CreateTopicsResult.TopicMetadataAndConfig
 
topicId() - Method in class org.apache.kafka.clients.admin.TopicDescription
 
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
 
topicIds() - Method in class org.apache.kafka.common.Cluster
 
TopicListing - Class in org.apache.kafka.clients.admin
A listing of a topic in the cluster.
TopicListing(String, boolean) - Constructor for class org.apache.kafka.clients.admin.TopicListing
Create an instance with the specified parameters.
topicNameExtractor() - Method in interface org.apache.kafka.streams.TopologyDescription.Sink
The TopicNameExtractor class 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.
topicPartition() - Method in class org.apache.kafka.connect.mirror.Checkpoint
 
TopicPartition - Class in org.apache.kafka.common
A topic name and partition number
TopicPartition(String, int) - Constructor for class org.apache.kafka.common.TopicPartition
 
TopicPartitionInfo - Class in org.apache.kafka.common
A class containing leadership, replicas and ISR information for a topic partition.
TopicPartitionInfo(int, Node, List<Node>, List<Node>) - Constructor for class org.apache.kafka.common.TopicPartitionInfo
Create an instance of this class with the provided parameters.
TopicPartitionReplica - Class in org.apache.kafka.common
The topic name, partition number and the brokerId of the replica
TopicPartitionReplica(String, int, int) - Constructor for class org.apache.kafka.common.TopicPartitionReplica
 
topicPartitions() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsOptions
Returns a list of topic partitions to add as part of the result.
topicPartitions() - Method in class org.apache.kafka.clients.admin.MemberAssignment
The topic partitions assigned to a group member.
topicPartitions() - Method in class org.apache.kafka.streams.processor.TaskMetadata
 
topicPartitions() - Method in class org.apache.kafka.streams.state.StreamsMetadata
Topic partitions consumed by the instance as an active replica
topicPartitions(List<TopicPartition>) - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsOptions
Set the topic partitions to list as part of the result.
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 with StreamsConfig.TOPIC_PREFIX used 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() - Method in interface org.apache.kafka.streams.TopologyDescription.Source
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 interface org.apache.kafka.connect.mirror.ReplicationPolicy
Source cluster alias of given remote topic, e.g.
Topology - Class in org.apache.kafka.streams
A logical representation of a ProcessorTopology.
Topology() - Constructor for class org.apache.kafka.streams.Topology
 
TOPOLOGY_OPTIMIZATION - Static variable in class org.apache.kafka.streams.StreamsConfig
Deprecated.
TOPOLOGY_OPTIMIZATION_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
topology.optimization
Topology.AutoOffsetReset - Enum in org.apache.kafka.streams
Sets the auto.offset.reset configuration when adding a source processor or when creating KStream or KTable via StreamsBuilder.
TopologyDescription - Interface in org.apache.kafka.streams
A meta representation of a topology.
TopologyDescription.GlobalStore - Interface in org.apache.kafka.streams
Represents a global 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 a Topology.
TopologyException - Exception in org.apache.kafka.streams.errors
Indicates a pre run time error occurred while parsing the logical topology to construct the physical processor topology.
TopologyException(String) - Constructor for exception org.apache.kafka.streams.errors.TopologyException
 
TopologyException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TopologyException
 
TopologyException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TopologyException
 
TopologyTestDriver - Class in org.apache.kafka.streams
This class makes it easier to write tests to verify the behavior of topologies created with Topology or StreamsBuilder.
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, long) - Constructor for class org.apache.kafka.streams.TopologyTestDriver
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 a KStream.
toStream(KeyValueMapper<? super K, ? super V, ? extends KR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Convert this changelog stream to a KStream using the given KeyValueMapper to 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 a KStream using the given KeyValueMapper to select the new key.
toStream(Named) - Method in interface org.apache.kafka.streams.kstream.KTable
Convert this changelog stream to a KStream.
toString() - Method in class org.apache.kafka.clients.admin.AlterConfigOp
 
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.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
 
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.FinalizedVersionRange
 
toString() - Method in class org.apache.kafka.clients.admin.ListOffsetsResult.ListOffsetsResultInfo
 
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.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.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.UserScramCredentialsDescription
 
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.ConsumerRecord
 
toString() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
 
toString() - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
 
toString() - Method in class org.apache.kafka.clients.producer.ProducerRecord
 
toString() - Method in class org.apache.kafka.clients.producer.RecordMetadata
 
toString() - Method in class org.apache.kafka.common.acl.AccessControlEntry
 
toString() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
 
toString() - Method in class org.apache.kafka.common.acl.AclBinding
 
toString() - Method in class org.apache.kafka.common.acl.AclBindingFilter
 
toString() - Method in class org.apache.kafka.common.Cluster
 
toString() - Method in class org.apache.kafka.common.ClusterResource
 
toString() - Method in class org.apache.kafka.common.config.ConfigDef.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.NonEmptyString
 
toString() - Method in class org.apache.kafka.common.config.ConfigDef.NonEmptyStringWithoutControlChars
 
toString() - Method in class org.apache.kafka.common.config.ConfigDef.NonNullValidator
 
toString() - Method in class org.apache.kafka.common.config.ConfigDef.Range
 
toString() - Method in class org.apache.kafka.common.config.ConfigDef.ValidList
 
toString() - Method in class org.apache.kafka.common.config.ConfigDef.ValidString
 
toString() - Method in class org.apache.kafka.common.config.ConfigResource
 
toString() - Method in class org.apache.kafka.common.config.ConfigValue
 
toString() - Method in enum org.apache.kafka.common.ConsumerGroupState
 
toString() - Method in class org.apache.kafka.common.Endpoint
 
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 org.apache.kafka.common.metrics.QuotaViolationException
 
toString() - Method in class org.apache.kafka.common.metrics.stats.Histogram
 
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.ResourceFilter
 
toString() - Method in class org.apache.kafka.common.resource.ResourcePattern
 
toString() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
 
toString() - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
 
toString() - Method in class org.apache.kafka.common.security.auth.SaslExtensions
 
toString() - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
 
toString() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
 
toString() - Method in class org.apache.kafka.common.TopicPartition
 
toString() - Method in class org.apache.kafka.common.TopicPartitionInfo
 
toString() - Method in class org.apache.kafka.common.TopicPartitionReplica
 
toString() - Method in class org.apache.kafka.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 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 class org.apache.kafka.server.authorizer.Action
 
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.MockProcessorContext.CapturedForward
 
toString() - Method in class org.apache.kafka.streams.processor.api.Record
 
toString() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedForward
 
toString() - Method in class org.apache.kafka.streams.processor.TaskId
 
toString() - Method in class org.apache.kafka.streams.processor.TaskMetadata
 
toString() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
toString() - Method in class org.apache.kafka.streams.state.HostInfo
 
toString() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
toString() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
 
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 a KStream to system out.
toTable() - Method in interface org.apache.kafka.streams.kstream.KStream
Convert this stream to a KTable.
toTable(Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KStream
Convert this stream to a KTable.
toTable(Named) - Method in interface org.apache.kafka.streams.kstream.KStream
Convert this stream to a KTable.
toTable(Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KStream
Convert this stream to a KTable.
Total - Class in org.apache.kafka.common.metrics.stats
Deprecated.
since 2.4 . Use CumulativeSum instead.
Total() - Constructor for class org.apache.kafka.common.metrics.stats.Total
Deprecated.
 
totalCount() - Method in class org.apache.kafka.clients.admin.NewPartitions
The total number of partitions after the operation succeeds.
TRACE - org.apache.kafka.common.metrics.Sensor.RecordingLevel
 
TRACE_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
The TRACE level designates finer-grained informational events than the DEBUG level.
traceMessage() - Method in class org.apache.kafka.connect.health.AbstractState
The error message associated with the connector or task.
TRANSACTION_TIMEOUT_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
transaction.timeout.ms
TRANSACTION_TIMEOUT_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
 
transactionAborted() - Method in class org.apache.kafka.clients.producer.MockProducer
 
TransactionAbortedException - Exception 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 org.apache.kafka.common.errors.TransactionAbortedException
 
TransactionAbortedException(String) - Constructor for exception org.apache.kafka.common.errors.TransactionAbortedException
 
TransactionAbortedException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.TransactionAbortedException
 
TRANSACTIONAL_ID - org.apache.kafka.common.resource.ResourceType
A transactional ID.
TRANSACTIONAL_ID_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
transactional.id
TRANSACTIONAL_ID_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
 
TransactionalIdAuthorizationException - Exception in org.apache.kafka.common.errors
 
TransactionalIdAuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.TransactionalIdAuthorizationException
 
transactionCommitted() - Method in class org.apache.kafka.clients.producer.MockProducer
 
TransactionCoordinatorFencedException - Exception in org.apache.kafka.common.errors
 
TransactionCoordinatorFencedException(String) - Constructor for exception org.apache.kafka.common.errors.TransactionCoordinatorFencedException
 
TransactionCoordinatorFencedException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.TransactionCoordinatorFencedException
 
transactionInFlight() - Method in class org.apache.kafka.clients.producer.MockProducer
 
transactionInitialized() - Method in class org.apache.kafka.clients.producer.MockProducer
 
transform(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigTransformer
Transforms the given configuration data by using the ConfigProvider instances to look up values to replace the variables in the pattern.
transform(K, V) - Method in interface org.apache.kafka.streams.kstream.Transformer
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(TransformerSupplier<? super K, ? super V, KeyValue<K1, V1>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform each record of the input stream into zero or one record in the output stream (both key and value type can be altered arbitrarily).
transform(TransformerSupplier<? super K, ? super V, KeyValue<K1, V1>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform each record of the input stream into zero or one record in the output stream (both key and value type can be altered arbitrarily).
transform(V) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
Transform the given value to a new value.
Transformation<R extends ConnectRecord<R>> - Interface in org.apache.kafka.connect.transforms
Single message transformation for Kafka Connect record types.
Transformer<K,​V,​R> - Interface in org.apache.kafka.streams.kstream
The Transformer interface is for stateful mapping of an input record to zero, one, or multiple new output records (both key and value type can be altered arbitrarily).
TransformerSupplier<K,​V,​R> - Interface in org.apache.kafka.streams.kstream
A TransformerSupplier interface which can create one or more Transformer instances.
transformValues(ValueTransformerSupplier<? super V, ? extends VR>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into a new value (with possibly a new type) of the output record.
transformValues(ValueTransformerSupplier<? super V, ? extends VR>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into a new value (with possibly a new type) of the output record.
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into a new value (with possibly a new type) of the output record.
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into 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 new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type), with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
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 new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type), with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into a new value (with possibly a new type) of the output record.
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into 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
Translate 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 enum 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 the ConverterConfig.TYPE_CONFIG configuration.
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
 

U

UnacceptableCredentialException - Exception 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 org.apache.kafka.common.errors.UnacceptableCredentialException
Constructor
UnacceptableCredentialException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnacceptableCredentialException
 
unauthorizedTopics() - Method in class org.apache.kafka.common.Cluster
 
unauthorizedTopics() - Method in exception 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).
UNCLEAN - 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
 
UniformStickyPartitioner - Class in org.apache.kafka.clients.producer
The partitioning strategy: If a partition is specified in the record, use it Otherwise choose the sticky partition that changes when the batch is full.
UniformStickyPartitioner() - Constructor for class org.apache.kafka.clients.producer.UniformStickyPartitioner
 
unit - Variable in class org.apache.kafka.common.metrics.stats.Rate
 
unitName() - Method in class org.apache.kafka.common.metrics.stats.Rate
 
UNKNOWN - org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
 
UNKNOWN - org.apache.kafka.clients.admin.ConfigEntry.ConfigType
 
UNKNOWN - org.apache.kafka.clients.admin.ScramMechanism
 
UNKNOWN - org.apache.kafka.common.acl.AclOperation
Represents any AclOperation which this client cannot understand, perhaps because this client is too old.
UNKNOWN - org.apache.kafka.common.acl.AclPermissionType
Represents any AclPermissionType which this client cannot understand, perhaps because this client is too old.
UNKNOWN - org.apache.kafka.common.config.ConfigResource.Type
 
UNKNOWN - org.apache.kafka.common.ConsumerGroupState
 
UNKNOWN - org.apache.kafka.common.resource.PatternType
Represents any PatternType which this client cannot understand, perhaps because this client is too old.
UNKNOWN - org.apache.kafka.common.resource.ResourceType
Represents any ResourceType which this client cannot understand, perhaps because this client is too old.
UNKNOWN - 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
UnknownLeaderEpochException - Exception in org.apache.kafka.common.errors
The request contained a leader epoch which is larger than that on the broker that received the request.
UnknownLeaderEpochException(String) - Constructor for exception org.apache.kafka.common.errors.UnknownLeaderEpochException
 
UnknownLeaderEpochException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownLeaderEpochException
 
UnknownMemberIdException - Exception in org.apache.kafka.common.errors
 
UnknownMemberIdException() - Constructor for exception org.apache.kafka.common.errors.UnknownMemberIdException
 
UnknownMemberIdException(String) - Constructor for exception org.apache.kafka.common.errors.UnknownMemberIdException
 
UnknownMemberIdException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownMemberIdException
 
UnknownMemberIdException(Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownMemberIdException
 
UnknownProducerIdException - Exception in org.apache.kafka.common.errors
This exception is raised by the broker if it could not locate the producer metadata associated with the producerId in question.
UnknownProducerIdException(String) - Constructor for exception org.apache.kafka.common.errors.UnknownProducerIdException
 
UnknownServerException - Exception in org.apache.kafka.common.errors
An error occurred on the server for which the client doesn't have a corresponding error code.
UnknownServerException() - Constructor for exception org.apache.kafka.common.errors.UnknownServerException
 
UnknownServerException(String) - Constructor for exception org.apache.kafka.common.errors.UnknownServerException
 
UnknownServerException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownServerException
 
UnknownServerException(Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownServerException
 
UnknownStateStoreException - Exception 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 org.apache.kafka.streams.errors.UnknownStateStoreException
 
UnknownStateStoreException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.UnknownStateStoreException
 
UnknownTopicIdException - Exception in org.apache.kafka.common.errors
 
UnknownTopicIdException(String) - Constructor for exception org.apache.kafka.common.errors.UnknownTopicIdException
 
UnknownTopicOrPartitionException - Exception in org.apache.kafka.common.errors
This topic/partition doesn't exist.
UnknownTopicOrPartitionException() - Constructor for exception org.apache.kafka.common.errors.UnknownTopicOrPartitionException
 
UnknownTopicOrPartitionException(String) - Constructor for exception org.apache.kafka.common.errors.UnknownTopicOrPartitionException
 
UnknownTopicOrPartitionException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownTopicOrPartitionException
 
UnknownTopicOrPartitionException(Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownTopicOrPartitionException
 
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.KafkaAdminClient
 
UnregisterBrokerOptions - Class in org.apache.kafka.clients.admin
UnregisterBrokerOptions() - Constructor for class org.apache.kafka.clients.admin.UnregisterBrokerOptions
 
UnregisterBrokerResult - Class in org.apache.kafka.clients.admin
UnstableOffsetCommitException - Exception in org.apache.kafka.common.errors
Exception thrown when there are unstable offsets for the requested topic partitions.
UnstableOffsetCommitException(String) - Constructor for exception 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 with KafkaConsumer.subscribe(Collection) or KafkaConsumer.subscribe(Pattern).
unsubscribe() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
unsubscribe(String, Set<String>, ConfigChangeCallback) - Method in interface org.apache.kafka.common.config.provider.ConfigProvider
Unsubscribes to changes for the given keys at the given path (optional operation).
unsubscribeAll() - Method in interface org.apache.kafka.common.config.provider.ConfigProvider
Clears all subscribers (optional operation).
UnsupportedByAuthenticationException - Exception in org.apache.kafka.common.errors
Authentication mechanism does not support the requested function.
UnsupportedByAuthenticationException(String) - Constructor for exception org.apache.kafka.common.errors.UnsupportedByAuthenticationException
 
UnsupportedByAuthenticationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnsupportedByAuthenticationException
 
UnsupportedCompressionTypeException - Exception in org.apache.kafka.common.errors
The requesting client does not support the compression type of given partition.
UnsupportedCompressionTypeException(String) - Constructor for exception org.apache.kafka.common.errors.UnsupportedCompressionTypeException
 
UnsupportedCompressionTypeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnsupportedCompressionTypeException
 
UnsupportedForMessageFormatException - Exception in org.apache.kafka.common.errors
The message format version does not support the requested function.
UnsupportedForMessageFormatException(String) - Constructor for exception org.apache.kafka.common.errors.UnsupportedForMessageFormatException
 
UnsupportedForMessageFormatException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnsupportedForMessageFormatException
 
UnsupportedSaslMechanismException - Exception in org.apache.kafka.common.errors
This exception indicates that the SASL mechanism requested by the client is not enabled on the broker.
UnsupportedSaslMechanismException(String) - Constructor for exception org.apache.kafka.common.errors.UnsupportedSaslMechanismException
 
UnsupportedSaslMechanismException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnsupportedSaslMechanismException
 
UnsupportedVersionException - Exception in org.apache.kafka.common.errors
Indicates that a request API or version needed by the client is not supported by the broker.
UnsupportedVersionException(String) - Constructor for exception org.apache.kafka.common.errors.UnsupportedVersionException
 
UnsupportedVersionException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnsupportedVersionException
 
until(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Deprecated.
since 2.1. Use JoinWindows.grace(Duration) instead.
until(long) - Method in class org.apache.kafka.streams.kstream.SessionWindows
Deprecated.
since 2.1. Use Materialized.retention or directly configure the retention in a store supplier and use Materialized.as(SessionBytesStoreSupplier).
until(long) - Method in class org.apache.kafka.streams.kstream.TimeWindows
Deprecated.
since 2.1. Use Materialized.retention or directly configure the retention in a store supplier and use Materialized.as(WindowBytesStoreSupplier).
until(long) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
Deprecated.
since 2.1.
until(long) - Method in class org.apache.kafka.streams.kstream.Windows
Deprecated.
since 2.1. Use Materialized.withRetention(Duration) or directly configure the retention in a store supplier and use Materialized.as(WindowBytesStoreSupplier).
untilTimeLimit(Duration, Suppressed.BufferConfig) - Static method in interface org.apache.kafka.streams.kstream.Suppressed
Configure the suppression to wait timeToWaitForMoreEvents amount 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
 
update(SampledStat.Sample, MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Avg
 
update(SampledStat.Sample, MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Frequencies
 
update(SampledStat.Sample, MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Max
 
update(SampledStat.Sample, MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Min
 
update(SampledStat.Sample, MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Percentiles
 
update(SampledStat.Sample, MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
 
update(SampledStat.Sample, MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.WindowedCount
 
update(SampledStat.Sample, MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.WindowedSum
 
update(To) - Method in class org.apache.kafka.streams.processor.To
 
updateBeginningOffsets(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
updateClusterMetadata(Cluster) - Method in interface org.apache.kafka.server.quota.ClientQuotaCallback
Metadata update callback that is invoked whenever UpdateMetadata request is received from the controller.
updateEndOffsets(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
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.KafkaAdminClient
 
UpdateFeaturesOptions - Class in org.apache.kafka.clients.admin
UpdateFeaturesOptions() - Constructor for class org.apache.kafka.clients.admin.UpdateFeaturesOptions
 
UpdateFeaturesResult - Class in org.apache.kafka.clients.admin
updatePartitions(String, List<PartitionInfo>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
updateQuota(ClientQuotaType, ClientQuotaEntity, double) - Method in interface org.apache.kafka.server.quota.ClientQuotaCallback
Quota configuration update callback that is invoked when quota configuration for an entity is updated in ZooKeeper.
UPGRADE_FROM_0100 - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "upgrade.from" for upgrading an application from version 0.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 version 0.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 version 0.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 version 0.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 version 1.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 version 1.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 version 2.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 version 2.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 version 2.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 version 2.3.x.
UPGRADE_FROM_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
upgrade.from
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
Find 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
Find 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 interface org.apache.kafka.connect.mirror.ReplicationPolicy
Name of topic on the source cluster, e.g.
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
 
UsePreviousTimeOnInvalidTimestamp - Class in org.apache.kafka.streams.processor
Deprecated.
since 2.5. Use UsePartitionTimeOnInvalidTimestamp instead
UsePreviousTimeOnInvalidTimestamp() - Constructor for class org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestamp
Deprecated.
 
user - Variable in class org.apache.kafka.clients.admin.UserScramCredentialAlteration
 
user() - Method in class org.apache.kafka.clients.admin.UserScramCredentialAlteration
 
USER - 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.
UserScramCredentialAlteration(String) - Constructor for class org.apache.kafka.clients.admin.UserScramCredentialAlteration
 
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 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
 
UUIDDeserializer - Class in org.apache.kafka.common.serialization
We are converting the byte array to String before deserializing to UUID.
UUIDDeserializer() - Constructor for class org.apache.kafka.common.serialization.UUIDDeserializer
 
UUIDSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.UUIDSerde
 
UUIDSerializer - Class in org.apache.kafka.common.serialization
We are converting UUID to String before serializing.
UUIDSerializer() - Constructor for class org.apache.kafka.common.serialization.UUIDSerializer
 

V

valid() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsResult
Returns a future which yields just the valid listings.
valid(String) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
Validates a specific extension in the original inputExtensions map
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(String) - Static method in class org.apache.kafka.streams.kstream.Named
 
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(ConnectorClientConfigRequest) - Method in interface org.apache.kafka.connect.connector.policy.ConnectorClientConfigOverridePolicy
Worker will invoke this while constructing the producer for the SourceConnectors, DLQ for SinkConnectors and the consumer for the SinkConnectors to validate if all of 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 a PolicyViolationException with a suitable error message if the alter configs request parameters for the provided resource do not satisfy this policy.
validate(CreateTopicPolicy.RequestMetadata) - Method in interface org.apache.kafka.server.policy.CreateTopicPolicy
Validate the request parameters and throw a PolicyViolationException with a suitable error message if the create topics request parameters for the provided topic do not satisfy this policy.
validateAll(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
 
validatedExtensions() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
 
validateOnly() - Method in class org.apache.kafka.clients.admin.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(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.
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.
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
 
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 org.apache.kafka.common.ElectionType
 
value - Variable in class org.apache.kafka.common.metrics.stats.SampledStat.Sample
 
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 interface org.apache.kafka.common.Metric
Deprecated.
As of 1.0.0, use Metric.metricValue() instead. This will be removed in a future major release.
value() - Method in class org.apache.kafka.common.metrics.KafkaMetric
Deprecated.
value() - Method in exception 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
The b64token value 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.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.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 - org.apache.kafka.connect.storage.ConverterType
 
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 a KeyValue with a timestamp.
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,​VR> - Interface in org.apache.kafka.streams.kstream
The ValueJoiner interface for joining two values into a new value of arbitrary type.
ValueMapper<V,​VR> - Interface in org.apache.kafka.streams.kstream
The ValueMapper interface for mapping a value to a new value of arbitrary type.
ValueMapperWithKey<K,​V,​VR> - Interface in org.apache.kafka.streams.kstream
The ValueMapperWithKey interface for mapping a value to a new value of arbitrary type.
valueOf(byte) - Static method in enum org.apache.kafka.common.ElectionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.clients.admin.AlterConfigOp.OpType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.clients.admin.ConfigEntry.ConfigType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.clients.admin.ScramMechanism
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.clients.consumer.OffsetResetStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.acl.AclOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.acl.AclPermissionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.config.ConfigDef.Importance
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.config.ConfigDef.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.config.ConfigDef.Width
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.config.ConfigResource.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.config.SslClientAuth
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.ConsumerGroupState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.ElectionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.IsolationLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.metrics.Sensor.RecordingLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.metrics.stats.Percentiles.BucketSizing
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.resource.PatternType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.resource.ResourceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.connect.data.Schema.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.connect.health.ConnectorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.connect.storage.ConverterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.server.authorizer.AuthorizationResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.server.quota.ClientQuotaType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.KafkaStreams.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.processor.PunctuationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.Topology.AutoOffsetReset
Returns the enum constant of this type 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 org.apache.kafka.clients.admin.AlterConfigOp.OpType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.kafka.clients.admin.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 from TopicPartitionReplica to KafkaFuture which 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 org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.clients.admin.ConfigEntry.ConfigType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.kafka.clients.admin.CreateAclsResult
Return a map from ACL bindings to futures which can be used to check the status of the creation of each ACL binding.
values() - Method in class org.apache.kafka.clients.admin.CreatePartitionsResult
Return a map from topic names to futures, which can be used to check the status of individual partition creations.
values() - Method in class org.apache.kafka.clients.admin.CreateTopicsResult
Return a map from topic names to futures, which can be used to check the status of individual topic creations.
values() - Method in class org.apache.kafka.clients.admin.DeleteAclsResult.FilterResults
Return a list of delete ACLs results for a given filter.
values() - Method in class org.apache.kafka.clients.admin.DeleteAclsResult
Return a map from acl filters to futures which can be used to check the status of the deletions by each filter.
values() - Method in class org.apache.kafka.clients.admin.DeleteTopicsResult
Return a map from topic names to futures which can be used to check the status of individual deletions.
values() - Method in class org.apache.kafka.clients.admin.DescribeAclsResult
Return a future containing the ACLs requested.
values() - Method in class org.apache.kafka.clients.admin.DescribeConfigsResult
Return a map from resources to futures which can be used to check the status of the configuration for each resource.
values() - Method in class org.apache.kafka.clients.admin.DescribeLogDirsResult
Deprecated.
Deprecated Since Kafka 2.7. Use DescribeLogDirsResult.descriptions().
values() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult
Return a map from replica to future which can be used to check the log directory information of individual replicas
values() - Method in class org.apache.kafka.clients.admin.DescribeTopicsResult
Return a map from topic names to futures which can be used to check the status of individual topics.
values() - Static method in enum org.apache.kafka.clients.admin.ScramMechanism
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.kafka.clients.admin.UpdateFeaturesResult
 
values() - Static method in enum org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.clients.consumer.OffsetResetStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.acl.AclOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.acl.AclPermissionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.kafka.common.config.AbstractConfig
 
values() - Static method in enum org.apache.kafka.common.config.ConfigDef.Importance
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.config.ConfigDef.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.config.ConfigDef.Width
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.config.ConfigResource.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.config.SslClientAuth
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.ConsumerGroupState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.ElectionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.IsolationLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.metrics.Sensor.RecordingLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.metrics.stats.Percentiles.BucketSizing
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.resource.PatternType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.resource.ResourceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.connect.data.Schema.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.connect.health.ConnectorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.connect.storage.ConverterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.server.authorizer.AuthorizationResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.server.quota.ClientQuotaType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.streams.errors.StreamsUncaughtExceptionHandler.StreamThreadExceptionResponse
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.streams.KafkaStreams.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.streams.processor.PunctuationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.streams.Topology.AutoOffsetReset
Returns an array containing the constants of this enum type, 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 org.apache.kafka.common.config.SslClientAuth
 
Values.Parser - Class in org.apache.kafka.connect.data
 
Values.SchemaDetector - Class in org.apache.kafka.connect.data
 
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 - Variable in class org.apache.kafka.streams.kstream.Consumed
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.Grouped
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.Joined
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.Materialized
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.Produced
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.Repartitioned
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.Serialized
Deprecated.
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.StreamJoined
 
valueSerde() - Method in class org.apache.kafka.streams.kstream.Joined
 
valueSerde() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
 
valueSerde() - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
Returns the default value serde.
valueSerde() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
 
valueSerde() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns 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 a Grouped instance with the provided valueSerde.
valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Joined
Create an instance of Joined with a value Serde.
valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Produced
Create a Produced instance with provided 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 with prefix exists, all prefixed values will be parsed and put into map.
valuesWithPrefixOverride(String) - Method in class org.apache.kafka.common.config.AbstractConfig
Put all keys that do not start with prefix and their parsed values in the result map and then put all the remaining keys with the prefix stripped and their parsed values in the result map.
ValueTransformer<V,​VR> - Interface in org.apache.kafka.streams.kstream
The ValueTransformer interface for stateful mapping of a value to a new value (with possible new type).
ValueTransformerSupplier<V,​VR> - Interface in org.apache.kafka.streams.kstream
A ValueTransformerSupplier interface which can create one or more ValueTransformer instances.
ValueTransformerWithKey<K,​V,​VR> - Interface in org.apache.kafka.streams.kstream
The ValueTransformerWithKey interface for stateful mapping of a value to a new value (with possible new type).
ValueTransformerWithKeySupplier<K,​V,​VR> - Interface in org.apache.kafka.streams.kstream
A ValueTransformerWithKeySupplier interface which can create one or more ValueTransformerWithKey instances.
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(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.
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
 
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
 

W

wakeup() - Method in interface org.apache.kafka.clients.consumer.Consumer
 
wakeup() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Wakeup the consumer.
wakeup() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
WakeupException - Exception in org.apache.kafka.common.errors
Exception used to indicate preemption of a blocking operation by an external thread.
WakeupException() - Constructor for exception org.apache.kafka.common.errors.WakeupException
 
WALL_CLOCK_TIME - org.apache.kafka.streams.processor.PunctuationType
 
WallclockTimestampExtractor - Class in org.apache.kafka.streams.processor
Retrieves current wall clock timestamps as System.currentTimeMillis().
WallclockTimestampExtractor() - Constructor for class org.apache.kafka.streams.processor.WallclockTimestampExtractor
 
WARN_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
The WARN level 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 more WindowStore<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
 
windowedBy(SessionWindows) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
Create a new SessionWindowedCogroupedKStream instance that can be used to perform session windowed aggregations.
windowedBy(SessionWindows) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Create a new SessionWindowedKStream instance that can be used to perform session windowed aggregations.
windowedBy(SlidingWindows) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
Create a new TimeWindowedCogroupedKStream instance that can be used to perform sliding windowed aggregations.
windowedBy(SlidingWindows) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Create a new TimeWindowedKStream instance that can be used to perform sliding windowed aggregations.
windowedBy(Windows<W>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
Create a new TimeWindowedCogroupedKStream instance that can be used to perform windowed aggregations.
windowedBy(Windows<W>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Create a new TimeWindowedKStream instance that can be used to perform windowed aggregations.
WindowedCount - Class in org.apache.kafka.common.metrics.stats
A SampledStat that 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
A SampledStat that maintains the sum of what it has seen.
WindowedSum() - Constructor for class org.apache.kafka.common.metrics.stats.WindowedSum
 
Windows<W extends Window> - Class in org.apache.kafka.streams.kstream
The window specification for fixed size windows that is used to define window boundaries and grace period.
Windows() - Constructor for class org.apache.kafka.streams.kstream.Windows
 
windowsFor(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Not supported by JoinWindows.
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 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
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 a StoreBuilder that can be used to build a WindowStore.
WindowStoreIterator<V> - Interface in org.apache.kafka.streams.state
Iterator interface of KeyValue with key typed Long used for WindowStore.fetch(Object, long, long) and WindowStore.fetch(Object, Instant, Instant) Users must call its close method explicitly upon completeness to release resources, or use try-with-resources statement (available since JDK7) for this Closeable class.
with(long) - Static method in class org.apache.kafka.streams.kstream.SessionWindows
Deprecated.
with(String, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Grouped
Create a Grouped instance with the provided name, keySerde, and valueSerde.
with(Duration) - Static method in class org.apache.kafka.streams.kstream.SessionWindows
Create a new window specification with the specified inactivity gap.
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
Create an instance of Consumed with key and value Serdes.
with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Grouped
Create a Grouped instance with the provided keySerde and valueSerde.
with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Materialized
Materialize a StateStore with the provided key and value Serdes.
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 a Repartitioned instance with provided key serde and value serde.
with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Serialized
Deprecated.
Construct a Serialized instance with the provided key and value Serdes.
with(Serde<K>, Serde<V>, Serde<VO>) - Static method in class org.apache.kafka.streams.kstream.Joined
Create an instance of Joined with key, value, and otherValue Serde instances.
with(Serde<K>, Serde<V>, Serde<VO>, String) - Static method in class org.apache.kafka.streams.kstream.Joined
Create an instance of Joined with key, value, and otherValue Serde instances.
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, Topology.AutoOffsetReset) - Static method in class org.apache.kafka.streams.kstream.Consumed
Create an instance of Consumed with the supplied arguments.
with(Serde<K>, Serde<V1>, Serde<V2>) - Static method in class org.apache.kafka.streams.kstream.StreamJoined
Creates a StreamJoined instance with the provided serdes to configure the stores for the join.
with(Schema, Object) - Method in interface org.apache.kafka.connect.header.Header
Return a new Header object that has the same key but with the supplied value.
with(TimestampExtractor) - Static method in class org.apache.kafka.streams.kstream.Consumed
Create an instance of Consumed with a TimestampExtractor.
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
Create an instance of Consumed with a Topology.AutoOffsetReset.
withBuiltinTypes(String, Class<K>, Class<V>) - Static method in class org.apache.kafka.streams.state.StateSerdes
Create a new instance of StateSerdes for the given state name and key-/value-type classes.
withCachingDisabled() - Method in class org.apache.kafka.streams.kstream.Materialized
Disable caching for the materialized StateStore.
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 materialized StateStore.
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.
withConsumer(Consumer<? super KStream<K, V>>, String) - Static method in class org.apache.kafka.streams.kstream.Branched
Create an instance of Branched with 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 of Branched with provided chain consumer.
withFunction(Function<? super KStream<K, V>, ? extends KStream<K, V>>) - Static method in class org.apache.kafka.streams.kstream.Branched
Create an instance of Branched with 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 of Branched with provided chain function and branch name suffix.
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(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.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Consumed
Configure the instance of Consumed with a key Serde.
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 key Serde to be used.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Materialized
Set the keySerde the materialize StateStore will 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 of Repartitioned with the provided key serde.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Serialized
Deprecated.
Construct a Serialized instance with the provided key Serde.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
Configure with the provided Serde for the key
withKeyValueMapper(KeyValueMapper<? super K, ? super V, String>) - Method in class org.apache.kafka.streams.kstream.Printed
Print the records of a KStream with the provided KeyValueMapper The provided KeyValueMapper's mapped value type must be String.
withLabel(String) - Method in class org.apache.kafka.streams.kstream.Printed
Print the records of a KStream with the provided label.
withLoggingDisabled() - Method in class org.apache.kafka.streams.kstream.Materialized
Disable change logging for the materialized StateStore.
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 this StoreBuilder.
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.
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 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 of Branched with a branch name suffix.
withName(String) - Method in class org.apache.kafka.streams.kstream.Consumed
Configure the instance of Consumed with 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 a KStream with 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 of Repartitioned with 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.
withNoBound() - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
Set the buffer to be unconstrained by size (either keys or bytes).
withNumberOfPartitions(int) - Method in class org.apache.kafka.streams.kstream.Repartitioned
Create a new instance of Repartitioned with the provided number of partitions for repartition topic.
withOffsetResetPolicy(Topology.AutoOffsetReset) - Method in class org.apache.kafka.streams.kstream.Consumed
Configure the instance of Consumed with a Topology.AutoOffsetReset.
withOtherStoreSupplier(WindowBytesStoreSupplier) - Method in class org.apache.kafka.streams.kstream.StreamJoined
Configure with the provided WindowBytesStoreSupplier for the other store supplier.
withOtherValueSerde(Serde<V2>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
Configure with the provided Serde for the other value
withOtherValueSerde(Serde<VO>) - Method in class org.apache.kafka.streams.kstream.Joined
Set the otherValue Serde to be used.
withPartition(Integer) - Method in class org.apache.kafka.streams.StoreQueryParameters
Set a specific partition that should be queried exclusively.
withPartitions(Map<TopicPartition, PartitionInfo>) - Method in class org.apache.kafka.common.Cluster
Return a copy of this cluster combined with `partitions`.
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.
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 of Repartitioned with the provided partitioner.
withThisStoreSupplier(WindowBytesStoreSupplier) - Method in class org.apache.kafka.streams.kstream.StreamJoined
Configure with the provided WindowBytesStoreSupplier for this store supplier.
withTimeDifferenceAndGrace(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.
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 of Consumed with a TimestampExtractor.
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
Configure the instance of Consumed with a value Serde.
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.Joined
Set the value Serde to be used.
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Materialized
Set the valueSerde the materialized StateStore will 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 of Repartitioned with the provided value serde.
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Serialized
Deprecated.
Construct a Serialized instance with the provided value Serde.
withValueSerde(Serde<V1>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
Configure with the provided Serde for this value
workerId() - Method in class org.apache.kafka.connect.health.AbstractState
The identifier of the worker associated with the connector or the task.
Wrapper(Deserializer<T>) - Constructor for class org.apache.kafka.common.serialization.ExtendedDeserializer.Wrapper
Deprecated.
 
Wrapper(Serializer<T>) - Constructor for class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
Deprecated.
 
WrapperSerde(Serializer<T>, Deserializer<T>) - Constructor for class org.apache.kafka.common.serialization.Serdes.WrapperSerde
 
WRITE - org.apache.kafka.common.acl.AclOperation
WRITE operation.
writeTo(DataOutputStream) - Method in class org.apache.kafka.streams.processor.TaskId
 
writeTo(ByteBuffer) - Method in class org.apache.kafka.streams.processor.TaskId
 
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.
A B C D E F G H I J K L M N O P Q R S T U V W Z 
All Classes All Packages