Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- abort() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
- abort() - Method in class org.apache.kafka.common.security.plain.PlainLoginModule
- abort() - Method in class org.apache.kafka.common.security.scram.ScramLoginModule
- abortTransaction() - Method in class org.apache.kafka.clients.producer.KafkaProducer
-
Aborts the ongoing transaction.
- abortTransaction() - Method in class org.apache.kafka.clients.producer.MockProducer
- abortTransaction() - Method in interface org.apache.kafka.clients.producer.Producer
- abortTransaction() - Method in interface org.apache.kafka.connect.source.TransactionContext
-
Requests a transaction abort after the next batch of records from
SourceTask.poll()
. - abortTransaction(AbortTransactionSpec) - Method in interface org.apache.kafka.clients.admin.Admin
-
Forcefully abort a transaction which is open on a topic partition.
- abortTransaction(AbortTransactionSpec, AbortTransactionOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Forcefully abort a transaction which is open on a topic partition.
- abortTransaction(AbortTransactionSpec, AbortTransactionOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- abortTransaction(AbortTransactionSpec, AbortTransactionOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- abortTransaction(SourceRecord) - Method in interface org.apache.kafka.connect.source.TransactionContext
-
Requests a transaction abort after a source record is processed.
- abortTransactionException - Variable in class org.apache.kafka.clients.producer.MockProducer
- AbortTransactionOptions - Class in org.apache.kafka.clients.admin
- AbortTransactionOptions() - Constructor for class org.apache.kafka.clients.admin.AbortTransactionOptions
- AbortTransactionResult - Class in org.apache.kafka.clients.admin
- AbortTransactionSpec - Class in org.apache.kafka.clients.admin
- AbortTransactionSpec(TopicPartition, long, short, int) - Constructor for class org.apache.kafka.clients.admin.AbortTransactionSpec
- AbstractConfig - Class in org.apache.kafka.common.config
-
A convenient base class for configurations to extend.
- AbstractConfig(ConfigDef, Map<?, ?>) - Constructor for class org.apache.kafka.common.config.AbstractConfig
-
Construct a configuration with a ConfigDef and the configuration properties, which can include properties for zero or 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 -
Deprecated.
- AbstractProcessor() - Constructor for class org.apache.kafka.streams.processor.AbstractProcessor
-
Deprecated.
- 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
StateStore
s to see if they match the type expected by implementors of this interface. - accepts(StateStore) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.SessionStoreType
- 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.
- AclBindingDeleteResult(AclBinding) - Constructor for class org.apache.kafka.server.authorizer.AclDeleteResult.AclBindingDeleteResult
- AclBindingDeleteResult(AclBinding, ApiException) - Constructor for class org.apache.kafka.server.authorizer.AclDeleteResult.AclBindingDeleteResult
- aclBindingDeleteResults() - Method in class org.apache.kafka.server.authorizer.AclDeleteResult
-
Returns delete result for each matching ACL binding.
- AclBindingFilter - Class in org.apache.kafka.common.acl
-
A filter which can match AclBinding objects.
- AclBindingFilter(ResourcePatternFilter, AccessControlEntryFilter) - Constructor for class org.apache.kafka.common.acl.AclBindingFilter
-
Create an instance of this filter with the provided parameters.
- aclCount() - Method in interface org.apache.kafka.server.authorizer.Authorizer
-
Get the current number of ACLs, for the purpose of metrics.
- AclCreateResult - Class in org.apache.kafka.server.authorizer
- AclCreateResult(ApiException) - Constructor for class org.apache.kafka.server.authorizer.AclCreateResult
- AclDeleteResult - Class in org.apache.kafka.server.authorizer
- AclDeleteResult(Collection<AclDeleteResult.AclBindingDeleteResult>) - Constructor for class org.apache.kafka.server.authorizer.AclDeleteResult
- AclDeleteResult(ApiException) - Constructor for class org.apache.kafka.server.authorizer.AclDeleteResult
- AclDeleteResult.AclBindingDeleteResult - Class in org.apache.kafka.server.authorizer
-
Delete result for each ACL binding that matched a delete filter.
- AclOperation - Enum Class in org.apache.kafka.common.acl
-
Represents an operation which an ACL grants or denies permission to perform.
- AclPermissionType - Enum Class in org.apache.kafka.common.acl
-
Represents whether an ACL grants or denies permissions.
- acls(AclBindingFilter) - Method in interface org.apache.kafka.server.authorizer.Authorizer
-
Returns ACL bindings which match the provided filter.
- Action - Class in org.apache.kafka.server.authorizer
- Action(AclOperation, ResourcePattern, int, boolean, boolean) - Constructor for class org.apache.kafka.server.authorizer.Action
- activeHost() - Method in class org.apache.kafka.streams.KeyQueryMetadata
-
Get the active Kafka Streams instance for given key.
- activeProducers() - Method in class org.apache.kafka.clients.admin.DescribeProducersResult.PartitionProducerState
- activeTasks() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
Deprecated.
- activeTasks() - Method in interface org.apache.kafka.streams.ThreadMetadata
-
Metadata of the active tasks assigned to the stream thread.
- add(String, byte[]) - Method in interface org.apache.kafka.common.header.Headers
-
Creates and adds a header, to the end, returning if the operation succeeded.
- add(String, Object, Schema) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- add(String, Object, Schema) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection 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
- addDecimal(String, BigDecimal) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addDecimal(String, BigDecimal) - Method in interface org.apache.kafka.connect.header.Headers
- addDouble(String, double) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addDouble(String, double) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value. - addErrorMessage(String) - Method in class org.apache.kafka.common.config.ConfigValue
- addExecutionInfo(String) - Method in interface org.apache.kafka.streams.query.QueryResult
-
Used by stores to add detailed execution information (if requested) during query execution.
- addFloat(String, float) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addFloat(String, float) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value. - addGlobalStore(StoreBuilder<?>, String, Deserializer<K>, Deserializer<V>, String, String, ProcessorSupplier<K, V>) - Method in class org.apache.kafka.streams.Topology
-
Deprecated.
- 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
-
Deprecated.Since 2.7.0; use
StreamsBuilder.addGlobalStore(StoreBuilder, String, Consumed, ProcessorSupplier)
instead. - 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
-
Deprecated.
- 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. - 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.
- addMetricIfAbsent(MetricName, MetricConfig, MetricValueProvider<?>) - Method in class org.apache.kafka.common.metrics.Metrics
-
Create or get an existing metric to monitor an object that implements MetricValueProvider.
- addProcessor(String, ProcessorSupplier<KIn, VIn, KOut, VOut>, String...) - Method in class org.apache.kafka.streams.Topology
-
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
-
Deprecated.Since 2.7.0 Use
Topology.addProcessor(String, ProcessorSupplier, String...)
instead. - 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
- addRemoteLogSegmentMetadata(RemoteLogSegmentMetadata) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteLogMetadataManager
-
This method is used to add
RemoteLogSegmentMetadata
asynchronously with the containingRemoteLogSegmentId
intoRemoteLogMetadataManager
. - addReporter(MetricsReporter) - Method in class org.apache.kafka.common.metrics.Metrics
-
Add a MetricReporter
- addResult(int, QueryResult<R>) - Method in class org.apache.kafka.streams.query.StateQueryResult
-
Set the result for a partitioned store query.
- addSensor(String, Sensor.RecordingLevel) - Method in interface org.apache.kafka.streams.StreamsMetrics
-
Generic method to create a sensor.
- addSensor(String, Sensor.RecordingLevel, Sensor...) - Method in interface org.apache.kafka.streams.StreamsMetrics
-
Generic method to create a sensor with parent sensors.
- addShort(String, short) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addShort(String, short) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection 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. - addTime(String, Date) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addTime(String, Date) - Method in interface org.apache.kafka.connect.header.Headers
- addTimestamp(String, Date) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addTimestamp(String, Date) - Method in interface org.apache.kafka.connect.header.Headers
- 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 - Enum constant in enum class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
- ADMIN_CLIENT_PREFIX - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- ADMIN_CLIENT_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to isolate
admin
configs from other client configs. - adminClient - Variable in class org.apache.kafka.streams.KafkaStreams
- 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
-
Deprecated.
- adminClientId() - Method in interface org.apache.kafka.streams.ThreadMetadata
-
Client ID of the admin client used by the stream thread.
- adminClientPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
Prefix a property with
StreamsConfig.ADMIN_CLIENT_PREFIX
. - adminConfig() - Method in class org.apache.kafka.connect.mirror.MirrorClientConfig
-
Sub-config for Admin clients.
- advanceBy(Duration) - Method in class org.apache.kafka.streams.kstream.TimeWindows
-
Return a window definition with the original size, but advance ("hop") the window by the given interval, which specifies by how much a window moves forward relative to the previous one.
- advanceMs - Variable in class org.apache.kafka.streams.kstream.TimeWindows
-
The size of the window's advance interval in milliseconds, i.e., by how much a window moves forward relative to the previous one.
- advanceTime(Duration) - Method in class org.apache.kafka.streams.TestInputTopic
-
Advances the internally tracked event time of this input topic.
- advanceWallClockTime(Duration) - Method in class org.apache.kafka.streams.TopologyTestDriver
-
Advances the internally mocked wall-clock time.
- after(Duration) - Method in class org.apache.kafka.streams.kstream.JoinWindows
-
Changes the end window boundary 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(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Aggregate the values of records in this stream by the grouped key.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Aggregate the values of records in this stream by the grouped key and defined windows.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Aggregate the values of records in this stream by the grouped key and defined sessions.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Materialized<K, VR, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Aggregate the values of records in this stream by the grouped key and defined sessions.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Aggregate the values of records in this stream by the grouped key and defined sessions.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Named, Materialized<K, VR, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Aggregate the values of records in this stream by the grouped key and defined sessions.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Aggregate the values of records in this stream by the grouped key and defined windows.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Aggregate the values of records in this stream by the grouped key.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Aggregate the values of records in this stream by the grouped key and defined windows.
- Aggregator<K,
V, 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.AbortTransactionResult
-
Get a future which completes when the transaction specified by
AbortTransactionSpec
in the respective call toAdmin.abortTransaction(AbortTransactionSpec, AbortTransactionOptions)
returns successfully or fails due to an error or timeout. - all() - Method in class org.apache.kafka.clients.admin.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 onKafkaFuture.get()
if all the replica movement have succeeded. - all() - Method in class org.apache.kafka.clients.admin.AlterUserScramCredentialsResult
-
Return a future which succeeds only if all the user SCRAM credential alterations succeed.
- all() - Method in class org.apache.kafka.clients.admin.CreateAclsResult
-
Return a future which succeeds only if all the ACL creations succeed.
- all() - Method in class org.apache.kafka.clients.admin.CreatePartitionsResult
-
Return a future which succeeds if all the partition creations succeed.
- all() - Method in class org.apache.kafka.clients.admin.CreateTopicsResult
-
Return a future which succeeds if all the topic creations succeed.
- all() - Method in class org.apache.kafka.clients.admin.DeleteAclsResult
-
Return a future which succeeds only if all the ACLs deletions succeed, and which contains all the deleted ACLs.
- all() - Method in class org.apache.kafka.clients.admin.DeleteConsumerGroupOffsetsResult
-
Return a future which succeeds only if all the deletions succeed.
- all() - Method in class org.apache.kafka.clients.admin.DeleteConsumerGroupsResult
-
Return a future which succeeds only if all the consumer group deletions succeed.
- all() - Method in class org.apache.kafka.clients.admin.DeleteRecordsResult
-
Return a future which succeeds only if all the records deletions succeed.
- all() - Method in class org.apache.kafka.clients.admin.DeleteTopicsResult
- all() - Method in class org.apache.kafka.clients.admin.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.DescribeProducersResult
- all() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult
-
Return a future which succeeds if log directory information of all replicas are available
- all() - Method in class org.apache.kafka.clients.admin.DescribeTopicsResult
-
Deprecated.Since 3.1.0 use
DescribeTopicsResult.allTopicNames()
instead - all() - Method in class org.apache.kafka.clients.admin.DescribeTransactionsResult
-
Get a future which returns a map of the transaction descriptions requested in the respective call to
Admin.describeTransactions(Collection, DescribeTransactionsOptions)
. - all() - Method in class org.apache.kafka.clients.admin.DescribeUserScramCredentialsResult
- all() - Method in class org.apache.kafka.clients.admin.ElectLeadersResult
-
Return a future which succeeds if all the topic elections succeed.
- all() - Method in class org.apache.kafka.clients.admin.FenceProducersResult
-
Return a future which succeeds only if all the producer fencings succeed.
- all() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsResult
-
Return a future which yields all Map<String, Map<TopicPartition, OffsetAndMetadata> objects, if requests for all the groups succeed.
- all() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsResult
-
Returns a future that yields either an exception, or the full set of consumer group listings.
- all() - Method in class org.apache.kafka.clients.admin.ListOffsetsResult
-
Return a future which succeeds only if offsets for all specified partitions have been successfully retrieved.
- all() - Method in class org.apache.kafka.clients.admin.ListTransactionsResult
-
Get all transaction listings.
- all() - Method in class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupResult
-
Returns a future which indicates whether the request was 100% success, i.e. no either top level or member level error.
- all() - Method in class org.apache.kafka.clients.admin.UnregisterBrokerResult
-
Return a future which succeeds if the operation is successful.
- all() - Method in class org.apache.kafka.clients.admin.UpdateFeaturesResult
-
Return a future which succeeds if all the feature updates succeed.
- all() - Static method in class org.apache.kafka.common.quota.ClientQuotaFilter
-
Constructs and returns a quota filter that matches all configured entities.
- all() - Static method in class org.apache.kafka.streams.processor.To
-
Forward the key/value pair to all downstream processors
- all() - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
-
Return an iterator over all keys in this store.
- all() - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
-
Gets all the key-value pairs in the existing windows.
- ALL - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
-
ALL operation.
- allByBrokerId() - Method in class org.apache.kafka.clients.admin.ListTransactionsResult
-
Get all transaction listings in a map which is keyed by the ID of respective broker that is currently managing them.
- allDescriptions() - Method in class org.apache.kafka.clients.admin.DescribeLogDirsResult
-
Return a future which succeeds only if all the brokers have responded without error.
- allLocalStorePartitionLags() - Method in class org.apache.kafka.streams.KafkaStreams
-
Returns
LagInfo
, for all store partitions (active or standby) local to this Streams instance. - allLocalStorePartitionLags(List<Task>) - Method in class org.apache.kafka.streams.KafkaStreams
- allMetadata() - Method in class org.apache.kafka.streams.KafkaStreams
-
Deprecated.since 3.0.0 use
KafkaStreams.metadataForAllStreamsClients()
- allMetadataForStore(String) - Method in class org.apache.kafka.streams.KafkaStreams
-
Deprecated.since 3.0.0 use
KafkaStreams.streamsMetadataForStore(java.lang.String)
instead - allOf(KafkaFuture<?>...) - Static method in class org.apache.kafka.common.KafkaFuture
-
Returns a new KafkaFuture that is completed when all the given futures have completed.
- ALLOW - Enum constant in enum class org.apache.kafka.common.acl.AclPermissionType
-
Grants access.
- ALLOW_AUTO_CREATE_TOPICS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
allow.auto.create.topics
- allowDowngrade() - Method in class org.apache.kafka.clients.admin.FeatureUpdate
-
Deprecated.
- ALLOWED - Enum constant in enum class org.apache.kafka.server.authorizer.AuthorizationResult
- allTopicIds() - Method in class org.apache.kafka.clients.admin.DescribeTopicsResult
- allTopicNames() - Method in class org.apache.kafka.clients.admin.DescribeTopicsResult
- allWithName(String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- allWithName(String) - Method in interface org.apache.kafka.connect.header.Headers
- AlreadyExistsException - Exception 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 - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
-
ALTER operation.
- ALTER_CONFIGS - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
-
ALTER_CONFIGS operation.
- alterClientQuotas(Collection<ClientQuotaAlteration>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Alters client quota configurations with the specified alterations.
- alterClientQuotas(Collection<ClientQuotaAlteration>, AlterClientQuotasOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Alters client quota configurations with the specified alterations.
- alterClientQuotas(Collection<ClientQuotaAlteration>, AlterClientQuotasOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- alterClientQuotas(Collection<ClientQuotaAlteration>, AlterClientQuotasOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- AlterClientQuotasOptions - Class in org.apache.kafka.clients.admin
- AlterClientQuotasOptions() - Constructor for class org.apache.kafka.clients.admin.AlterClientQuotasOptions
- AlterClientQuotasResult - Class in org.apache.kafka.clients.admin
-
The result of the
Admin.alterClientQuotas(Collection, AlterClientQuotasOptions)
call. - AlterClientQuotasResult(Map<ClientQuotaEntity, KafkaFuture<Void>>) - Constructor for class org.apache.kafka.clients.admin.AlterClientQuotasResult
-
Maps an entity to its alteration result.
- AlterConfigOp - Class in org.apache.kafka.clients.admin
-
A class representing 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 Class in org.apache.kafka.clients.admin
- AlterConfigPolicy - Interface in org.apache.kafka.server.policy
-
An interface for enforcing a policy on alter configs requests.
- AlterConfigPolicy.RequestMetadata - Class in org.apache.kafka.server.policy
-
Class containing the create request parameters.
- alterConfigs(Map<ConfigResource, Config>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Deprecated.Since 2.3. Use
Admin.incrementalAlterConfigs(Map)
. - alterConfigs(Map<ConfigResource, Config>, AlterConfigsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Deprecated.Since 2.3. Use
Admin.incrementalAlterConfigs(Map, AlterConfigsOptions)
. - alterConfigs(Map<ConfigResource, Config>, AlterConfigsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
-
Deprecated.
- alterConfigs(Map<ConfigResource, Config>, AlterConfigsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
Deprecated.
- AlterConfigsOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.incrementalAlterConfigs(Map)
andAdmin.alterConfigs(Map)
. - 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.ForwardingAdmin
- alterConsumerGroupOffsets(String, Map<TopicPartition, OffsetAndMetadata>, AlterConsumerGroupOffsetsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- AlterConsumerGroupOffsetsOptions - Class in org.apache.kafka.clients.admin
-
Options for the
Admin.alterConsumerGroupOffsets(String, Map, AlterConsumerGroupOffsetsOptions)
call. - AlterConsumerGroupOffsetsOptions() - Constructor for class org.apache.kafka.clients.admin.AlterConsumerGroupOffsetsOptions
- AlterConsumerGroupOffsetsResult - Class in org.apache.kafka.clients.admin
-
The result of the
Admin.alterConsumerGroupOffsets(String, Map)
call. - alterPartitionReassignments(Map<TopicPartition, Optional<NewPartitionReassignment>>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Change the reassignments for one or more partitions.
- alterPartitionReassignments(Map<TopicPartition, Optional<NewPartitionReassignment>>, AlterPartitionReassignmentsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Change the reassignments for one or more partitions.
- alterPartitionReassignments(Map<TopicPartition, Optional<NewPartitionReassignment>>, AlterPartitionReassignmentsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- alterPartitionReassignments(Map<TopicPartition, Optional<NewPartitionReassignment>>, AlterPartitionReassignmentsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- AlterPartitionReassignmentsOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.alterPartitionReassignments(Map, AlterPartitionReassignmentsOptions)
The API of this class is evolving. - AlterPartitionReassignmentsOptions() - Constructor for class org.apache.kafka.clients.admin.AlterPartitionReassignmentsOptions
- AlterPartitionReassignmentsResult - Class in org.apache.kafka.clients.admin
- alterReplicaLogDirs(Map<TopicPartitionReplica, String>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Change the log directory for the specified replicas.
- alterReplicaLogDirs(Map<TopicPartitionReplica, String>, AlterReplicaLogDirsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Change the log directory for the specified replicas.
- alterReplicaLogDirs(Map<TopicPartitionReplica, String>, AlterReplicaLogDirsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- alterReplicaLogDirs(Map<TopicPartitionReplica, String>, AlterReplicaLogDirsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- AlterReplicaLogDirsOptions - Class in org.apache.kafka.clients.admin
- AlterReplicaLogDirsOptions() - Constructor for class org.apache.kafka.clients.admin.AlterReplicaLogDirsOptions
- AlterReplicaLogDirsResult - Class in org.apache.kafka.clients.admin
-
The result of
Admin.alterReplicaLogDirs(Map, AlterReplicaLogDirsOptions)
. - alterUserScramCredentials(List<UserScramCredentialAlteration>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Alter SASL/SCRAM credentials for the given users.
- alterUserScramCredentials(List<UserScramCredentialAlteration>, AlterUserScramCredentialsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Alter SASL/SCRAM credentials.
- alterUserScramCredentials(List<UserScramCredentialAlteration>, AlterUserScramCredentialsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- alterUserScramCredentials(List<UserScramCredentialAlteration>, AlterUserScramCredentialsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- AlterUserScramCredentialsOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.alterUserScramCredentials(List, AlterUserScramCredentialsOptions)
The API of this class is evolving. - AlterUserScramCredentialsOptions() - Constructor for class org.apache.kafka.clients.admin.AlterUserScramCredentialsOptions
- AlterUserScramCredentialsResult - Class in org.apache.kafka.clients.admin
-
The result of the
Admin.alterUserScramCredentials(List)
call. - AlterUserScramCredentialsResult(Map<String, KafkaFuture<Void>>) - Constructor for class org.apache.kafka.clients.admin.AlterUserScramCredentialsResult
- ANONYMOUS - Static variable in class org.apache.kafka.common.security.auth.KafkaPrincipal
- ANY - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
-
In a filter, matches any AclOperation.
- ANY - Enum constant in enum class org.apache.kafka.common.acl.AclPermissionType
-
In a filter, matches any AclPermissionType.
- ANY - Enum constant in enum class org.apache.kafka.common.resource.PatternType
-
In a filter, matches any resource pattern type.
- ANY - Enum constant in enum class org.apache.kafka.common.resource.ResourceType
-
In a filter, matches any ResourceType.
- ANY - Static variable in class org.apache.kafka.common.acl.AccessControlEntryFilter
-
Matches any access control entry.
- ANY - Static variable in class org.apache.kafka.common.acl.AclBindingFilter
-
A filter which matches any ACL binding.
- ANY - Static variable in class org.apache.kafka.common.resource.ResourcePatternFilter
-
Matches any resource pattern.
- ApiException - Exception 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.ProcessingContext
-
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
-
Return all the application config properties as key/value pairs.
- appConfigs() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
-
Returns all the application config properties as key/value pairs.
- appConfigsWithPrefix(String) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- appConfigsWithPrefix(String) - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
-
Return all the application config properties with the given key prefix, as key/value pairs stripping the prefix.
- appConfigsWithPrefix(String) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- appConfigsWithPrefix(String) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return all the application config properties with the given key prefix, as key/value pairs stripping the prefix.
- appConfigsWithPrefix(String) - Method in interface org.apache.kafka.streams.processor.StateStoreContext
-
Returns all the application config properties with the given key prefix, as key/value pairs stripping the prefix.
- append(StringBuilder, Object, boolean) - Static method in class org.apache.kafka.connect.data.Values
- APPEND - Enum constant in enum class org.apache.kafka.clients.admin.AlterConfigOp.OpType
-
(For list-type configuration entries only.)
- appendDeserializerToConfig(Map<String, Object>, Deserializer<?>, Deserializer<?>) - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
- 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
- applicationConfigs - Variable in class org.apache.kafka.streams.KafkaStreams
- applicationConfigs - Variable in class org.apache.kafka.streams.TopologyConfig
- applicationId() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- applicationId() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
-
Return the application id.
- applicationId() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- applicationId() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return the application id.
- applicationId() - Method in interface org.apache.kafka.streams.processor.StateStoreContext
-
Returns the application id.
- 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
Header
s with the given key, apply the transform to each and store the result in place of the original. - apply(K1, V1, V2) - Method in interface org.apache.kafka.streams.kstream.ValueJoinerWithKey
-
Return a joined value consisting of
readOnlyKey
,value1
andvalue2
. - 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
- 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
Header
s, 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 berecord
itself) ornull
, corresponding to a map or filter operation respectively. - apply(V) - Method in interface org.apache.kafka.streams.kstream.ValueMapper
-
Map the given value to a new value.
- apply(V1, V2) - Method in interface org.apache.kafka.streams.kstream.ValueJoiner
-
Return a joined value consisting of
value1
andvalue2
. - apply(V, V) - Method in interface org.apache.kafka.streams.kstream.Reducer
-
Aggregate the two given values into a single one.
- approximateNumEntries() - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
-
Return an approximate count of key-value mappings in this store.
- array(Schema) - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- ARRAY - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
An ordered sequence of elements, each of which shares the same type.
- as(String) - Static method in class org.apache.kafka.streams.kstream.Branched
-
Create an instance 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(String) - Static method in class org.apache.kafka.streams.kstream.TableJoined
-
Create an instance of
TableJoined
with base name for all components of the join, including internal topics created to complete the join. - as(Materialized.StoreType) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
Materialize a
StateStore
with the givenMaterialized.StoreType
. - as(KeyValueBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
Materialize a
KeyValueStore
using the providedKeyValueBytesStoreSupplier
. - as(SessionBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
Materialize a
SessionStore
using the providedSessionBytesStoreSupplier
. - as(WindowBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
Materialize a
WindowStore
using the providedWindowBytesStoreSupplier
. - 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.
- ASSIGN_FROM_SUBSCRIBED_ASSIGNORS - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- 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(Position) - Static method in class org.apache.kafka.streams.query.PositionBound
-
Creates a new PositionBound representing a specific position.
- AT_LEAST_ONCE - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"processing.guarantee"
for at-least-once processing guarantees. - atLeast(Number) - Static method in class org.apache.kafka.common.config.ConfigDef.Range
-
A numeric range that checks only the lower bound
- atMostOfSize(int) - Static method in class org.apache.kafka.common.config.ConfigDef.ListSize
- AuthenticateCallbackHandler - Interface in org.apache.kafka.common.security.auth
- authenticated() - Method in class org.apache.kafka.common.security.plain.PlainAuthenticateCallback
-
Returns true if client password matches expected password, false otherwise.
- authenticated(boolean) - Method in class org.apache.kafka.common.security.plain.PlainAuthenticateCallback
-
Sets the authenticated state.
- AuthenticationContext - Interface in org.apache.kafka.common.security.auth
-
An object representing contextual information from the authentication session.
- AuthenticationException - Exception 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 Class in org.apache.kafka.server.authorizer
- authorize(AuthorizableRequestContext, List<Action>) - Method in interface org.apache.kafka.server.authorizer.Authorizer
-
Authorizes the specified action.
- authorizeByResourceType(AuthorizableRequestContext, AclOperation, ResourceType) - Method in interface org.apache.kafka.server.authorizer.Authorizer
-
Check if the caller is authorized to perform the given ACL operation on at least one resource of the given type.
- authorizedOperations() - Method in class org.apache.kafka.clients.admin.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.
- AuthorizerNotReadyException - Exception in org.apache.kafka.common.errors
-
An exception that indicates that the authorizer is not ready to receive the request yet.
- AuthorizerNotReadyException() - Constructor for exception org.apache.kafka.common.errors.AuthorizerNotReadyException
- AuthorizerServerInfo - Interface in org.apache.kafka.server.authorizer
-
Runtime broker configuration metadata provided to authorizers during start up.
- AUTO_COMMIT_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
auto.commit.interval.ms
- AUTO_INCLUDE_JMX_REPORTER_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
Deprecated.
- AUTO_INCLUDE_JMX_REPORTER_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
Deprecated.
- AUTO_INCLUDE_JMX_REPORTER_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
Deprecated.
- AUTO_INCLUDE_JMX_REPORTER_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- AUTO_INCLUDE_JMX_REPORTER_DOC - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- 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, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Fetch any sessions with the matching key and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from latest to earliest.
- backwardFindSessions(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
- backwardFindSessions(K, K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Fetch any sessions in the given range of keys and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from latest to earliest.
- backwardFindSessions(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Fetch any sessions in the given range of keys and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from latest to earliest.
- backwardFindSessions(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
- BATCH_SIZE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
batch.size
- BatchingStateRestoreCallback - Interface in org.apache.kafka.streams.processor
-
Interface for batching restoration of a
StateStore
It is expected that implementations of this class will not call theStateRestoreCallback.restore(byte[], byte[])
method. - before(Duration) - Method in class org.apache.kafka.streams.kstream.JoinWindows
-
Changes the start window boundary 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 - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigType
- BOOLEAN - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Type
- BOOLEAN - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
Boolean value (true or false)
- BOOLEAN_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- BOOLEAN_SIZE - Static variable in class org.apache.kafka.streams.state.StateSerdes
- 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 withBranchedKStream
. - 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 - Enum constant in enum class org.apache.kafka.common.config.ConfigResource.Type
- BROKER_LOGGER - Enum constant in enum class org.apache.kafka.common.config.ConfigResource.Type
- brokerId() - Method in class org.apache.kafka.clients.admin.DescribeProducersOptions
- brokerId() - Method in class org.apache.kafka.common.TopicPartitionReplica
- brokerId() - Method in interface org.apache.kafka.server.authorizer.AuthorizerServerInfo
-
Returns broker id.
- brokerId() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogMetadata
- brokerId(int) - Method in class org.apache.kafka.clients.admin.DescribeProducersOptions
- BrokerIdNotRegisteredException - Exception 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
- BUFFERED_RECORDS_PER_PARTITION_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- 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 aProperties
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
- BUILT_IN_METRICS_VERSION_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
built.in.metrics.version
- byBrokerId() - Method in class org.apache.kafka.clients.admin.ListTransactionsResult
-
Get a future which returns a map containing the underlying listing future for each broker in the cluster.
- ByteArray() - Static method in class org.apache.kafka.common.serialization.Serdes
-
A serde for nullable
byte[]
type. - ByteArrayDeserializer - Class in org.apache.kafka.common.serialization
- ByteArrayDeserializer() - Constructor for class org.apache.kafka.common.serialization.ByteArrayDeserializer
- ByteArraySerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.ByteArraySerde
- ByteArraySerializer - Class in org.apache.kafka.common.serialization
- ByteArraySerializer() - Constructor for class org.apache.kafka.common.serialization.ByteArraySerializer
- ByteBuffer() - Static method in class org.apache.kafka.common.serialization.Serdes
-
A serde for nullable
ByteBuffer
type. - 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
-
Do not need to flip before call serialize(String, ByteBuffer).
- ByteBufferSerializer() - Constructor for class org.apache.kafka.common.serialization.ByteBufferSerializer
- bytes() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- Bytes() - Static method in class org.apache.kafka.common.serialization.Serdes
-
A serde for nullable
Bytes
type. - BYTES - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
Sequence of unsigned 8-bit bytes
- BYTES_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- BytesDeserializer - Class in org.apache.kafka.common.serialization
- BytesDeserializer() - Constructor for class org.apache.kafka.common.serialization.BytesDeserializer
- BytesSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.BytesSerde
- BytesSerializer - Class in org.apache.kafka.common.serialization
- BytesSerializer() - Constructor for class org.apache.kafka.common.serialization.BytesSerializer
C
- CACHE_MAX_BYTES_BUFFERING_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- CACHE_MAX_BYTES_BUFFERING_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- cacheSize - Variable in class org.apache.kafka.streams.TopologyConfig
- 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
-
Cancellable interface returned in
ProcessorContext.schedule(Duration, PunctuationType, Punctuator)
. - cancelled() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedPunctuator
- cancelled() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedPunctuator
- 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
- canDefineTransactionBoundaries(Map<String, String>) - Method in class org.apache.kafka.connect.source.SourceConnector
-
Signals whether the connector implementation is capable of defining the transaction boundaries for a connector with the given configuration.
- 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
- checkpointsTopic(String) - Method in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
- checkpointsTopic(String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
-
Returns the name checkpoint topic for given cluster alias.
- 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
- 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 - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigType
- CLASS - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Type
- 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 theapplication ID
. - CLEANUP_POLICY_COMPACT - Static variable in class org.apache.kafka.common.config.TopicConfig
- CLEANUP_POLICY_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
- CLEANUP_POLICY_DELETE - Static variable in class org.apache.kafka.common.config.TopicConfig
- CLEANUP_POLICY_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
- clear() - Method in class org.apache.kafka.clients.producer.MockProducer
-
Clear the stored history of sent records, consumer group offsets
- clear() - Method in class org.apache.kafka.common.metrics.stats.Histogram
- clear() - Method in class org.apache.kafka.connect.header.ConnectHeaders
- clear() - Method in interface org.apache.kafka.connect.header.Headers
-
Removes all headers from this object.
- CLIENT_DNS_LOOKUP_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
client.dns.lookup
- CLIENT_DNS_LOOKUP_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
client.dns.lookup
- CLIENT_DNS_LOOKUP_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
client.dns.lookup
- CLIENT_ID - Enum constant in enum class org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
- CLIENT_ID - Static variable in class org.apache.kafka.common.quota.ClientQuotaEntity
- CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
client.id
- CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
client.id
- CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
client.id
- CLIENT_ID_DOC - Static variable in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- CLIENT_RACK_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
client.rack
- CLIENT_SECRET_CONFIG - Static variable in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- CLIENT_SECRET_DOC - Static variable in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- CLIENT_TAG_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to add arbitrary tags to a Kafka Stream's instance as key-value pairs.
- clientAddress() - Method in interface org.apache.kafka.common.security.auth.AuthenticationContext
-
Address of the authenticated client
- clientAddress() - Method in class org.apache.kafka.common.security.auth.PlaintextAuthenticationContext
- clientAddress() - Method in class org.apache.kafka.common.security.auth.SaslAuthenticationContext
- clientAddress() - Method in class org.apache.kafka.common.security.auth.SslAuthenticationContext
- clientAddress() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
-
Returns client IP address from which request was sent.
- clientId - Variable in class org.apache.kafka.streams.KafkaStreams
- 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.
forConnectorType.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 Class in org.apache.kafka.server.quota
-
Entity type of a
ClientQuotaEntity.ConfigEntity
- ClientQuotaFilter - Class in org.apache.kafka.common.quota
-
Describes a client quota entity filter.
- ClientQuotaFilterComponent - Class in org.apache.kafka.common.quota
-
Describes a component for applying a client quota filter.
- ClientQuotaType - Enum Class in org.apache.kafka.server.quota
-
Types of quotas that may be configured on brokers for client requests.
- clientTagPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
Prefix a client tag key with
StreamsConfig.CLIENT_TAG_PREFIX
. - clientType() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
-
ConnectorClientConfigRequest.ClientType.PRODUCER
forConnectorType.SOURCE
ConnectorClientConfigRequest.ClientType.CONSUMER
forConnectorType.SINK
ConnectorClientConfigRequest.ClientType.PRODUCER
for DLQ inConnectorType.SINK
ConnectorClientConfigRequest.ClientType.ADMIN
for DLQ Topic Creation inConnectorType.SINK
- 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
-
Deprecated.
- 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 interface org.apache.kafka.common.security.auth.Login
-
Closes this instance.
- close() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- close() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallbackHandler
- close() - Method in interface org.apache.kafka.common.serialization.Deserializer
-
Close this deserializer.
- close() - Method in class org.apache.kafka.common.serialization.ListDeserializer
- close() - Method in class org.apache.kafka.common.serialization.ListSerializer
- close() - Method in interface org.apache.kafka.common.serialization.Serde
-
Close this serde class, which will close the underlying serializer and deserializer.
- close() - Method in class org.apache.kafka.common.serialization.Serdes.WrapperSerde
- close() - Method in interface org.apache.kafka.common.serialization.Serializer
-
Close this serializer.
- close() - Method in class org.apache.kafka.connect.mirror.MirrorClient
-
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
-
Deprecated.Close this processor and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.processor.api.FixedKeyProcessor
-
Close this processor and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.processor.api.Processor
-
Close this processor and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.processor.Processor
-
Deprecated.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(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.ForwardingAdmin
- close(Duration) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- close(Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
- close(Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Tries to close the consumer cleanly within the specified timeout.
- close(Duration) - Method in class org.apache.kafka.clients.consumer.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.
- close(KafkaStreams.CloseOptions) - 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. - closed() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- closed() - Method in class org.apache.kafka.clients.producer.MockProducer
- closeException - Variable in class org.apache.kafka.clients.producer.MockProducer
- CloseOptions() - Constructor for class org.apache.kafka.streams.KafkaStreams.CloseOptions
- Cluster - Class in org.apache.kafka.common
-
An immutable representation of a subset of the nodes, topics, and partitions in the Kafka cluster.
- Cluster(String, Collection<Node>, Collection<PartitionInfo>, Set<String>, Set<String>) - Constructor for class org.apache.kafka.common.Cluster
-
Create a new cluster with the given id, nodes and partitions
- Cluster(String, Collection<Node>, Collection<PartitionInfo>, Set<String>, Set<String>, Set<String>, Node) - Constructor for class org.apache.kafka.common.Cluster
-
Create a new cluster with the given id, nodes and partitions
- Cluster(String, Collection<Node>, Collection<PartitionInfo>, Set<String>, Set<String>, Set<String>, Node, Map<String, Uuid>) - Constructor for class org.apache.kafka.common.Cluster
-
Create a new cluster with the given id, nodes, partitions and topicIds
- Cluster(String, Collection<Node>, Collection<PartitionInfo>, Set<String>, Set<String>, Node) - Constructor for class org.apache.kafka.common.Cluster
-
Create a new cluster with the given id, nodes and partitions
- CLUSTER - Enum constant in enum class org.apache.kafka.common.resource.ResourceType
-
The cluster as a whole.
- CLUSTER - Static variable in class org.apache.kafka.common.resource.Resource
-
A resource representing the whole cluster.
- CLUSTER_ACTION - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
-
CLUSTER_ACTION operation.
- CLUSTER_NAME - Static variable in class org.apache.kafka.common.resource.Resource
-
The name of the CLUSTER resource.
- ClusterAuthorizationException - Exception 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 class org.apache.kafka.clients.admin.FeatureUpdate.UpgradeType
- code() - Method in enum class org.apache.kafka.common.acl.AclOperation
-
Return the code of this operation.
- code() - Method in enum class org.apache.kafka.common.acl.AclPermissionType
-
Return the code of this permission type.
- code() - Method in enum class org.apache.kafka.common.resource.PatternType
- code() - Method in enum class org.apache.kafka.common.resource.ResourceType
-
Return the code of this resource.
- cogroup(Aggregator<? super K, ? super V, VOut>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Create a new
CogroupedKStream
from the this grouped KStream to allow cogrouping otherKGroupedStream
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 thisCogroupedKStream
. - CogroupedKStream<K,
VOut> - Interface in org.apache.kafka.streams.kstream -
CogroupedKStream
is an abstraction of multiple grouped record streams ofKeyValue
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.ProcessingContext
-
Request a commit.
- commit() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- commit() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Request a commit.
- COMMIT_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
commit.interval.ms
- commitAsync() - Method in interface org.apache.kafka.clients.consumer.Consumer
- commitAsync() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Commit offsets returned on the 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
- CommitCallback - Interface in org.apache.kafka.streams.processor
-
Stores can register this callback to be notified upon successful commit.
- commitCount() - Method in class org.apache.kafka.clients.producer.MockProducer
- CommitFailedException - Exception 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
-
Deprecated.
- 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
ProcessingContext.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.since 2.4 Use
KafkaConsumer.committed(Set, Duration)
instead - committed(TopicPartition, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
Deprecated.
- committedOffsets() - Method in class org.apache.kafka.streams.processor.TaskMetadata
-
Deprecated.This function will return a map of TopicPartitions and the highest committed offset seen so far
- committedOffsets() - Method in interface org.apache.kafka.streams.TaskMetadata
-
Offsets of the source topic partitions committed so far by the task.
- commitTransaction() - Method in class org.apache.kafka.clients.producer.KafkaProducer
-
Commits the ongoing transaction.
- commitTransaction() - Method in class org.apache.kafka.clients.producer.MockProducer
- commitTransaction() - Method in interface org.apache.kafka.clients.producer.Producer
- commitTransaction() - Method in interface org.apache.kafka.connect.source.TransactionContext
-
Request a transaction commit after the next batch of records from
SourceTask.poll()
is processed. - commitTransaction(SourceRecord) - Method in interface org.apache.kafka.connect.source.TransactionContext
-
Request a transaction commit after a source record is processed.
- commitTransactionException - Variable in class org.apache.kafka.clients.producer.MockProducer
- commonSchemaFor(Schema, SchemaAndValue) - Static method in class org.apache.kafka.connect.data.Values
- compareTo(Uuid) - Method in class org.apache.kafka.common.Uuid
- compareTo(TaskId) - Method in class org.apache.kafka.streams.processor.TaskId
- compilePredicate(Map<String, ?>) - Static method in class org.apache.kafka.common.metrics.JmxReporter
- complete(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.
- COMPLETE_ABORT - Enum constant in enum class org.apache.kafka.clients.admin.TransactionState
- COMPLETE_COMMIT - Enum constant in enum class org.apache.kafka.clients.admin.TransactionState
- 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 - Enum constant in enum class 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.Converter
-
Configuration specification for this converter.
- config() - Method in interface org.apache.kafka.connect.storage.HeaderConverter
-
Configuration specification for this set of header converters.
- config() - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
- config() - Method in class org.apache.kafka.connect.storage.StringConverter
- config() - Method in 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 Class in org.apache.kafka.common.config
-
The importance level for a configuration
- ConfigDef.LambdaValidator - Class in org.apache.kafka.common.config
- ConfigDef.ListSize - Class in org.apache.kafka.common.config
- ConfigDef.NonEmptyString - Class in org.apache.kafka.common.config
- ConfigDef.NonEmptyStringWithoutControlChars - Class in org.apache.kafka.common.config
- ConfigDef.NonNullValidator - Class in org.apache.kafka.common.config
- ConfigDef.Range - Class in org.apache.kafka.common.config
-
Validation logic for numeric ranges
- ConfigDef.Recommender - Interface in org.apache.kafka.common.config
-
This is used by 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 Class 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 Class in org.apache.kafka.common.config
-
The width of a configuration value
- configEntities() - Method in interface org.apache.kafka.server.quota.ClientQuotaEntity
-
Returns the list of configuration entities that this quota entity is comprised of.
- configEntry() - Method in class org.apache.kafka.clients.admin.AlterConfigOp
- ConfigEntry - Class in org.apache.kafka.clients.admin
-
A class representing a configuration entry containing name, value and additional metadata.
- ConfigEntry(String, String) - Constructor for class org.apache.kafka.clients.admin.ConfigEntry
-
Create a configuration entry with the provided values.
- ConfigEntry(String, String, ConfigEntry.ConfigSource, boolean, boolean, List<ConfigEntry.ConfigSynonym>, ConfigEntry.ConfigType, String) - Constructor for class org.apache.kafka.clients.admin.ConfigEntry
-
Create a configuration with the provided values.
- ConfigEntry.ConfigSource - Enum Class in org.apache.kafka.clients.admin
-
Source of configuration entries.
- ConfigEntry.ConfigSynonym - Class in org.apache.kafka.clients.admin
-
Class representing a configuration synonym of a
ConfigEntry
. - ConfigEntry.ConfigType - Enum Class 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 Class in org.apache.kafka.common.config
-
Type of resource.
- configs() - Method in class org.apache.kafka.clients.admin.NewTopic
-
The configuration for the new topic or null if no configs ever specified.
- configs() - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Get the Task configuration.
- configs() - Method in interface org.apache.kafka.connect.source.SourceTaskContext
-
Get the Task configuration.
- configs() - Method in class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
-
Return the configs in the request.
- configs() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
-
Return topic configs in the request, not including broker defaults.
- configs(Map<String, String>) - Method in class org.apache.kafka.clients.admin.NewTopic
-
Set the configuration to use on the new topic.
- ConfigTransformer - Class in org.apache.kafka.common.config
-
This class wraps a set 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
-
Deprecated.
- 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 interface org.apache.kafka.common.security.auth.SecurityProviderCreator
-
Configure method is used to configure the generator to create the Security Provider
- configure(Map<String, ?>) - Method in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
- configure(Map<String, ?>) - Method in class org.apache.kafka.connect.mirror.IdentityReplicationPolicy
- configure(Map<String, ?>) - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
- configure(Map<String, ?>) - Method in class org.apache.kafka.connect.storage.StringConverter
- configure(Map<String, ?>) - Method in class org.apache.kafka.streams.errors.DefaultProductionExceptionHandler
- configure(Map<String, ?>) - Method in class org.apache.kafka.streams.errors.LogAndContinueExceptionHandler
- configure(Map<String, ?>) - Method in class org.apache.kafka.streams.errors.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.ListDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.ListSerializer
- configure(Map<String, ?>, boolean) - Method in interface org.apache.kafka.common.serialization.Serde
-
Configure this class, which will configure the underlying serializer and deserializer.
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.Serdes.WrapperSerde
- configure(Map<String, ?>, boolean) - Method in interface org.apache.kafka.common.serialization.Serializer
-
Configure this class.
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.StringDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.StringSerializer
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.UUIDDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.UUIDSerializer
- configure(Map<String, ?>, boolean) - Method in interface org.apache.kafka.connect.storage.Converter
-
Configure this class.
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.connect.storage.StringConverter
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.SessionWindowedSerializer
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.TimeWindowedSerializer
- configure(Map<String, ?>, String, List<AppConfigurationEntry>) - Method in interface org.apache.kafka.common.security.auth.AuthenticateCallbackHandler
-
Configures this callback handler for the specified SASL mechanism.
- configure(Map<String, ?>, String, List<AppConfigurationEntry>) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- configure(Map<String, ?>, String, List<AppConfigurationEntry>) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallbackHandler
- configure(Map<String, ?>, String, Configuration, AuthenticateCallbackHandler) - Method in interface org.apache.kafka.common.security.auth.Login
-
Configures this login instance.
- ConfigValue - Class in org.apache.kafka.common.config
- ConfigValue(String) - Constructor for class org.apache.kafka.common.config.ConfigValue
- ConfigValue(String, Object, List<Object>, List<String>) - Constructor for class org.apache.kafka.common.config.ConfigValue
- configValues() - Method in class org.apache.kafka.common.config.Config
- ConnectClusterDetails - Interface in org.apache.kafka.connect.health
-
Provides immutable Connect cluster information, such as the ID of the backing Kafka cluster.
- ConnectClusterState - Interface in org.apache.kafka.connect.health
-
Provides the ability to lookup connector metadata, including status and configurations, as well as immutable cluster information such as Kafka cluster ID.
- ConnectedStoreProvider - Interface in org.apache.kafka.streams.processor
-
Provides a set of
StoreBuilder
s 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
- CONNECTOR - Enum constant in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
-
Transactions will be defined by the connector itself, via a
TransactionContext
. - 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 Class in org.apache.kafka.connect.connector.policy
- connectorConfig(String) - Method in interface org.apache.kafka.connect.health.ConnectClusterState
-
Lookup the current configuration of a connector.
- ConnectorContext - Interface in org.apache.kafka.connect.connector
-
ConnectorContext 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.
- ConnectorTransactionBoundaries - Enum Class in org.apache.kafka.connect.source
-
An enum to represent the level of support for connector-defined transaction boundaries.
- connectorType() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
-
Type of the Connector.
- ConnectorType - Enum Class in org.apache.kafka.connect.health
-
Enum definition that identifies the type of the connector.
- ConnectorUtils - Class in org.apache.kafka.connect.util
-
Utilities that connector implementations might find useful.
- ConnectorUtils() - Constructor for class org.apache.kafka.connect.util.ConnectorUtils
- connectProcessorAndStateStores(String, String...) - Method in class org.apache.kafka.streams.Topology
-
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-RSConfigurable
and cluster stateConnectClusterState
. - ConnectSchema - Class in org.apache.kafka.connect.data
- ConnectSchema(Schema.Type) - Constructor for class org.apache.kafka.connect.data.ConnectSchema
-
Construct a default schema for a primitive type.
- ConnectSchema(Schema.Type, boolean, Object, String, Integer, String) - Constructor for class org.apache.kafka.connect.data.ConnectSchema
-
Construct a Schema for a primitive type, setting schema parameters, struct fields, and key and value schemas to null.
- ConnectSchema(Schema.Type, boolean, Object, String, Integer, String, Map<String, String>, List<Field>, Schema, Schema) - Constructor for class org.apache.kafka.connect.data.ConnectSchema
-
Construct a Schema.
- CONSTANT - Enum constant in enum class org.apache.kafka.common.metrics.stats.Percentiles.BucketSizing
- ConstantBinScheme(int, double, double) - Constructor for class org.apache.kafka.common.metrics.stats.Histogram.ConstantBinScheme
-
Create a bin scheme with the specified number of bins that all have the same width.
- Consumed<K,
V> - Class in org.apache.kafka.streams.kstream -
The
Consumed
class is used to define the optional parameters when usingStreamsBuilder
to build instances ofKStream
,KTable
, andGlobalKTable
. - 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 - Enum constant in enum class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
- CONSUMER_CLIENT_PREFIX - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- CONSUMER_GROUP_ID_KEY - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
- CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to isolate
consumer
configs from other client configs. - consumerClientId() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
Deprecated.
- consumerClientId() - Method in interface org.apache.kafka.streams.ThreadMetadata
-
Client ID of the Kafka consumer used by the stream thread.
- 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
- ConsumerGroupDescription(String, boolean, Collection<MemberDescription>, String, ConsumerGroupState, Node, Set<AclOperation>) - 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 Class 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 Class in org.apache.kafka.clients.consumer
-
The rebalance protocol defines partition assignment and revocation semantics.
- ConsumerPartitionAssignor.Subscription - Class in org.apache.kafka.clients.consumer
- consumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
Prefix a property 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, int, int, K, V, Headers, Optional<Integer>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
-
Creates a record to be received from a specified topic and partition
- ConsumerRecord(String, int, long, long, TimestampType, long, int, int, K, V) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
-
Deprecated.use one of the constructors without a `checksum` parameter. This constructor will be removed in Apache Kafka 4.0 (deprecated since 3.0).
- ConsumerRecord(String, int, long, long, TimestampType, Long, int, int, K, V, Headers) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
-
Deprecated.use one of the constructors without a `checksum` parameter. This constructor will be removed in Apache Kafka 4.0 (deprecated since 3.0).
- ConsumerRecord(String, int, long, long, TimestampType, Long, int, int, K, V, Headers, Optional<Integer>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
-
Deprecated.use one of the constructors without a `checksum` parameter. This constructor will be removed in Apache Kafka 4.0 (deprecated since 3.0).
- ConsumerRecord(String, int, long, K, V) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
-
Creates a record to be received from a specified topic and partition (provided for compatibility with Kafka 0.9 before the message format supported timestamps and before serialized metadata were exposed).
- ConsumerRecords<K,
V> - Class in org.apache.kafka.clients.consumer -
A container that holds the 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
-
Deprecated.
- 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
-
Deprecated.Get the processor's context set during
initialization
. - context() - Method in class org.apache.kafka.streams.processor.api.ContextualFixedKeyProcessor
-
Get the processor's context set during
initialization
. - context() - Method in class org.apache.kafka.streams.processor.api.ContextualProcessor
-
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.
- ContextualFixedKeyProcessor<KIn,
VIn, VOut> - Class in org.apache.kafka.streams.processor.api -
An abstract implementation of
FixedKeyProcessor
that manages theFixedKeyProcessorContext
instance and provides default no-op implementation ofFixedKeyProcessor.close()
. - ContextualFixedKeyProcessor() - Constructor for class org.apache.kafka.streams.processor.api.ContextualFixedKeyProcessor
- ContextualProcessor<KIn,
VIn, KOut, VOut> - Class in org.apache.kafka.streams.processor.api -
An abstract implementation of
Processor
that manages theProcessorContext
instance and provides default no-op implementation ofProcessor.close()
. - ContextualProcessor() - Constructor for class org.apache.kafka.streams.processor.api.ContextualProcessor
- CONTINUE - Enum constant in enum class org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
- CONTINUE - Enum constant in enum class 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 - Enum constant in enum class 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
andHeaderConverter
instances. - ConverterConfig(ConfigDef, Map<String, ?>) - Constructor for class org.apache.kafka.connect.storage.ConverterConfig
- ConverterType - Enum Class in org.apache.kafka.connect.storage
-
The type of
Converter
andHeaderConverter
. - 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 - Enum constant in enum class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
- COOPERATIVE_STICKY_ASSIGNOR_NAME - Static variable in class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
- CooperativeStickyAssignor - Class in org.apache.kafka.clients.consumer
-
A cooperative version of 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.
- coordinatorEpoch() - Method in class org.apache.kafka.clients.admin.AbortTransactionSpec
- coordinatorEpoch() - Method in class org.apache.kafka.clients.admin.ProducerState
- coordinatorId() - Method in class org.apache.kafka.clients.admin.TransactionDescription
- CoordinatorLoadInProgressException - Exception 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. after a leader change for that group metadata topic partition).
- 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
- copy() - Method in class org.apache.kafka.streams.query.Position
-
Create a deep copy of the Position.
- COPY_SEGMENT_FINISHED - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
-
This state indicates that the segment copying to remote storage is finished.
- COPY_SEGMENT_STARTED - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
-
This state indicates that the segment copying to remote storage is started but not yet finished.
- copyLogSegmentData(RemoteLogSegmentMetadata, LogSegmentData) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteStorageManager
-
Copies the given
LogSegmentData
provided for the givenremoteLogSegmentMetadata
. - correlationId() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
-
Returns the correlation id from the request header.
- corruptedTasks() - Method in exception 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() - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Count the number of records in this stream by the grouped key and defined sessions.
- count() - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Count the number of records in this stream by the grouped key and defined windows.
- count(Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Count the number of records in this stream by the grouped key.
- count(Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- count(Materialized<K, Long, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Count the number of records in this stream by the grouped key and defined sessions.
- count(Materialized<K, Long, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Count the number of records in this stream by the grouped key and defined windows.
- count(Named) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Count the number of records in this stream by the grouped key.
- count(Named) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- count(Named) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Count the number of records in this stream by the grouped key and defined sessions.
- count(Named) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Count the number of records in this stream by the grouped key and defined windows.
- count(Named, Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Count the number of records in this stream by the grouped key.
- count(Named, Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
- count(Named, Materialized<K, Long, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Count the number of records in this stream by the grouped key and defined sessions.
- count(Named, Materialized<K, Long, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Count the number of records in this stream by the grouped key and defined windows.
- counts() - Method in class org.apache.kafka.common.metrics.stats.Histogram
- create(Map<String, Object>) - Static method in interface org.apache.kafka.clients.admin.Admin
-
Create a new Admin with the given configuration.
- create(Map<String, Object>) - Static method in class org.apache.kafka.clients.admin.AdminClient
-
Create a new Admin with the given configuration.
- create(Properties) - Static method in interface org.apache.kafka.clients.admin.Admin
-
Create a new Admin with the given configuration.
- create(Properties) - Static method in class org.apache.kafka.clients.admin.AdminClient
-
Create a new Admin with the given configuration.
- create(Record<KIn, VIn>) - Static method in class org.apache.kafka.streams.processor.api.InternalFixedKeyRecordFactory
-
Only allowed way to create
FixedKeyRecord
s. - 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 underlyingStateStore
s. - create(StateStoreProvider, String) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.KeyValueStoreType
- create(StateStoreProvider, String) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.SessionStoreType
- create(StateStoreProvider, String) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.WindowStoreType
- CREATE - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
-
CREATE operation.
- CREATE_TOKENS - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
-
CREATE_TOKENS operation.
- createAcls(Collection<AclBinding>) - Method in interface org.apache.kafka.clients.admin.Admin
-
This is a convenience method 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.ForwardingAdmin
- createAcls(Collection<AclBinding>, CreateAclsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- createAcls(AuthorizableRequestContext, List<AclBinding>) - Method in interface org.apache.kafka.server.authorizer.Authorizer
-
Creates new ACL bindings.
- CreateAclsOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.createAcls(Collection)
. - 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 - Enum constant in enum class org.apache.kafka.streams.KafkaStreams.State
- createDelegationToken() - Method in interface org.apache.kafka.clients.admin.Admin
-
Create a Delegation Token.
- createDelegationToken(CreateDelegationTokenOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Create a Delegation Token.
- createDelegationToken(CreateDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- createDelegationToken(CreateDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- CreateDelegationTokenOptions - Class in org.apache.kafka.clients.admin
- CreateDelegationTokenOptions() - Constructor for class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
- CreateDelegationTokenResult - Class in org.apache.kafka.clients.admin
-
The result of the
KafkaAdminClient.createDelegationToken(CreateDelegationTokenOptions)
call. - 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.ForwardingAdmin
- createPartitions(Map<String, NewPartitions>, CreatePartitionsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- CreatePartitionsOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.createPartitions(Map)
. - 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.ForwardingAdmin
- createTopics(Collection<NewTopic>, CreateTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- CreateTopicsOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.createTopics(Collection)
. - CreateTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.CreateTopicsOptions
- CreateTopicsResult - Class in org.apache.kafka.clients.admin
-
The result of
Admin.createTopics(Collection)
. - CreateTopicsResult(Map<String, KafkaFuture<CreateTopicsResult.TopicMetadataAndConfig>>) - Constructor for class org.apache.kafka.clients.admin.CreateTopicsResult
- CreateTopicsResult.TopicMetadataAndConfig - Class in org.apache.kafka.clients.admin
- createWithUpdates(RemoteLogSegmentMetadataUpdate) - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
-
Creates a new RemoteLogSegmentMetadata applying the given
rlsmUpdate
on this instance. - 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
- currentLag(TopicPartition) - Method in interface org.apache.kafka.clients.consumer.Consumer
- currentLag(TopicPartition) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Get the consumer's current lag on the partition.
- currentLag(TopicPartition) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- currentOffsetPosition() - Method in class org.apache.kafka.streams.LagInfo
-
Get the current maximum offset on the store partition's changelog topic, that has been successfully written into the store partition's state store.
- currentStreamTimeMs() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- currentStreamTimeMs() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
-
Return the current stream-time in milliseconds.
- currentStreamTimeMs() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- currentStreamTimeMs() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return the current stream-time in milliseconds.
- currentSystemTimeMs() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- currentSystemTimeMs() - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
-
Return the current system timestamp (also called wall-clock time) in milliseconds.
- currentSystemTimeMs() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- currentSystemTimeMs() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Return the current system timestamp (also called wall-clock time) in milliseconds.
- currentTransactionStartOffset() - Method in class org.apache.kafka.clients.admin.ProducerState
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 - Enum constant in enum class org.apache.kafka.common.ConsumerGroupState
- DEBUG - Enum constant in enum class org.apache.kafka.common.metrics.Sensor.RecordingLevel
- DEBUG_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
-
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 - Static variable in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
-
The default transaction boundary style that will be used for source connectors when no style is explicitly configured.
- DEFAULT_ALLOW_AUTO_CREATE_TOPICS - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
- DEFAULT_API_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- DEFAULT_API_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
default.api.timeout.ms
- DEFAULT_CLIENT_ID - Enum constant in enum class org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
- DEFAULT_CONFIG - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
- DEFAULT_DESERIALIZATION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
default.deserialization.exception.handler
- DEFAULT_DESERIALIZATION_EXCEPTION_HANDLER_CLASS_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- DEFAULT_DSL_STORE_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
default.dsl.store
- DEFAULT_DSL_STORE_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- 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_PRODUCTION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
default.production.exception.handler
- DEFAULT_SASL_LOGIN_RETRY_BACKOFF_MAX_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_LOGIN_RETRY_BACKOFF_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_MECHANISM - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_OAUTHBEARER_CLOCK_SKEW_SECONDS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_OAUTHBEARER_JWKS_ENDPOINT_REFRESH_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_OAUTHBEARER_JWKS_ENDPOINT_RETRY_BACKOFF_MAX_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_OAUTHBEARER_JWKS_ENDPOINT_RETRY_BACKOFF_MS - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_OAUTHBEARER_SCOPE_CLAIM_NAME - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SASL_OAUTHBEARER_SUB_CLAIM_NAME - Static variable in class org.apache.kafka.common.config.SaslConfigs
- DEFAULT_SECURITY_PROTOCOL - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
- DEFAULT_SSL_ENABLED_PROTOCOLS - Static variable in class org.apache.kafka.common.config.SslConfigs
- DEFAULT_SSL_ENDPOINT_IDENTIFICATION_ALGORITHM - Static variable in class org.apache.kafka.common.config.SslConfigs
- DEFAULT_SSL_KEYMANGER_ALGORITHM - Static variable in class org.apache.kafka.common.config.SslConfigs
- DEFAULT_SSL_KEYSTORE_TYPE - Static variable in class org.apache.kafka.common.config.SslConfigs
- DEFAULT_SSL_PROTOCOL - Static variable in class org.apache.kafka.common.config.SslConfigs
- DEFAULT_SSL_TRUSTMANAGER_ALGORITHM - Static variable in class org.apache.kafka.common.config.SslConfigs
- DEFAULT_SSL_TRUSTSTORE_TYPE - Static variable in class org.apache.kafka.common.config.SslConfigs
- DEFAULT_TIMESTAMP_EXTRACTOR_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
default.timestamp.extractor
- DEFAULT_TIMESTAMP_EXTRACTOR_CLASS_DOC - Static variable in class org.apache.kafka.streams.StreamsConfig
- DEFAULT_USER - Enum constant in enum class org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
- DEFAULT_VALUE_SERDE_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
default value.serde
- DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- 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 ofkey Serde class
. - 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 ofvalue Serde class
. - define(String, ConfigDef.Type, Object, ConfigDef.Importance, String) - Method in class org.apache.kafka.common.config.ConfigDef
-
Define a new configuration with no special validation logic
- define(String, ConfigDef.Type, Object, ConfigDef.Importance, String, String, 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 - Enum constant in enum class org.apache.kafka.common.resource.ResourceType
-
A token ID.
- delegationToken() - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenResult
-
Returns a future which yields a delegation token
- DelegationToken - Class in org.apache.kafka.common.security.token.delegation
-
A class representing a delegation token.
- DelegationToken(TokenInformation, byte[]) - Constructor for class org.apache.kafka.common.security.token.delegation.DelegationToken
- DelegationTokenAuthorizationException - Exception 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 - Enum constant in enum class org.apache.kafka.clients.admin.AlterConfigOp.OpType
-
Revert the configuration entry to the default value (possibly null).
- DELETE - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
-
DELETE operation.
- DELETE_PARTITION_FINISHED - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
-
This state indicates that the partition is deleted successfully.
- DELETE_PARTITION_MARKED - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
-
This is used when a topic/partition is marked for delete by the controller.
- DELETE_PARTITION_STARTED - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
-
This state indicates that the partition deletion is started but not yet finished.
- DELETE_RETENTION_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
- DELETE_RETENTION_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
- DELETE_SEGMENT_FINISHED - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
-
This state indicates that the segment is deleted successfully.
- DELETE_SEGMENT_STARTED - Enum constant in enum class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
-
This state indicates that the segment deletion is started but not yet finished.
- deleteAcls(Collection<AclBindingFilter>) - Method in interface org.apache.kafka.clients.admin.Admin
-
This is a convenience method 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.ForwardingAdmin
- deleteAcls(Collection<AclBindingFilter>, DeleteAclsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- deleteAcls(AuthorizableRequestContext, List<AclBindingFilter>) - Method in interface org.apache.kafka.server.authorizer.Authorizer
-
Deletes all ACL bindings that match the provided filters.
- DeleteAclsOptions - Class in org.apache.kafka.clients.admin
-
Options for 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.ForwardingAdmin
- deleteConsumerGroupOffsets(String, Set<TopicPartition>, DeleteConsumerGroupOffsetsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DeleteConsumerGroupOffsetsOptions - Class in org.apache.kafka.clients.admin
-
Options for the
Admin.deleteConsumerGroupOffsets(String, Set)
call. - DeleteConsumerGroupOffsetsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteConsumerGroupOffsetsOptions
- DeleteConsumerGroupOffsetsResult - Class in org.apache.kafka.clients.admin
-
The result of the
Admin.deleteConsumerGroupOffsets(String, Set)
call. - deleteConsumerGroups(Collection<String>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Delete consumer groups from the cluster with the default options.
- deleteConsumerGroups(Collection<String>, DeleteConsumerGroupsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Delete consumer groups from the cluster.
- deleteConsumerGroups(Collection<String>, DeleteConsumerGroupsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- deleteConsumerGroups(Collection<String>, DeleteConsumerGroupsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DeleteConsumerGroupsOptions - Class in org.apache.kafka.clients.admin
-
Options for the
Admin.deleteConsumerGroups(Collection)
call. - DeleteConsumerGroupsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteConsumerGroupsOptions
- DeleteConsumerGroupsResult - Class in org.apache.kafka.clients.admin
-
The result of the
Admin.deleteConsumerGroups(Collection)
call. - deletedGroups() - Method in class org.apache.kafka.clients.admin.DeleteConsumerGroupsResult
-
Return a map from group id to futures which can be used to check the status of individual deletions.
- DeletedRecords - Class in org.apache.kafka.clients.admin
-
Represents information about deleted records 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.
- deleteLogSegmentData(RemoteLogSegmentMetadata) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteStorageManager
-
Deletes the resources associated with the given
remoteLogSegmentMetadata
. - deleteRecords(Map<TopicPartition, RecordsToDelete>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Delete records whose offset is smaller than the given offset of the corresponding partition.
- deleteRecords(Map<TopicPartition, RecordsToDelete>, DeleteRecordsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Delete records whose offset is smaller than the given offset of the corresponding partition.
- deleteRecords(Map<TopicPartition, RecordsToDelete>, DeleteRecordsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- deleteRecords(Map<TopicPartition, RecordsToDelete>, DeleteRecordsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DeleteRecordsOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.deleteRecords(Map, DeleteRecordsOptions)
. - 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(TopicCollection, DeleteTopicsOptions)
with default options. - deleteTopics(Collection<String>, DeleteTopicsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
This is a convenience method for
Admin.deleteTopics(TopicCollection, DeleteTopicsOptions)
with default options. - deleteTopics(TopicCollection) - Method in interface org.apache.kafka.clients.admin.Admin
-
This is a convenience method for
Admin.deleteTopics(TopicCollection, DeleteTopicsOptions)
with default options. - deleteTopics(TopicCollection, DeleteTopicsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Delete a batch of topics.
- deleteTopics(TopicCollection, DeleteTopicsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- deleteTopics(TopicCollection, DeleteTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DeleteTopicsOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.deleteTopics(Collection)
. - 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. - DeleteTopicsResult(Map<Uuid, KafkaFuture<Void>>, Map<String, KafkaFuture<Void>>) - Constructor for class org.apache.kafka.clients.admin.DeleteTopicsResult
- DELIVERY_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
delivery.timeout.ms
- DENIED - Enum constant in enum class org.apache.kafka.server.authorizer.AuthorizationResult
- DENY - Enum constant in enum class org.apache.kafka.common.acl.AclPermissionType
-
Disallows access.
- dependents - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
- DEPRECATED_DEFAULT_24_HR_GRACE_PERIOD - Static variable in class org.apache.kafka.streams.kstream.Windows
-
By default grace period is 24 hours for all windows in other words we allow out-of-order data for up to a day This behavior is now deprecated and additional details are available in the motivation for the KIP Check out KIP-633 for more details
- describe() - Method in class org.apache.kafka.streams.Topology
-
Returns a description of the specified
Topology
. - DESCRIBE - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
-
DESCRIBE operation.
- DESCRIBE_CONFIGS - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
-
DESCRIBE_CONFIGS operation.
- DESCRIBE_TOKENS - Enum constant in enum class org.apache.kafka.common.acl.AclOperation
-
DESCRIBE_TOKENS operation.
- describeAcls(AclBindingFilter) - Method in interface org.apache.kafka.clients.admin.Admin
-
This is a convenience method 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.ForwardingAdmin
- describeAcls(AclBindingFilter, DescribeAclsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeAclsOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.describeAcls(AclBindingFilter)
. - 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.ForwardingAdmin
- describeClientQuotas(ClientQuotaFilter, DescribeClientQuotasOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeClientQuotasOptions - Class in org.apache.kafka.clients.admin
- DescribeClientQuotasOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeClientQuotasOptions
- DescribeClientQuotasResult - Class in org.apache.kafka.clients.admin
-
The result of the
Admin.describeClientQuotas(ClientQuotaFilter, DescribeClientQuotasOptions)
call. - DescribeClientQuotasResult(KafkaFuture<Map<ClientQuotaEntity, Map<String, Double>>>) - Constructor for class org.apache.kafka.clients.admin.DescribeClientQuotasResult
-
Maps an entity to its configured quota value(s).
- describeCluster() - Method in interface org.apache.kafka.clients.admin.Admin
-
Get information about the nodes in the cluster, using the default options.
- describeCluster(DescribeClusterOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Get information about the nodes in the cluster.
- describeCluster(DescribeClusterOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeCluster(DescribeClusterOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeClusterOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.describeCluster()
. - 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.ForwardingAdmin
- describeConfigs(Collection<ConfigResource>, DescribeConfigsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeConfigsOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.describeConfigs(Collection)
. - 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. - DescribeConfigsResult(Map<ConfigResource, KafkaFuture<Config>>) - Constructor for class org.apache.kafka.clients.admin.DescribeConfigsResult
- 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.ForwardingAdmin
- describeConsumerGroups(Collection<String>, DescribeConsumerGroupsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeConsumerGroupsOptions - Class in org.apache.kafka.clients.admin
- DescribeConsumerGroupsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeConsumerGroupsOptions
- DescribeConsumerGroupsResult - Class in org.apache.kafka.clients.admin
-
The result of the
KafkaAdminClient.describeConsumerGroups(Collection, DescribeConsumerGroupsOptions)
} call. - DescribeConsumerGroupsResult(Map<String, KafkaFuture<ConsumerGroupDescription>>) - Constructor for class org.apache.kafka.clients.admin.DescribeConsumerGroupsResult
- describeDelegationToken() - Method in interface org.apache.kafka.clients.admin.Admin
-
Describe the Delegation Tokens.
- describeDelegationToken(DescribeDelegationTokenOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Describe the Delegation Tokens.
- describeDelegationToken(DescribeDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeDelegationToken(DescribeDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeDelegationTokenOptions - Class in org.apache.kafka.clients.admin
- DescribeDelegationTokenOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeDelegationTokenOptions
- DescribeDelegationTokenResult - Class in org.apache.kafka.clients.admin
-
The result of the
KafkaAdminClient.describeDelegationToken(DescribeDelegationTokenOptions)
call. - 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.ForwardingAdmin
- describeFeatures(DescribeFeaturesOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeFeaturesOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.describeFeatures(DescribeFeaturesOptions)
. - DescribeFeaturesOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeFeaturesOptions
- DescribeFeaturesResult - Class in org.apache.kafka.clients.admin
-
The result of the
Admin.describeFeatures(DescribeFeaturesOptions)
call. - describeLogDirs(Collection<Integer>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Query the information of all log directories on the given set of brokers
- describeLogDirs(Collection<Integer>, DescribeLogDirsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Query the information of all log directories on the given set of brokers
- describeLogDirs(Collection<Integer>, DescribeLogDirsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeLogDirs(Collection<Integer>, DescribeLogDirsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeLogDirsOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.describeLogDirs(Collection)
The API of this class is evolving, seeAdmin
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. - describeMetadataQuorum() - Method in interface org.apache.kafka.clients.admin.Admin
-
Describes the state of the metadata quorum.
- describeMetadataQuorum(DescribeMetadataQuorumOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Describes the state of the metadata quorum.
- describeMetadataQuorum(DescribeMetadataQuorumOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeMetadataQuorum(DescribeMetadataQuorumOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeMetadataQuorumOptions - Class in org.apache.kafka.clients.admin
- DescribeMetadataQuorumOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeMetadataQuorumOptions
- DescribeMetadataQuorumResult - Class in org.apache.kafka.clients.admin
- describeProducers(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Describe producer state on a set of topic partitions.
- describeProducers(Collection<TopicPartition>, DescribeProducersOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Describe active producer state on a set of topic partitions.
- describeProducers(Collection<TopicPartition>, DescribeProducersOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeProducers(Collection<TopicPartition>, DescribeProducersOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeProducersOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.describeProducers(Collection)
. - DescribeProducersOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeProducersOptions
- DescribeProducersResult - Class in org.apache.kafka.clients.admin
- DescribeProducersResult.PartitionProducerState - Class in org.apache.kafka.clients.admin
- describeReplicaLogDirs(Collection<TopicPartitionReplica>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Query the replica log directory information for the specified replicas.
- describeReplicaLogDirs(Collection<TopicPartitionReplica>, DescribeReplicaLogDirsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Query the replica log directory information for the specified replicas.
- describeReplicaLogDirs(Collection<TopicPartitionReplica>, DescribeReplicaLogDirsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeReplicaLogDirs(Collection<TopicPartitionReplica>, DescribeReplicaLogDirsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeReplicaLogDirsOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.describeReplicaLogDirs(Collection)
. - DescribeReplicaLogDirsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeReplicaLogDirsOptions
- DescribeReplicaLogDirsResult - Class in org.apache.kafka.clients.admin
-
The result of
Admin.describeReplicaLogDirs(Collection)
. - 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(TopicCollection) - Method in interface org.apache.kafka.clients.admin.Admin
-
This is a convenience method for
Admin.describeTopics(TopicCollection, DescribeTopicsOptions)
with default options. - describeTopics(TopicCollection, DescribeTopicsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Describe some topics in the cluster.
- describeTopics(TopicCollection, DescribeTopicsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeTopics(TopicCollection, DescribeTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeTopicsOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.describeTopics(Collection)
. - 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
-
Deprecated.
- DescribeTopicsResult(Map<Uuid, KafkaFuture<TopicDescription>>, Map<String, KafkaFuture<TopicDescription>>) - Constructor for class org.apache.kafka.clients.admin.DescribeTopicsResult
- describeTransactions(Collection<String>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Describe the state of a set of transactional IDs.
- describeTransactions(Collection<String>, DescribeTransactionsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Describe the state of a set of transactional IDs from the respective transaction coordinators, which are dynamically discovered.
- describeTransactions(Collection<String>, DescribeTransactionsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeTransactions(Collection<String>, DescribeTransactionsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeTransactionsOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.describeTransactions(Collection)
. - DescribeTransactionsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeTransactionsOptions
- DescribeTransactionsResult - Class in org.apache.kafka.clients.admin
- describeUserScramCredentials() - Method in interface org.apache.kafka.clients.admin.Admin
-
Describe all SASL/SCRAM credentials.
- describeUserScramCredentials(List<String>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Describe SASL/SCRAM credentials for the given users.
- describeUserScramCredentials(List<String>, DescribeUserScramCredentialsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Describe SASL/SCRAM credentials.
- describeUserScramCredentials(List<String>, DescribeUserScramCredentialsOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- describeUserScramCredentials(List<String>, DescribeUserScramCredentialsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- DescribeUserScramCredentialsOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.describeUserScramCredentials(List, DescribeUserScramCredentialsOptions)
The API of this class is evolving. - 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.DescribeTransactionsResult
-
Get the description of a specific transactional ID.
- description(String) - Method in class org.apache.kafka.clients.admin.DescribeUserScramCredentialsResult
- descriptions() - Method in class org.apache.kafka.clients.admin.DescribeLogDirsResult
-
Return a map from brokerId to future which can be used to check the information of partitions on each individual broker.
- deserializationExceptionHandler - Variable in class org.apache.kafka.streams.TopologyConfig.TaskConfig
- DeserializationExceptionHandler - Interface in org.apache.kafka.streams.errors
-
Interface that specifies how an exception from source node deserialization (e.g., reading from Kafka) should be handled.
- DeserializationExceptionHandler.DeserializationHandlerResponse - Enum Class in org.apache.kafka.streams.errors
-
Enumeration that describes the response from the exception handler.
- deserializationExceptionHandlerSupplier - Variable in class org.apache.kafka.streams.TopologyConfig
- deserialize(byte[]) - Method in interface org.apache.kafka.common.security.auth.KafkaPrincipalSerde
-
Deserialize 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.FloatDeserializer
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.IntegerDeserializer
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ListDeserializer
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.LongDeserializer
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ShortDeserializer
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.StringDeserializer
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.UUIDDeserializer
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.VoidDeserializer
- deserialize(String, byte[]) - Method in class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
- deserialize(String, byte[]) - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
- deserialize(String, Headers, byte[]) - Method in interface org.apache.kafka.common.serialization.Deserializer
-
Deserialize a record value from a byte array into a value or object.
- 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
- DOES_NOT_EXIST - Enum constant in enum class org.apache.kafka.streams.query.FailureReason
-
The requested store partition does not exist at all.
- Double() - Static method in class org.apache.kafka.common.serialization.Serdes
-
A serde for nullable
Double
type. - DOUBLE - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigType
- DOUBLE - Enum constant in enum class org.apache.kafka.common.config.ConfigDef.Type
- 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
- dryRun() - Method in class org.apache.kafka.clients.admin.UpdateFeaturesOptions
-
Deprecated.
- dryRun(boolean) - Method in class org.apache.kafka.clients.admin.UpdateFeaturesOptions
-
Deprecated.
- 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 - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
- DYNAMIC_BROKER_LOGGER_CONFIG - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
- DYNAMIC_DEFAULT_BROKER_CONFIG - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
- DYNAMIC_TOPIC_CONFIG - Enum constant in enum class org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
E
- EAGER - Enum constant in enum class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
- earliest() - Static method in class org.apache.kafka.clients.admin.OffsetSpec
-
Used to retrieve the earliest offset of a partition
- EARLIEST - Enum constant in enum class org.apache.kafka.clients.consumer.OffsetResetStrategy
- EARLIEST - Enum constant in enum class org.apache.kafka.streams.Topology.AutoOffsetReset
- EarliestSpec() - Constructor for class org.apache.kafka.clients.admin.OffsetSpec.EarliestSpec
- earlyStartListeners() - Method in interface org.apache.kafka.server.authorizer.AuthorizerServerInfo
-
Returns the configured early start listeners.
- ElectionNotNeededException - Exception 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 Class in org.apache.kafka.common
- electLeaders(ElectionType, Set<TopicPartition>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Elect a replica as leader for topic partitions.
- electLeaders(ElectionType, Set<TopicPartition>, ElectLeadersOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Elect a replica as leader for the given
partitions
, or for all partitions if the argument topartitions
is null. - electLeaders(ElectionType, Set<TopicPartition>, ElectLeadersOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- electLeaders(ElectionType, Set<TopicPartition>, ElectLeadersOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- ElectLeadersOptions - Class in org.apache.kafka.clients.admin
- ElectLeadersOptions() - Constructor for class org.apache.kafka.clients.admin.ElectLeadersOptions
- ElectLeadersResult - Class in org.apache.kafka.clients.admin
-
The result of
Admin.electLeaders(ElectionType, Set, ElectLeadersOptions)
The API of this class is evolving, seeAdmin
for details. - 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
- EMIT_INTERVAL_MS_KSTREAMS_OUTER_JOIN_SPURIOUS_RESULTS_FIX - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- EMIT_INTERVAL_MS_KSTREAMS_WINDOWED_AGGREGATION - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- emitEarlyWhenFull() - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Set the buffer to just emit the oldest records when any of its constraints are violated.
- emitStrategy(EmitStrategy) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Configure when the aggregated result will be emitted for
SessionWindowedKStream
. - emitStrategy(EmitStrategy) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Configure when the aggregated result will be emitted for
TimeWindowedKStream
. - EmitStrategy - Interface in org.apache.kafka.streams.kstream
-
This interface controls the strategy that can be used to control how we emit results in a processor.
- EmitStrategy.StrategyType - Enum Class in org.apache.kafka.streams.kstream
- empty() - Static method in class org.apache.kafka.clients.consumer.ConsumerRecords
- empty() - Static method in class org.apache.kafka.common.Cluster
-
Create an empty cluster instance with no nodes and no topic-partitions.
- empty() - Static method in class org.apache.kafka.common.security.auth.SaslExtensions
-
Creates an "empty" instance indicating no SASL extensions.
- EMPTY - Enum constant in enum class org.apache.kafka.clients.admin.TransactionState
- EMPTY - Enum constant in enum class org.apache.kafka.common.ConsumerGroupState
- EMPTY - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecords
- emptyPosition() - Static method in class org.apache.kafka.streams.query.Position
-
Create a new, empty Position.
- ENABLE_AUTO_COMMIT_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
enable.auto.commit
- ENABLE_IDEMPOTENCE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
enable.idempotence
- ENABLE_IDEMPOTENCE_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
- enableExecutionInfo() - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
Requests for stores and the Streams runtime to record any useful details about how the query was executed.
- enableSpuriousResultFix - Variable in class org.apache.kafka.streams.kstream.JoinWindows
-
Enable left/outer stream-stream join, by not emitting left/outer results eagerly, but only after the grace period passed.
- 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
- endOffset() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- endOffsetPosition() - Method in class org.apache.kafka.streams.LagInfo
-
Get the end offset position for this store partition's changelog topic on the Kafka brokers.
- endOffsets() - Method in class org.apache.kafka.streams.processor.TaskMetadata
-
Deprecated.This function will return a map of TopicPartitions and the highest offset seen so far in the Topic
- endOffsets() - Method in interface org.apache.kafka.streams.TaskMetadata
-
End offsets of the source topic partitions of the task.
- endOffsets(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
- endOffsets(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Get the end offsets for the given partitions.
- endOffsets(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- endOffsets(Collection<TopicPartition>, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
- endOffsets(Collection<TopicPartition>, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Get the end offsets for the given partitions.
- endOffsets(Collection<TopicPartition>, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- Endpoint - Class in org.apache.kafka.common
-
Represents a broker endpoint.
- Endpoint(String, SecurityProtocol, String, int) - Constructor for class org.apache.kafka.common.Endpoint
- endpoints() - Method in 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
- enforceRebalance() - Method in class org.apache.kafka.clients.consumer.MockConsumer
- enforceRebalance(String) - Method in interface org.apache.kafka.clients.consumer.Consumer
- enforceRebalance(String) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Alert the consumer to trigger a new rebalance by rejoining the group.
- enforceRebalance(String) - Method in class org.apache.kafka.clients.consumer.MockConsumer
- ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.CaseInsensitiveValidString
- ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.CompositeValidator
- ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.LambdaValidator
- ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.ListSize
- ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.NonEmptyString
- ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.NonEmptyStringWithoutControlChars
- ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.NonNullValidator
- ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.Range
- ensureValid(String, Object) - Method in interface org.apache.kafka.common.config.ConfigDef.Validator
-
Perform single configuration validation.
- ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.ValidList
- ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.ValidString
- entities() - Method in class org.apache.kafka.clients.admin.DescribeClientQuotasResult
-
Returns a map from quota entity to a future which can be used to check the status of the operation.
- entity() - Method in class org.apache.kafka.common.quota.ClientQuotaAlteration
- entityType() - Method in class org.apache.kafka.common.quota.ClientQuotaFilterComponent
- entityType() - Method in interface org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntity
-
Returns the type of this entity.
- entries() - Method in class org.apache.kafka.clients.admin.Config
-
Configuration entries for a resource.
- entries() - Method in class org.apache.kafka.common.quota.ClientQuotaEntity
- entry() - Method in class org.apache.kafka.common.acl.AclBinding
- entryFilter() - Method in class org.apache.kafka.common.acl.AclBindingFilter
- eosEnabled - Variable in class org.apache.kafka.streams.TopologyConfig
- eosEnabled - Variable in class org.apache.kafka.streams.TopologyConfig.TaskConfig
- epochId(String) - Method in class org.apache.kafka.clients.admin.FenceProducersResult
-
Returns a future that provides the epoch ID generated while initializing the given transaction when the request completes.
- equals(Object) - Method in class org.apache.kafka.clients.admin.AbortTransactionSpec
- equals(Object) - Method in class org.apache.kafka.clients.admin.AlterConfigOp
- equals(Object) - Method in class org.apache.kafka.clients.admin.Config
- equals(Object) - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
- equals(Object) - Method in class org.apache.kafka.clients.admin.ConfigEntry
- equals(Object) - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
- equals(Object) - Method in class org.apache.kafka.clients.admin.ConsumerGroupListing
- equals(Object) - Method in class org.apache.kafka.clients.admin.DescribeProducersOptions
- equals(Object) - Method in class org.apache.kafka.clients.admin.FeatureMetadata
- equals(Object) - Method in class org.apache.kafka.clients.admin.FeatureUpdate
- equals(Object) - Method in class org.apache.kafka.clients.admin.FinalizedVersionRange
- equals(Object) - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsSpec
- equals(Object) - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
- equals(Object) - Method in class org.apache.kafka.clients.admin.ListTransactionsOptions
- equals(Object) - Method in class org.apache.kafka.clients.admin.MemberAssignment
- equals(Object) - Method in class org.apache.kafka.clients.admin.MemberDescription
- equals(Object) - Method in class org.apache.kafka.clients.admin.MemberToRemove
- equals(Object) - Method in class org.apache.kafka.clients.admin.NewTopic
- equals(Object) - Method in class org.apache.kafka.clients.admin.ProducerState
- equals(Object) - Method in class org.apache.kafka.clients.admin.QuorumInfo
- equals(Object) - Method in class org.apache.kafka.clients.admin.QuorumInfo.ReplicaState
- 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.TransactionDescription
- equals(Object) - Method in class org.apache.kafka.clients.admin.TransactionListing
- equals(Object) - Method in class org.apache.kafka.clients.admin.UserScramCredentialsDescription
- equals(Object) - Method in class org.apache.kafka.clients.consumer.ConsumerGroupMetadata
- equals(Object) - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
- equals(Object) - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
- equals(Object) - Method in class org.apache.kafka.clients.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.ResourcePattern
- equals(Object) - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
- equals(Object) - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
- equals(Object) - Method in class org.apache.kafka.common.security.auth.SaslExtensions
-
Implements equals using the reference comparison implementation from
Object.equals(Object)
. - equals(Object) - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
- equals(Object) - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
- equals(Object) - Method in class org.apache.kafka.common.TopicIdPartition
- equals(Object) - Method in class org.apache.kafka.common.TopicPartition
- equals(Object) - Method in class org.apache.kafka.common.TopicPartitionInfo
- equals(Object) - Method in class org.apache.kafka.common.TopicPartitionReplica
- equals(Object) - Method in class org.apache.kafka.common.Uuid
-
Returns true iff obj is another Uuid represented by the same two long values.
- equals(Object) - Method in class org.apache.kafka.connect.connector.ConnectRecord
- equals(Object) - Method in class org.apache.kafka.connect.data.ConnectSchema
- equals(Object) - Method in class org.apache.kafka.connect.data.Field
- equals(Object) - Method in class org.apache.kafka.connect.data.SchemaAndValue
- equals(Object) - Method in class org.apache.kafka.connect.data.Struct
- equals(Object) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- equals(Object) - Method in class org.apache.kafka.connect.health.AbstractState
- equals(Object) - Method in class org.apache.kafka.connect.health.ConnectorHealth
- equals(Object) - Method in class org.apache.kafka.connect.health.TaskState
- equals(Object) - Method in class org.apache.kafka.connect.mirror.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.server.log.remote.storage.LogSegmentData
- equals(Object) - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentId
- equals(Object) - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- equals(Object) - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
- equals(Object) - Method in class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteMetadata
- equals(Object) - Method in class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
- equals(Object) - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
- equals(Object) - Method in class org.apache.kafka.streams.KeyQueryMetadata
- equals(Object) - Method in class org.apache.kafka.streams.KeyValue
- equals(Object) - Method in class org.apache.kafka.streams.kstream.Consumed
- equals(Object) - Method in class org.apache.kafka.streams.kstream.JoinWindows
- equals(Object) - Method in class org.apache.kafka.streams.kstream.Produced
- equals(Object) - Method in class org.apache.kafka.streams.kstream.SessionWindows
- equals(Object) - Method in class org.apache.kafka.streams.kstream.SlidingWindows
- equals(Object) - Method in class org.apache.kafka.streams.kstream.TimeWindows
- equals(Object) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
- equals(Object) - Method in class org.apache.kafka.streams.kstream.Window
- equals(Object) - Method in class org.apache.kafka.streams.kstream.Windowed
- equals(Object) - Method in class org.apache.kafka.streams.LagInfo
- equals(Object) - Method in class org.apache.kafka.streams.processor.api.FixedKeyRecord
- equals(Object) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedForward
- equals(Object) - Method in class org.apache.kafka.streams.processor.api.Record
- equals(Object) - Method in class org.apache.kafka.streams.processor.TaskId
- equals(Object) - Method in class org.apache.kafka.streams.processor.TaskMetadata
-
Deprecated.
- equals(Object) - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
Deprecated.
- equals(Object) - Method in class org.apache.kafka.streams.processor.To
- equals(Object) - Method in class org.apache.kafka.streams.query.Position
- equals(Object) - Method in class org.apache.kafka.streams.query.PositionBound
- equals(Object) - Method in class org.apache.kafka.streams.state.HostInfo
- equals(Object) - Method in class org.apache.kafka.streams.state.StreamsMetadata
-
Deprecated.
- 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 interface org.apache.kafka.streams.StreamsMetadata
-
Compares the specified object with this StreamsMetadata.
- equals(Object) - Method in interface org.apache.kafka.streams.TaskMetadata
-
Compares the specified object with this TaskMetadata.
- equals(Object) - Method in class org.apache.kafka.streams.test.TestRecord
- equals(Object) - Method in interface org.apache.kafka.streams.ThreadMetadata
-
Compares the specified object with this ThreadMetadata.
- errantRecordReporter() - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Get the reporter to which the sink task can report problematic or failed
records
passed to theSinkTask.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
-
Set the error values as per RFC 6749: The OAuth 2.0 Authorization Framework.
- error(String, String, String) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
-
Set the error values as per RFC 7628: A Set of Simple Authentication and Security Layer (SASL) Mechanisms for OAuth.
- ERROR - Enum constant in enum class org.apache.kafka.streams.KafkaStreams.State
- ERROR_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
-
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
-
Return the (potentially null) error scope value as per RFC 7628: A Set of Simple Authentication and Security Layer (SASL) Mechanisms for OAuth.
- errorStatus() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
-
Return the (potentially null) error status value as per RFC 7628: A Set of Simple Authentication and Security Layer (SASL) Mechanisms for OAuth and the IANA OAuth Extensions Error Registry.
- errorUri() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback
-
Return the (potentially null) error URI as per RFC 6749: The OAuth 2.0 Authorization Framework.
- escape(String) - Static method in class org.apache.kafka.connect.data.Values
- eventCount - Variable in class org.apache.kafka.common.metrics.stats.SampledStat.Sample
- eventTimestampMs() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogMetadata
- eventWindow() - Method in class org.apache.kafka.common.metrics.MetricConfig
- eventWindow(long) - Method in class org.apache.kafka.common.metrics.MetricConfig
- EXACTLY_ONCE - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.Since 3.0.0, will be removed in 4.0. Use
"exactly_once_v2"
instead. - EXACTLY_ONCE_BETA - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.Since 3.0.0, will be removed in 4.0. Use
"exactly_once_v2"
instead. - EXACTLY_ONCE_V2 - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter
"processing.guarantee"
for exactly-once processing guarantees. - exactlyOnceSupport(Map<String, String>) - Method in class org.apache.kafka.connect.source.SourceConnector
-
Signals whether the connector supports exactly-once semantics with a proposed configuration.
- ExactlyOnceSupport - Enum Class in org.apache.kafka.connect.source
-
An enum to represent the level of support for exactly-once semantics from a source connector.
- exception() - Method in class org.apache.kafka.clients.admin.DeleteAclsResult.FilterResult
-
Return an exception if the ACL delete was not successful or null if it was.
- exception() - Method in class org.apache.kafka.server.authorizer.AclCreateResult
-
Returns any exception during create.
- exception() - Method in class org.apache.kafka.server.authorizer.AclDeleteResult.AclBindingDeleteResult
-
Returns any exception that resulted in failure to delete ACL binding.
- exception() - Method in class org.apache.kafka.server.authorizer.AclDeleteResult
-
Returns any exception while attempting to match ACL filter to delete ACLs.
- EXCLUDE_CONFIG - Static variable in class org.apache.kafka.common.metrics.JmxReporter
- EXCLUDE_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
- executionInfoEnabled() - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
Whether the request includes detailed execution information.
- expireDelegationToken(byte[]) - Method in interface org.apache.kafka.clients.admin.Admin
-
Expire a Delegation Token.
- expireDelegationToken(byte[], ExpireDelegationTokenOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Expire a Delegation Token.
- expireDelegationToken(byte[], ExpireDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- expireDelegationToken(byte[], ExpireDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- ExpireDelegationTokenOptions - Class in org.apache.kafka.clients.admin
- ExpireDelegationTokenOptions() - Constructor for class org.apache.kafka.clients.admin.ExpireDelegationTokenOptions
- ExpireDelegationTokenResult - Class in org.apache.kafka.clients.admin
-
The result of the
KafkaAdminClient.expireDelegationToken(byte[], ExpireDelegationTokenOptions)
call. - expiryTimePeriodMs() - Method in class org.apache.kafka.clients.admin.ExpireDelegationTokenOptions
- expiryTimePeriodMs(long) - Method in class org.apache.kafka.clients.admin.ExpireDelegationTokenOptions
- expiryTimestamp() - Method in class org.apache.kafka.clients.admin.ExpireDelegationTokenResult
-
Returns a future which yields expiry timestamp
- expiryTimestamp() - Method in class org.apache.kafka.clients.admin.RenewDelegationTokenResult
-
Returns a future which yields expiry timestamp
- expiryTimestamp() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
- 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 class org.apache.kafka.streams.processor.LogAndSkipOnInvalidTimestamp
-
Extracts the embedded metadata timestamp from the given
ConsumerRecord
. - extract(ConsumerRecord<Object, Object>, long) - Method in interface org.apache.kafka.streams.processor.TimestampExtractor
-
Extracts a timestamp from a record.
- extract(ConsumerRecord<Object, Object>, long) - Method in class org.apache.kafka.streams.processor.WallclockTimestampExtractor
-
Return the current wall clock time as timestamp.
F
- FAIL - Enum constant in enum class org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
- FAIL - Enum constant in enum class 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
- FailureReason - Enum Class in org.apache.kafka.streams.query
-
This enumeration type captures the various top-level reasons that a particular partition of a store would fail to execute a query.
- FATAL_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
-
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
-
Deprecated.
- FeatureUpdate(short, FeatureUpdate.UpgradeType) - Constructor for class org.apache.kafka.clients.admin.FeatureUpdate
- FeatureUpdate.UpgradeType - Enum Class in org.apache.kafka.clients.admin
- FeatureUpdateFailedException - Exception 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
- fencedProducers() - Method in class org.apache.kafka.clients.admin.FenceProducersResult
-
Return a map from transactional ID to futures which can be used to check the status of individual fencings.
- fenceProducer() - Method in class org.apache.kafka.clients.producer.MockProducer
- fenceProducers(Collection<String>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Fence out all active producers that use any of the provided transactional IDs, with the default options.
- fenceProducers(Collection<String>, FenceProducersOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Fence out all active producers that use any of the provided transactional IDs.
- fenceProducers(Collection<String>, FenceProducersOptions) - Method in class org.apache.kafka.clients.admin.ForwardingAdmin
- fenceProducers(Collection<String>, FenceProducersOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
- FenceProducersOptions - Class in org.apache.kafka.clients.admin
-
Options for
Admin.fenceProducers(Collection, FenceProducersOptions)
The API of this class is evolving. - FenceProducersOptions() - Constructor for class org.apache.kafka.clients.admin.FenceProducersOptions
- FenceProducersResult - Class in org.apache.kafka.clients.admin
-
The result of the
Admin.fenceProducers(Collection)
call. - fetch(K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Retrieve all aggregated sessions for the provided key.
- fetch(K, long) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
-
Get the value of key from a window.
- fetch(K, long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
-
Get all the key-value pairs with the given key and the time range from all the existing windows.
- fetch(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
-
Get all the key-value pairs with the given key and the time range from all the existing windows.
- fetch(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
- fetch(K, K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Retrieve all aggregated sessions for the given range of keys.
- fetch(K, K, long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
-
Get all the key-value pairs in the given key range and time range from all the existing windows.
- fetch(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
-
Get all the key-value pairs in the given key range and time range from all the existing windows.
- fetch(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
- FETCH - Enum constant in enum class org.apache.kafka.server.quota.ClientQuotaType
- FETCH_MAX_BYTES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
fetch.max.bytes
- FETCH_MAX_WAIT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
fetch.max.wait.ms
- FETCH_MIN_BYTES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
fetch.min.bytes
- fetchAll(long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
-
Gets all the key-value pairs that belong to the windows within in the given time range.
- fetchAll(Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
-
Gets all the key-value pairs that belong to the windows within in the given time range.
- fetchAll(Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
- fetchIndex(RemoteLogSegmentMetadata, RemoteStorageManager.IndexType) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteStorageManager
-
Returns the index for the respective log segment of
RemoteLogSegmentMetadata
. - fetchLogSegment(RemoteLogSegmentMetadata, int) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteStorageManager
-
Returns the remote log segment data file/object as InputStream for the given
RemoteLogSegmentMetadata
starting from the given startPosition. - fetchLogSegment(RemoteLogSegmentMetadata, int, int) - Method in interface org.apache.kafka.server.log.remote.storage.RemoteStorageManager
-
Returns the remote log segment data file/object as InputStream for the given
RemoteLogSegmentMetadata
starting from the given startPosition. - fetchSession(K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Get the value of key from a single session.
- fetchSession(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Get the value of key from a single session.
- fetchSession(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
- FetchSessionIdNotFoundException - Exception 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
- FetchSessionTopicIdException - Exception in org.apache.kafka.common.errors
- FetchSessionTopicIdException(String) - Constructor for exception org.apache.kafka.common.errors.FetchSessionTopicIdException
- field(String) - Method in class org.apache.kafka.connect.data.ConnectSchema
- field(String) - Method in interface org.apache.kafka.connect.data.Schema
-
Get 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
- 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.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 thisKTable
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 thisKTable
which satisfy the given predicate, with thekey serde
,value serde
, and the underlyingmaterialized state storage
configured in theMaterialized
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 thisKTable
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 thisKTable
which satisfy the given predicate, with thekey serde
,value serde
, and the underlyingmaterialized state storage
configured in theMaterialized
instance. - filteredProducerIds() - Method in class org.apache.kafka.clients.admin.ListTransactionsOptions
-
Returns the set of producerIds that are being filtered or empty if none have been specified.
- filteredStates() - Method in class org.apache.kafka.clients.admin.ListTransactionsOptions
-
Returns the set of states to be filtered or empty if no states have been specified.
- filterNot(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Create a 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 thisKTable
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 thisKTable
which do not satisfy the given predicate, with thekey serde
,value serde
, and the underlyingmaterialized state storage
configured in theMaterialized
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 thisKTable
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 thisKTable
which do not satisfy the given predicate, with thekey serde
,value serde
, and the underlyingmaterialized state storage
configured in theMaterialized
instance. - filterProducerIds(Collection<Long>) - Method in class org.apache.kafka.clients.admin.ListTransactionsOptions
-
Filter only the transactions from producers in a specific set of producerIds.
- filterStates(Collection<TransactionState>) - Method in class org.apache.kafka.clients.admin.ListTransactionsOptions
-
Filter only the transactions that are in a specific set of states.
- finalizedFeatures() - Method in class org.apache.kafka.clients.admin.FeatureMetadata
-
Returns a map of finalized feature versions.
- finalizedFeaturesEpoch() - Method in class org.apache.kafka.clients.admin.FeatureMetadata
-
The epoch for the finalized features.
- FinalizedVersionRange - Class in org.apache.kafka.clients.admin
-
Represents a range of version levels supported by every broker in a cluster for some feature.
- findIndefiniteField() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
-
Returns a string describing an ANY or UNKNOWN field, or null if there is no such field.
- findIndefiniteField() - Method in class org.apache.kafka.common.acl.AclBindingFilter
-
Return a string describing an ANY or UNKNOWN field, or null if there is no such field.
- findIndefiniteField() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
- findSessions(long, long) - Method in interface org.apache.kafka.streams.state.SessionStore
-
Return all the session window entries that ends between the specified range (both ends are inclusive).
- findSessions(K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Fetch any sessions with the matching key and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from earliest to latest.
- findSessions(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Fetch any sessions with the matching key and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from earliest to latest.
- findSessions(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
- findSessions(K, K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Fetch any sessions in the given range of keys and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from earliest to latest.
- findSessions(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Fetch any sessions in the given range of keys and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime iterating from earliest to latest.
- findSessions(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.SessionStore
- FixedKeyProcessor<KIn,
VIn, VOut> - Interface in org.apache.kafka.streams.processor.api -
A processor of key-value pair records where keys are immutable.
- FixedKeyProcessorContext<KForward,
VForward> - Interface in org.apache.kafka.streams.processor.api -
Processor context interface for
FixedKeyRecord
. - FixedKeyProcessorSupplier<KIn,
VIn, VOut> - Interface in org.apache.kafka.streams.processor.api -
A processor supplier that can create one or more
FixedKeyProcessor
instances. - FixedKeyRecord<K,
V> - Class in org.apache.kafka.streams.processor.api -
A data class representing an incoming record with fixed key for processing in a
FixedKeyProcessor
or a record to forward to downstream processors viaFixedKeyProcessorContext
. - flatMap(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into zero or more records in the output stream (both key and value type can be altered arbitrarily).
- flatMap(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into zero or more records in the output stream (both key and value type can be altered arbitrarily).
- flatMapValues(ValueMapper<? super V, ? extends Iterable<? extends VR>>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Create a 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
-
Deprecated.Since 3.3. Use
KStream.process(ProcessorSupplier, String...)
instead. - flatTransform(TransformerSupplier<? super K, ? super V, Iterable<KeyValue<K1, V1>>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Deprecated.Since 3.3. Use
KStream.process(ProcessorSupplier, Named, String...)
instead. - flatTransformValues(ValueTransformerSupplier<? super V, Iterable<VR>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Deprecated.Since 3.3. Use
KStream.processValues(FixedKeyProcessorSupplier, String...)
instead. - flatTransformValues(ValueTransformerSupplier<? super V, Iterable<VR>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Deprecated.Since 3.3. Use
KStream.processValues(FixedKeyProcessorSupplier, Named, String...)
instead. - flatTransformValues(ValueTransformerWithKeySupplier<? super K, ? super V, Iterable<VR>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Deprecated.Since 3.3. Use
KStream.processValues(FixedKeyProcessorSupplier, String...)
instead. - flatTransformValues(ValueTransformerWithKeySupplier<? super K, ? super V, Iterable<VR>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Deprecated.Since 3.3. Use
KStream.processValues(FixedKeyProcessorSupplier, Named, String...)
instead. - Float() - Static method in class org.apache.kafka.common.serialization.Serdes
-
A serde for nullable
Float
type. - float32() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- FLOAT32 - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
32-bit IEEE 754 floating point number
- FLOAT32_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- float64() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- FLOAT64 - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
64-bit IEEE 754 floating point number
- FLOAT64_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- FloatDeserializer - Class in org.apache.kafka.common.serialization
- FloatDeserializer() - Constructor for class org.apache.kafka.common.serialization.FloatDeserializer
- FloatSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.FloatSerde
- FloatSerializer - Class in org.apache.kafka.common.serialization
- FloatSerializer() - Constructor for class org.apache.kafka.common.serialization.FloatSerializer
- flush() - Method in class org.apache.kafka.clients.producer.KafkaProducer
-
Invoking this method makes all buffered records immediately available to send (even 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 class org.apache.kafka.common.config.SslClientAuth
- foreach(ForeachAction<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Perform an action on each record 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 akey-value pair
. - ForeachProcessor<K,
V> - Class in org.apache.kafka.streams.kstream - ForeachProcessor(ForeachAction<K, V>) - Constructor for class org.apache.kafka.streams.kstream.ForeachProcessor
- forFailure(FailureReason, String) - Static method in interface org.apache.kafka.streams.query.QueryResult
-
Static factory method to create a result object for a failed query.
- forGroupId(String) - Static method in exception org.apache.kafka.common.errors.GroupAuthorizationException
- forId(byte) - Static method in enum class org.apache.kafka.clients.admin.AlterConfigOp.OpType
- forId(byte) - Static method in enum class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
- forId(byte) - Static method in enum class org.apache.kafka.common.config.ConfigResource.Type
- forId(byte) - Static method in enum class org.apache.kafka.common.IsolationLevel
- forId(byte) - Static method in enum class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentState
- forId(byte) - Static method in enum class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteState
- forId(int) - Static method in enum class org.apache.kafka.common.metrics.Sensor.RecordingLevel
- forId(short) - Static method in enum class org.apache.kafka.common.security.auth.SecurityProtocol
- formatRemoteTopic(String, String) - Method in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
- formatRemoteTopic(String, String) - Method in class org.apache.kafka.connect.mirror.IdentityReplicationPolicy
-
Unlike DefaultReplicationPolicy, IdentityReplicationPolicy does not include the source cluster alias in the remote topic name.
- formatRemoteTopic(String, String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
-
How to rename remote topics; generally should be like us-west.topic1.
- forName(String) - Static method in enum class org.apache.kafka.common.metrics.Sensor.RecordingLevel
-
Case insensitive lookup by protocol name
- forName(String) - Static method in enum class org.apache.kafka.common.security.auth.SecurityProtocol
-
Case insensitive lookup by protocol name
- forResult(R) - Static method in interface org.apache.kafka.streams.query.QueryResult
-
Static factory method to create a result object for a successful query.
- forTimestamp(long) - Static method in class org.apache.kafka.clients.admin.OffsetSpec
-
Used to retrieve the earliest offset whose timestamp is greater than or equal to the given timestamp in the corresponding partition
- forType(EmitStrategy.StrategyType) - Static method in enum class org.apache.kafka.streams.kstream.EmitStrategy.StrategyType
- forUnknownQueryType(Query<R>, StateStore) - Static method in interface org.apache.kafka.streams.query.QueryResult
-
Static factory method to create a failed query result object to indicate that the store does not know how to handle the query.
- forward(K, V) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- forward(K, V) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Forward a key/value pair to all downstream processors.
- forward(K, V, To) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- forward(K, V, To) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Forward a key/value pair to the specified downstream processors.
- forward(FixedKeyRecord<K, V>) - Method in interface org.apache.kafka.streams.processor.api.FixedKeyProcessorContext
-
Forward a record to all child processors.
- forward(FixedKeyRecord<K, V>, String) - Method in interface org.apache.kafka.streams.processor.api.FixedKeyProcessorContext
-
Forward a record to the specified child processor.
- forward(Record<K, V>) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- forward(Record<K, V>) - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
-
Forward a record to all child processors.
- forward(Record<K, V>, String) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- forward(Record<K, V>, String) - Method in interface org.apache.kafka.streams.processor.api.ProcessorContext
-
Forward a record to the specified child processor.
- forwarded() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
-
Get all the forwarded data this context has observed.
- forwarded() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
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.
- FORWARDING_ADMIN_CLASS - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- FORWARDING_ADMIN_CLASS_DEFAULT - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- FORWARDING_ADMIN_CLASS_DOC - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
- ForwardingAdmin - Class in org.apache.kafka.clients.admin
-
ForwardingAdmin
is the default value offorwarding.admin.class
in MirrorMaker. - ForwardingAdmin(Map<String, Object>) - Constructor for class org.apache.kafka.clients.admin.ForwardingAdmin
- Frequencies - Class in org.apache.kafka.common.metrics.stats
-
A
CompoundStat
that represents a normalized distribution with aFrequency
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 class org.apache.kafka.common.acl.AclOperation
-
Return the AclOperation with the provided code or `AclOperation.UNKNOWN` if one cannot be found.
- fromCode(byte) - Static method in enum class org.apache.kafka.common.acl.AclPermissionType
-
Return the AclPermissionType with the provided code or `AclPermissionType.UNKNOWN` if one cannot be found.
- fromCode(byte) - Static method in enum class org.apache.kafka.common.resource.PatternType
-
Return the PatternType with the provided code or
PatternType.UNKNOWN
if one cannot be found. - fromCode(byte) - Static method in enum class org.apache.kafka.common.resource.ResourceType
-
Return the ResourceType with the provided code or `ResourceType.UNKNOWN` if one cannot be found.
- fromCode(int) - Static method in enum class org.apache.kafka.clients.admin.FeatureUpdate.UpgradeType
- fromConnectData(String, Headers, Schema, Object) - Method in interface org.apache.kafka.connect.storage.Converter
-
Convert a Kafka Connect data object to a native object for serialization, potentially using the supplied topic and headers in the record as necessary.
- fromConnectData(String, Schema, Object) - Method in interface org.apache.kafka.connect.storage.Converter
-
Convert a Kafka Connect data object to a native object for serialization.
- fromConnectData(String, Schema, Object) - Method in class org.apache.kafka.connect.storage.StringConverter
- fromConnectHeader(String, String, Schema, Object) - Method in interface org.apache.kafka.connect.storage.HeaderConverter
- fromConnectHeader(String, String, Schema, Object) - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
- fromConnectHeader(String, String, Schema, Object) - Method in class org.apache.kafka.connect.storage.StringConverter
- 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.
- fromMap(Map<String, ? extends Map<Integer, Long>>) - Static method in class org.apache.kafka.streams.query.Position
-
Create a new Position and populate it with a mapping of topic -> partition -> offset.
- fromMechanismName(String) - Static method in enum class org.apache.kafka.clients.admin.ScramMechanism
- fromNameAndType(String, QueryableStoreType<T>) - Static method in class org.apache.kafka.streams.StoreQueryParameters
- fromProperty(String) - Static method in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
-
Parse a
SourceTask.TransactionBoundary
from the given string. - fromString(String) - Static method in enum class org.apache.kafka.common.acl.AclOperation
-
Parse the given string as an ACL operation.
- fromString(String) - Static method in enum class org.apache.kafka.common.acl.AclPermissionType
-
Parse the given string as an ACL permission.
- fromString(String) - Static method in enum class org.apache.kafka.common.resource.PatternType
-
Return the PatternType with the provided name or
PatternType.UNKNOWN
if one cannot be found. - fromString(String) - Static method in enum class org.apache.kafka.common.resource.ResourceType
-
Parse the given string as an ACL resource type.
- fromString(String) - Static method in class org.apache.kafka.common.Uuid
-
Creates a UUID based on a base64 string encoding used in the toString() method.
- fromType(byte) - Static method in enum class org.apache.kafka.clients.admin.ScramMechanism
- Function() - Constructor for class org.apache.kafka.common.KafkaFuture.Function
-
Deprecated.
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
- generationId() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
- get() - Method in class org.apache.kafka.common.KafkaFuture
-
Waits if necessary for this future to complete, and then returns its result.
- get() - Method in interface org.apache.kafka.streams.kstream.TransformerSupplier
-
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.FixedKeyProcessorSupplier
-
Return a newly constructed
FixedKeyProcessor
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
-
Deprecated.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 bypath
. - 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.Use
KeyQueryMetadata.activeHost()
instead. - getAdmin(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
-
Create an
Admin
which is used for internal topic management. - 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. - getAssignorInstances(List<String>, Map<String, Object>) - Static method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
-
Get a list of configured instances of
ConsumerPartitionAssignor
based on the class names/types specified byConsumerConfig.PARTITION_ASSIGNMENT_STRATEGY_CONFIG
- getBoolean(String) - Method in class org.apache.kafka.common.config.AbstractConfig
- getBoolean(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to calling
Struct.get(String)
and casting the result to a Boolean. - getBoolean(Map<String, Object>, String, boolean) - Static method in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- 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
- getClientTags() - Method in class org.apache.kafka.streams.StreamsConfig
-
Get the configured client tags set with
StreamsConfig.CLIENT_TAG_PREFIX
prefix. - 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. - 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
- getExecutionInfo() - Method in interface org.apache.kafka.streams.query.QueryResult
-
If detailed execution information was requested in
StateQueryRequest.enableExecutionInfo()
, this method returned the execution details for this partition's result. - getFailureMessage() - Method in interface org.apache.kafka.streams.query.QueryResult
-
If this partition failed to execute the query, returns the failure message.
- getFailureReason() - Method in interface org.apache.kafka.streams.query.QueryResult
-
If this partition failed to execute the query, returns the reason.
- getFloat32(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to 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 forGlobalKTable
. - getGlobalConsumerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
-
Get the configs for the
global consumer
. - getGlobalResult() - Method in class org.apache.kafka.streams.query.StateQueryResult
-
The query's result for global store queries.
- getHeaders() - Method in class org.apache.kafka.streams.test.TestRecord
- getInnerSerializer() - Method in class org.apache.kafka.common.serialization.ListSerializer
- getInt(String) - Method in class org.apache.kafka.common.config.AbstractConfig
- getInt16(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to 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.query.KeyQuery
-
The key that was specified for this query.
- getKey() - Method in class org.apache.kafka.streams.query.WindowKeyQuery
- getKey() - Method in class org.apache.kafka.streams.query.WindowRangeQuery
- getKey() - Method in class org.apache.kafka.streams.test.TestRecord
- getKeyValueStore(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
-
Get the
KeyValueStore
orTimestampedKeyValueStore
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
- getLong(Map<String, Object>, String, long) - Static method in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- getLowerBound() - Method in class org.apache.kafka.streams.query.RangeQuery
-
The lower bound of the query, if specified.
- getMainConsumerConfigs(String, String, int) - Method in class org.apache.kafka.streams.StreamsConfig
-
Get the configs to 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 class org.apache.kafka.connect.data.Schema.Type
- getName() - Method in enum class org.apache.kafka.connect.storage.ConverterType
- getNewTopology(TopologyConfig) - Method in class org.apache.kafka.streams.StreamsBuilder
- getNow(T) - Method in class org.apache.kafka.common.KafkaFuture
-
Returns the result value (or throws any encountered exception) if completed, else returns the given valueIfAbsent.
- getOnlyPartitionResult() - Method in class org.apache.kafka.streams.query.StateQueryResult
-
For queries that are expected to match records in only one partition, returns the result.
- getPartition() - Method in class org.apache.kafka.streams.KeyQueryMetadata
-
Deprecated.Use
KeyQueryMetadata.partition()
instead. - getPartitionPositions(String) - Method in class org.apache.kafka.streams.query.Position
-
Return the partition -> offset mapping for a specific topic.
- getPartitionResults() - Method in class org.apache.kafka.streams.query.StateQueryResult
-
The query's result for each partition that executed the query.
- getPartitions() - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
If the request is for specific partitions, return the set of partitions to query.
- getPassword(String) - Method in class org.apache.kafka.common.config.AbstractConfig
- getPosition() - Method in interface org.apache.kafka.streams.processor.StateStore
-
Returns the position the state store is at with respect to the input topic/partitions
- getPosition() - Method in interface org.apache.kafka.streams.query.QueryResult
-
This state partition's exact position in its history when this query was executed.
- getPosition() - Method in class org.apache.kafka.streams.query.StateQueryResult
-
The position of the state store at the moment it executed the query.
- getPositionBound() - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
The bound that this request places on its query, in terms of the partitions' positions against its inputs.
- getPrincipalType() - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
- getProducer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
-
Create 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
- getQuery() - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
The query this request is meant to run.
- getQueueSize() - Method in class org.apache.kafka.streams.TestOutputTopic
-
Get size of unread record in the topic queue.
- getRecordTime() - Method in class org.apache.kafka.streams.test.TestRecord
- getRestoreConsumer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
-
Create a
Consumer
which is used to read records to restoreStateStore
s. - getRestoreConsumerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
-
Get the configs for the
restore-consumer
. - getResult() - Method in interface org.apache.kafka.streams.query.QueryResult
-
Returns the result of executing the query on one partition.
- getSensor(String) - Method in class org.apache.kafka.common.metrics.Metrics
-
Get the sensor with the given name if it exists
- getSessionStore(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
-
Get 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.Use
KeyQueryMetadata.standbyHosts()
instead. - getStateStore(String) - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext
- getStateStore(String) - Method in interface org.apache.kafka.streams.processor.api.ProcessingContext
-
Get the state store given the store name.
- getStateStore(String) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
- 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 withStateStore.init(StateStoreContext, StateStore)
if you need to initialize a store for your tests. - getStoreName() - Method in class org.apache.kafka.streams.query.StateQueryRequest
-
The name of the store this request is for.
- getString(String) - Method in class org.apache.kafka.common.config.AbstractConfig
- getString(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to calling
Struct.get(String)
and casting the result to a String. - getString(Map<String, Object>, String, String) - Static method in class org.apache.kafka.streams.StreamsConfig.InternalConfig
- getStruct(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to calling
Struct.get(String)
and casting the result to a Struct. - getTaskConfig() - Method in class org.apache.kafka.streams.TopologyConfig
- getTimeFrom() - Method in class org.apache.kafka.streams.query.WindowKeyQuery
- getTimeFrom() - Method in class org.apache.kafka.streams.query.WindowRangeQuery
- getTimestampedKeyValueStore(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
-
Get the
TimestampedKeyValueStore
with the given name. - getTimestampedWindowStore(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
-
Get the
TimestampedWindowStore
with the given name. - getTimeTo() - Method in class org.apache.kafka.streams.query.WindowKeyQuery
- getTimeTo() - Method in class org.apache.kafka.streams.query.WindowRangeQuery
- getTopics() - Method in class org.apache.kafka.streams.query.Position
-
Return the topics that are represented in this Position.
- getType() - Method in class org.apache.kafka.streams.processor.api.MockProcessorContext.CapturedPunctuator
- getType() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedPunctuator
- getUpperBound() - Method in class org.apache.kafka.streams.query.RangeQuery
-
The upper bound of the query, if specified
- getValue() - Method in class org.apache.kafka.streams.test.TestRecord
- getValueOrNull(ValueAndTimestamp<V>) - Static method in class org.apache.kafka.streams.state.ValueAndTimestamp
-
Return the wrapped
value
of the givenvalueAndTimestamp
parameter if the parameter is notnull
. - getWindowSize() - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
- getWindowStore(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
-
Get the
WindowStore
orTimestampedWindowStore
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
-
Deprecated.since 3.0. Use
JoinWindows.ofTimeDifferenceAndGrace(Duration, Duration)
instead - grace(Duration) - Method in class org.apache.kafka.streams.kstream.SessionWindows
-
Deprecated.since 3.0. Use
SessionWindows.ofInactivityGapAndGrace(Duration, Duration)
instead - grace(Duration) - Method in class org.apache.kafka.streams.kstream.TimeWindows
-
Deprecated.since 3.0. Use
TimeWindows.ofSizeAndGrace(Duration, Duration)
instead - 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.)
- group - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
- group() - Method in class org.apache.kafka.common.MetricName
- group() - Method in class org.apache.kafka.common.MetricNameTemplate
-
Get the name of the group.
- GROUP - Enum constant in enum class org.apache.kafka.common.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 providedKeyValueMapper
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 providedKeyValueMapper
andSerde
s as specified byGrouped
. - groupBy(KeyValueMapper<? super K, ? super V, KeyValue<KR, VR>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Re-groups the records of this
KTable
using the providedKeyValueMapper
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 providedKeyValueMapper
andSerde
s as specified byGrouped
. - 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 byGrouped
. - Grouped<K,
V> - Class in org.apache.kafka.streams.kstream -
The class that is used to capture the key and value
Serde
s and set the part of name used for repartition topics when performingKStream.groupBy(KeyValueMapper, Grouped)
,KStream.groupByKey(Grouped)
, orKTable.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(Callback[]) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginCallbackHandler
- handle(Callback[]) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallbackHandler
- handle(ProducerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.DefaultProductionExceptionHandler
- 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
- hasCompletedShutdown() - Method in enum class org.apache.kafka.streams.KafkaStreams.State
- hasDefault() - Method in class org.apache.kafka.common.config.ConfigDef.ConfigKey
- hasExpired() - Method in class org.apache.kafka.common.metrics.Sensor
-
Return true if the Sensor is eligible for removal due to inactivity.
- hashCode() - Method in class org.apache.kafka.clients.admin.AbortTransactionSpec
- hashCode() - Method in class org.apache.kafka.clients.admin.AlterConfigOp
- hashCode() - Method in class org.apache.kafka.clients.admin.Config
- hashCode() - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
- hashCode() - Method in class org.apache.kafka.clients.admin.ConfigEntry
- hashCode() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
- hashCode() - Method in class org.apache.kafka.clients.admin.ConsumerGroupListing
- hashCode() - Method in class org.apache.kafka.clients.admin.DescribeProducersOptions
- hashCode() - Method in class org.apache.kafka.clients.admin.FeatureMetadata
- hashCode() - Method in class org.apache.kafka.clients.admin.FeatureUpdate
- hashCode() - Method in class org.apache.kafka.clients.admin.FinalizedVersionRange
- hashCode() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsSpec
- hashCode() - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
- hashCode() - Method in class org.apache.kafka.clients.admin.ListTransactionsOptions
- hashCode() - Method in class org.apache.kafka.clients.admin.MemberAssignment
- hashCode() - Method in class org.apache.kafka.clients.admin.MemberDescription
- hashCode() - Method in class org.apache.kafka.clients.admin.MemberToRemove
- hashCode() - Method in class org.apache.kafka.clients.admin.NewTopic
- hashCode() - Method in class org.apache.kafka.clients.admin.ProducerState
- hashCode() - Method in class org.apache.kafka.clients.admin.QuorumInfo
- hashCode() - Method in class org.apache.kafka.clients.admin.QuorumInfo.ReplicaState
- 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.TransactionDescription
- hashCode() - Method in class org.apache.kafka.clients.admin.TransactionListing
- hashCode() - Method in class org.apache.kafka.clients.admin.UserScramCredentialsDescription
- hashCode() - Method in class org.apache.kafka.clients.consumer.ConsumerGroupMetadata
- hashCode() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
- hashCode() - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
- hashCode() - Method in class org.apache.kafka.clients.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.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
-
Implements
hashCode
using the native implementation fromObject.hashCode()
. - hashCode() - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
- hashCode() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
- hashCode() - Method in class org.apache.kafka.common.TopicIdPartition
- hashCode() - Method in class org.apache.kafka.common.TopicPartition
- hashCode() - Method in class org.apache.kafka.common.TopicPartitionInfo
- hashCode() - Method in class org.apache.kafka.common.TopicPartitionReplica
- hashCode() - Method in class org.apache.kafka.common.Uuid
-
Returns a hash code for this UUID
- hashCode() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- hashCode() - Method in class org.apache.kafka.connect.data.ConnectSchema
- hashCode() - Method in class org.apache.kafka.connect.data.Field
- hashCode() - Method in class org.apache.kafka.connect.data.SchemaAndValue
- hashCode() - Method in class org.apache.kafka.connect.data.Struct
- hashCode() - Method in class org.apache.kafka.connect.header.ConnectHeaders
- hashCode() - Method in class org.apache.kafka.connect.health.AbstractState
- hashCode() - Method in class org.apache.kafka.connect.health.ConnectorHealth
- hashCode() - Method in class org.apache.kafka.connect.health.TaskState
- hashCode() - Method in class org.apache.kafka.connect.mirror.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.server.log.remote.storage.LogSegmentData
- hashCode() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentId
- hashCode() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadata
- hashCode() - Method in class org.apache.kafka.server.log.remote.storage.RemoteLogSegmentMetadataUpdate
- hashCode() - Method in class org.apache.kafka.server.log.remote.storage.RemotePartitionDeleteMetadata
- hashCode() - Method in class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
- hashCode() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
- hashCode() - Method in class org.apache.kafka.streams.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.
Processor
orContextualProcessor
instead.