- 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
-
- AbstractConfig - Class in org.apache.kafka.common.config
-
A convenient base class for configurations to extend.
- 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.
- 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.
- AbstractNotifyingBatchingRestoreCallback - Class in org.apache.kafka.streams.processor
-
- AbstractNotifyingBatchingRestoreCallback() - Constructor for class org.apache.kafka.streams.processor.AbstractNotifyingBatchingRestoreCallback
-
- AbstractNotifyingRestoreCallback - Class in org.apache.kafka.streams.processor
-
- AbstractNotifyingRestoreCallback() - Constructor for class org.apache.kafka.streams.processor.AbstractNotifyingRestoreCallback
-
- 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
-
- AbstractProcessor() - Constructor for class org.apache.kafka.streams.processor.AbstractProcessor
-
- AbstractState - Class in org.apache.kafka.connect.health
-
Provides the current status along with identifier for Connect worker and tasks.
- AbstractState(String, String, String) - Constructor for class org.apache.kafka.connect.health.AbstractState
-
Construct a state for connector or task.
- accept(A, B) - Method in interface org.apache.kafka.common.KafkaFuture.BiConsumer
-
- 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.
- AccessControlEntry - Class in org.apache.kafka.common.acl
-
Represents an access control entry.
- AccessControlEntry(String, String, AclOperation, AclPermissionType) - Constructor for class org.apache.kafka.common.acl.AccessControlEntry
-
Create an instance of an access control entry with the provided parameters.
- AccessControlEntryFilter - Class in org.apache.kafka.common.acl
-
Represents a filter which matches access control entries.
- AccessControlEntryFilter(String, String, AclOperation, AclPermissionType) - Constructor for class org.apache.kafka.common.acl.AccessControlEntryFilter
-
Create an instance of an access control entry filter with the provided parameters.
- ACKS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
acks
- AclBinding - Class in org.apache.kafka.common.acl
-
Represents a binding between a resource pattern and an access control entry.
- AclBinding(ResourcePattern, AccessControlEntry) - Constructor for class org.apache.kafka.common.acl.AclBinding
-
Create an instance of this class with the provided parameters.
- AclBinding(Resource, AccessControlEntry) - Constructor for class org.apache.kafka.common.acl.AclBinding
-
- aclBinding() - Method in class org.apache.kafka.server.authorizer.AclDeleteResult.AclBindingDeleteResult
-
Returns ACL binding that matched the delete filter.
- 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.
- AclBindingFilter(ResourceFilter, AccessControlEntryFilter) - Constructor for class org.apache.kafka.common.acl.AclBindingFilter
-
- 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(ApiException) - Constructor for class org.apache.kafka.server.authorizer.AclDeleteResult
-
- AclDeleteResult(Collection<AclDeleteResult.AclBindingDeleteResult>) - Constructor for class org.apache.kafka.server.authorizer.AclDeleteResult
-
- AclDeleteResult.AclBindingDeleteResult - Class in org.apache.kafka.server.authorizer
-
Delete result for each ACL binding that matched a delete filter.
- AclOperation - Enum in org.apache.kafka.common.acl
-
Represents an operation which an ACL grants or denies permission to perform.
- AclPermissionType - Enum in org.apache.kafka.common.acl
-
Represents whether an ACL grants or denies permissions.
- acls(AclBindingFilter) - Method in interface org.apache.kafka.server.authorizer.Authorizer
-
Returns ACL bindings which match the provided filter.
- Action - Class in org.apache.kafka.server.authorizer
-
- Action(AclOperation, ResourcePattern, int, boolean, boolean) - Constructor for class org.apache.kafka.server.authorizer.Action
-
- activeTasks() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
- 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(String, byte[]) - Method in interface org.apache.kafka.common.header.Headers
-
Creates and adds a header, to the end, returning if the operation succeeded.
- add(Header) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- add(String, SchemaAndValue) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- add(String, Object, Schema) - 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.
- 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(String, Object, Schema) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value.
- addBoolean(String, boolean) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- addBoolean(String, boolean) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value.
- addByte(String, byte) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- addByte(String, byte) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value.
- addBytes(String, byte[]) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- addBytes(String, byte[]) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value.
- addClientSaslSupport(ConfigDef) - Static method in class org.apache.kafka.common.config.SaslConfigs
-
- addClientSslSupport(ConfigDef) - Static method in class org.apache.kafka.common.config.SslConfigs
-
- addDate(String, Date) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- addDate(String, Date) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and
Date
value.
- addDecimal(String, BigDecimal) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- addDecimal(String, BigDecimal) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and
Decimal
value.
- addDeserializerToConfig(Map<String, Object>, Deserializer<?>, Deserializer<?>) - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- addDeserializerToConfig(Properties, Deserializer<?>, Deserializer<?>) - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- 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.
- addEndOffsets(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- addErrorMessage(String) - Method in class org.apache.kafka.common.config.ConfigValue
-
- addFloat(String, float) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- addFloat(String, float) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value.
- addGlobalStore(StoreBuilder, String, String, Consumed, String, ProcessorSupplier) - Method in class org.apache.kafka.streams.StreamsBuilder
-
- addGlobalStore(StoreBuilder, String, Consumed, ProcessorSupplier) - Method in class org.apache.kafka.streams.StreamsBuilder
-
- addGlobalStore(StoreBuilder, String, Deserializer, Deserializer, String, String, ProcessorSupplier) - Method in class org.apache.kafka.streams.Topology
-
- addGlobalStore(StoreBuilder, String, TimestampExtractor, Deserializer, Deserializer, String, String, ProcessorSupplier) - Method in class org.apache.kafka.streams.Topology
-
- addingReplicas() - Method in class org.apache.kafka.clients.admin.PartitionReassignment
-
The brokers that we are adding this partition to as part of a reassignment.
- addInt(String, int) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- addInt(String, int) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value.
- addLatencyAndThroughputSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
-
Add a latency and throughput sensor for a specific operation, which will include the following sensors:
average latency
max latency
throughput (num.operations / time unit)
Also create a parent sensor with the same metrics that aggregates all entities with the same operation under the
same scope if it has not been created.
- 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.
- addProcessor(String, ProcessorSupplier, 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.
- addRecord(ConsumerRecord<K, V>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- addSensor(String, Sensor.RecordingLevel) - Method in interface org.apache.kafka.streams.StreamsMetrics
-
Generic method to create a sensor.
- addSensor(String, Sensor.RecordingLevel, Sensor...) - Method in interface org.apache.kafka.streams.StreamsMetrics
-
Generic method to create a sensor with parent sensors.
- addSerializerToConfig(Map<String, Object>, Serializer<?>, Serializer<?>) - Static method in class org.apache.kafka.clients.producer.ProducerConfig
-
- addSerializerToConfig(Properties, Serializer<?>, Serializer<?>) - Static method in class org.apache.kafka.clients.producer.ProducerConfig
-
- 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, 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, 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, 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>, 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.
- 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
.
- 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(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(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, 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.
- 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(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.
- 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.
- addString(String, String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- addString(String, String) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value.
- addStruct(String, Struct) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- addStruct(String, Struct) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value.
- addThroughputSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
-
Add a throughput sensor for a specific operation:
throughput (num.operations / time unit)
Also create a parent sensor with the same metrics that aggregates all entities with the same operation under the
same scope if it has not been created.
- addTime(String, Date) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- addTime(String, Date) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and
Time
value.
- addTimestamp(String, Date) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- addTimestamp(String, Date) - Method in interface org.apache.kafka.connect.header.Headers
-
- addWaiter(KafkaFuture.BiConsumer<? super T, ? super Throwable>) - Method in class org.apache.kafka.common.KafkaFuture
-
- addWithoutValidating(String, Object, Schema) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- Admin - Interface in org.apache.kafka.clients.admin
-
The administrative client for Kafka, which supports managing and inspecting topics, brokers, configurations and ACLs.
- ADMIN_CLIENT_PREFIX - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
-
- ADMIN_CLIENT_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to isolate
admin
configs from other client configs.
- AdminClient - Class in org.apache.kafka.clients.admin
-
The base class for in-built admin clients.
- AdminClient() - Constructor for class org.apache.kafka.clients.admin.AdminClient
-
- AdminClientConfig - Class in org.apache.kafka.clients.admin
-
The AdminClient configuration class, which also contains constants for configuration entry names.
- AdminClientConfig(Map<?, ?>) - Constructor for class org.apache.kafka.clients.admin.AdminClientConfig
-
- AdminClientConfig(Map<?, ?>, boolean) - Constructor for class org.apache.kafka.clients.admin.AdminClientConfig
-
- adminClientId() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
- adminClientPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
- adminConfig() - Method in class org.apache.kafka.connect.mirror.MirrorClientConfig
-
Sub-config for Admin clients.
- advanceBy(long) - Method in class org.apache.kafka.streams.kstream.TimeWindows
-
- advanceBy(Duration) - Method in class org.apache.kafka.streams.kstream.TimeWindows
-
Return a window definition with the original size, but advance ("hop") the window by the given interval, which
specifies by how much a window moves forward relative to the previous one.
- advanceMs - Variable in class org.apache.kafka.streams.kstream.TimeWindows
-
The size of the window's advance interval in milliseconds, i.e., by how much a window moves forward relative to
the previous one.
- advanceTime(Duration) - Method in class org.apache.kafka.streams.TestInputTopic
-
Advances the internally tracked event time of this input topic.
- advanceTimeMs(long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Advances the internally tracked time.
- advanceWallClockTime(long) - Method in class org.apache.kafka.streams.TopologyTestDriver
-
- advanceWallClockTime(Duration) - Method in class org.apache.kafka.streams.TopologyTestDriver
-
Advances the internally mocked wall-clock time.
- after(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
-
- 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<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>, 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, 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>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Aggregate the value of records of the original
KTable
that got
mapped
to the same key into a new instance of
KTable
.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Aggregate the value of records of the original
KTable
that got
mapped
to the same key into a new instance of
KTable
.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Aggregate the value of records of the original
KTable
that got
mapped
to the same key into a new instance of
KTable
using default serializers and deserializers.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Aggregate the value of records of the original
KTable
that got
mapped
to the same key into a new instance of
KTable
using default serializers and deserializers.
- aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, 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
SessionWindows
.
- 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
SessionWindows
.
- 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
SessionWindows
.
- 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
SessionWindows
.
- 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.
- 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.
- 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.
- 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.
- 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.AlterConfigsResult
-
Return a future which succeeds only if all the alter configs operations 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 future which succeeds if all the replica movement have succeeded
- all() - Method in class org.apache.kafka.clients.admin.CreateAclsResult
-
Return a future which succeeds only if all the ACL creations succeed.
- all() - Method in class org.apache.kafka.clients.admin.CreatePartitionsResult
-
Return a future which succeeds if all the partition creations succeed.
- all() - Method in class org.apache.kafka.clients.admin.CreateTopicsResult
-
Return a future which succeeds if all the topic creations succeed.
- all() - Method in class org.apache.kafka.clients.admin.DeleteAclsResult
-
Return a future which succeeds only if all the ACLs deletions succeed, and which contains all the deleted ACLs.
- all() - Method in class org.apache.kafka.clients.admin.DeleteConsumerGroupOffsetsResult
-
Return a future which succeeds only if all the deletions succeed.
- all() - Method in class org.apache.kafka.clients.admin.DeleteConsumerGroupsResult
-
Return a future which succeeds only if all the consumer group deletions succeed.
- all() - Method in class org.apache.kafka.clients.admin.DeleteRecordsResult
-
Return a future which succeeds only if all the records deletions succeed.
- all() - Method in class org.apache.kafka.clients.admin.DeleteTopicsResult
-
Return a future which succeeds only if all the topic deletions succeed.
- all() - Method in class org.apache.kafka.clients.admin.DescribeConfigsResult
-
Return a future which succeeds only if all the config descriptions succeed.
- all() - Method in class org.apache.kafka.clients.admin.DescribeConsumerGroupsResult
-
Return a future which yields all ConsumerGroupDescription objects, if all the describes succeed.
- all() - Method in class org.apache.kafka.clients.admin.DescribeLogDirsResult
-
Return a future which succeeds only if all the brokers have responded without error
- all() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult
-
Return a future which succeeds if log directory information of all replicas are available
- all() - Method in class org.apache.kafka.clients.admin.DescribeTopicsResult
-
Return a future which succeeds only if all the topic descriptions succeed.
- all() - Method in class org.apache.kafka.clients.admin.ElectLeadersResult
-
Return a future which succeeds if all the topic elections succeed.
- all() - Method in class org.apache.kafka.clients.admin.ElectPreferredLeadersResult
-
Deprecated.
Return a future which succeeds if all the topic elections succeed.
- all() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsResult
-
Returns a future that yields either an exception, or the full set of consumer group
listings.
- all() - Method in class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupResult
-
Returns a future which indicates whether the request was 100% success, i.e.
- 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.
- allMetadata() - Method in class org.apache.kafka.streams.KafkaStreams
-
Find all currently running
KafkaStreams
instances (potentially remotely) that use the same
application ID
as this instance (i.e., all instances that belong to
the same Kafka Streams application) and return
StreamsMetadata
for each discovered instance.
- allMetadataForStore(String) - Method in class org.apache.kafka.streams.KafkaStreams
-
Find all currently running
KafkaStreams
instances (potentially remotely) that
use the same
application ID
as this instance (i.e., all
instances that belong to the same Kafka Streams application)
and that contain a
StateStore
with the given
storeName
and return
StreamsMetadata
for each discovered instance.
- allOf(KafkaFuture<?>...) - Static method in class org.apache.kafka.common.KafkaFuture
-
Returns a new KafkaFuture that is completed when all the given futures have completed.
- ALLOW_AUTO_CREATE_TOPICS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
allow.auto.create.topics
- allWithName(String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- allWithName(String) - Method in interface org.apache.kafka.connect.header.Headers
-
Get the collection of
Header
objects whose
keys
all match the specified key.
- AlreadyExistsException - Exception in org.apache.kafka.connect.errors
-
Indicates the operation tried to create an entity that already exists.
- AlreadyExistsException(String) - Constructor for exception org.apache.kafka.connect.errors.AlreadyExistsException
-
- AlreadyExistsException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.AlreadyExistsException
-
- AlreadyExistsException(Throwable) - Constructor for exception org.apache.kafka.connect.errors.AlreadyExistsException
-
- AlterConfigOp - Class in org.apache.kafka.clients.admin
-
A class representing a alter configuration entry containing name, value and operation type.
- AlterConfigOp(ConfigEntry, AlterConfigOp.OpType) - Constructor for class org.apache.kafka.clients.admin.AlterConfigOp
-
- AlterConfigOp.OpType - Enum in org.apache.kafka.clients.admin
-
- AlterConfigPolicy - Interface in org.apache.kafka.server.policy
-
An interface for enforcing a policy on alter configs requests.
- AlterConfigPolicy.RequestMetadata - Class in org.apache.kafka.server.policy
-
Class containing the create request parameters.
- alterConfigs(Map<ConfigResource, Config>) - Method in interface org.apache.kafka.clients.admin.Admin
-
- alterConfigs(Map<ConfigResource, Config>, AlterConfigsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
- alterConfigs(Map<ConfigResource, Config>, AlterConfigsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
Deprecated.
- AlterConfigsOptions - Class in org.apache.kafka.clients.admin
-
- AlterConfigsOptions() - Constructor for class org.apache.kafka.clients.admin.AlterConfigsOptions
-
- AlterConfigsResult - Class in org.apache.kafka.clients.admin
-
- alterPartitionReassignments(Map<TopicPartition, Optional<NewPartitionReassignment>>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Change the reassignments for one or more partitions.
- alterPartitionReassignments(Map<TopicPartition, Optional<NewPartitionReassignment>>, AlterPartitionReassignmentsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Change the reassignments for one or more partitions.
- alterPartitionReassignments(Map<TopicPartition, Optional<NewPartitionReassignment>>, AlterPartitionReassignmentsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- AlterPartitionReassignmentsOptions - Class in org.apache.kafka.clients.admin
-
- AlterPartitionReassignmentsOptions() - Constructor for class org.apache.kafka.clients.admin.AlterPartitionReassignmentsOptions
-
- AlterPartitionReassignmentsResult - Class in org.apache.kafka.clients.admin
-
- alterReplicaLogDirs(Map<TopicPartitionReplica, String>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Change the log directory for the specified replicas.
- alterReplicaLogDirs(Map<TopicPartitionReplica, String>, AlterReplicaLogDirsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Change the log directory for the specified replicas.
- alterReplicaLogDirs(Map<TopicPartitionReplica, String>, AlterReplicaLogDirsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- AlterReplicaLogDirsOptions - Class in org.apache.kafka.clients.admin
-
- AlterReplicaLogDirsOptions() - Constructor for class org.apache.kafka.clients.admin.AlterReplicaLogDirsOptions
-
- AlterReplicaLogDirsResult - Class in org.apache.kafka.clients.admin
-
- ANONYMOUS - Static variable in class org.apache.kafka.common.security.auth.KafkaPrincipal
-
- ANY - Static variable in class org.apache.kafka.common.acl.AccessControlEntryFilter
-
Matches any access control entry.
- ANY - Static variable in class org.apache.kafka.common.acl.AclBindingFilter
-
A filter which matches any ACL binding.
- ANY - Static variable in class org.apache.kafka.common.resource.ResourceFilter
-
Matches any resource.
- ANY - Static variable in class org.apache.kafka.common.resource.ResourcePatternFilter
-
Matches any resource pattern.
- ApiException - Exception in org.apache.kafka.common.errors
-
Any API exception that is part of the public protocol and should be a subclass of this class and be part of this
package.
- ApiException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ApiException
-
- ApiException(String) - Constructor for exception org.apache.kafka.common.errors.ApiException
-
- ApiException(Throwable) - Constructor for exception org.apache.kafka.common.errors.ApiException
-
- ApiException() - Constructor for exception org.apache.kafka.common.errors.ApiException
-
- appConfigs() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- appConfigs() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Returns all the application config properties as key/value pairs.
- appConfigsWithPrefix(String) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- appConfigsWithPrefix(String) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Returns all the application config properties with the given key prefix, as key/value pairs
stripping the prefix.
- append(StringBuilder, Object, boolean) - Static method in class org.apache.kafka.connect.data.Values
-
- 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
-
user.endpoint
- applicationId() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- applicationId() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Returns the application id
- 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(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(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(Header) - Method in interface org.apache.kafka.connect.header.Headers.HeaderTransform
-
- apply(R) - Method in interface org.apache.kafka.connect.transforms.Transformation
-
Apply transformation to the record
and return another record object (which may be record
itself) or null
,
corresponding to a map or filter operation respectively.
- apply(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(K, V) - Method in interface org.apache.kafka.streams.kstream.ForeachAction
-
Perform an action for each record of a stream.
- apply() - Method in interface org.apache.kafka.streams.kstream.Initializer
-
Return the initial value for an aggregation.
- 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, V) - Method in interface org.apache.kafka.streams.kstream.Merger
-
Compute a new aggregate from the key and two aggregates.
- apply(V, V) - Method in interface org.apache.kafka.streams.kstream.Reducer
-
Aggregate the two given values into a single one.
- apply(V1, V2) - Method in interface org.apache.kafka.streams.kstream.ValueJoiner
-
Return a joined value consisting of value1
and value2
.
- apply(V) - Method in interface org.apache.kafka.streams.kstream.ValueMapper
-
Map the given 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.
- 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
-
- 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
-
- as(WindowBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
- as(SessionBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
- as(KeyValueBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
- 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.StreamJoined
-
Creates a
StreamJoined
instance using the provided name for the state stores and hence the changelog
topics for the join stores.
- 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(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(Map<String, Integer>, Map<String, ConsumerPartitionAssignor.Subscription>) - Method in class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
-
- assign(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Manually assign a list of partitions to this consumer.
- assign(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- assign(Map<String, Integer>, Map<String, ConsumerPartitionAssignor.Subscription>) - Method in class org.apache.kafka.clients.consumer.RangeAssignor
-
- assign(Map<String, Integer>, Map<String, ConsumerPartitionAssignor.Subscription>) - Method in class org.apache.kafka.clients.consumer.RoundRobinAssignor
-
- 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(List<TopicPartition>, ByteBuffer) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Assignment
-
- Assignment(List<TopicPartition>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Assignment
-
- 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_ERROR_CODE - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
-
- assignments() - Method in class org.apache.kafka.clients.admin.NewPartitions
-
The replica assignments for the new partitions, or null if the assignment will be done by the controller.
- AT_LEAST_ONCE - Static variable in class org.apache.kafka.streams.StreamsConfig
-
- atLeast(Number) - Static method in class org.apache.kafka.common.config.ConfigDef.Range
-
A numeric range that checks only the lower bound
- AuthenticateCallbackHandler - Interface in org.apache.kafka.common.security.auth
-
- authenticated() - Method in class org.apache.kafka.common.security.plain.PlainAuthenticateCallback
-
Returns true if client password matches expected password, false otherwise.
- authenticated(boolean) - Method in class org.apache.kafka.common.security.plain.PlainAuthenticateCallback
-
Sets the authenticated state.
- AuthenticationContext - Interface in org.apache.kafka.common.security.auth
-
An object representing contextual information from the authentication session.
- AuthenticationException - Exception in org.apache.kafka.common.errors
-
This exception indicates that SASL authentication has failed.
- AuthenticationException(String) - Constructor for exception org.apache.kafka.common.errors.AuthenticationException
-
- AuthenticationException(Throwable) - Constructor for exception org.apache.kafka.common.errors.AuthenticationException
-
- AuthenticationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.AuthenticationException
-
- AuthorizableRequestContext - Interface in org.apache.kafka.server.authorizer
-
Request context interface that provides data from request header as well as connection
and authentication information to plugins.
- AuthorizationException - Exception in org.apache.kafka.common.errors
-
- AuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.AuthorizationException
-
- AuthorizationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.AuthorizationException
-
- AuthorizationResult - Enum in org.apache.kafka.server.authorizer
-
- authorize(AuthorizableRequestContext, List<Action>) - Method in interface org.apache.kafka.server.authorizer.Authorizer
-
Authorizes the specified action.
- authorizedOperations() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
-
authorizedOperations for this group, or null if that information is not known.
- authorizedOperations() - Method in class org.apache.kafka.clients.admin.DescribeClusterResult
-
Returns a future which yields authorized operations.
- authorizedOperations() - Method in class org.apache.kafka.clients.admin.TopicDescription
-
authorized operations for this topic, or null if this is not known.
- Authorizer - Interface in org.apache.kafka.server.authorizer
-
Pluggable authorizer interface for Kafka brokers.
- AuthorizerServerInfo - Interface in org.apache.kafka.server.authorizer
-
Runtime broker configuration metadata provided to authorizers during start up.
- AUTO_COMMIT_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
auto.commit.interval.ms
- AUTO_OFFSET_RESET_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
auto.offset.reset
- AUTO_OFFSET_RESET_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- availablePartitionsForTopic(String) - Method in class org.apache.kafka.common.Cluster
-
Get the list of available partitions for this topic
- CACHE_MAX_BYTES_BUFFERING_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
cache.max.bytes.buffering
- cachingEnabled - Variable in class org.apache.kafka.streams.kstream.Materialized
-
- Callback - Interface in org.apache.kafka.clients.producer
-
A callback interface that the user can implement to allow code to execute when the request is complete.
- cancel(boolean) - Method in class org.apache.kafka.common.KafkaFuture
-
If not already completed, completes this future with a CancellationException.
- 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
-
- Cancellable - Interface in org.apache.kafka.streams.processor
-
- cancelled() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedPunctuator
-
- canConsume(String) - Method in class org.apache.kafka.connect.data.Values.Parser
-
- canConsume(String, boolean) - Method in class org.apache.kafka.connect.data.Values.Parser
-
- canConsumeNextToken() - Method in class org.apache.kafka.connect.data.Values.Parser
-
- canDetect(Object) - Method in class org.apache.kafka.connect.data.Values.SchemaDetector
-
- canParseSingleTokenLiteral(Values.Parser, boolean, String) - Static method in class org.apache.kafka.connect.data.Values
-
- CHECK_CRCS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
check.crcs
- Checkpoint - Class in org.apache.kafka.connect.mirror
-
Checkpoint records emitted from MirrorCheckpointConnector.
- Checkpoint(String, TopicPartition, long, long, String) - Constructor for class org.apache.kafka.connect.mirror.Checkpoint
-
- checkpointTopics() - Method in class org.apache.kafka.connect.mirror.MirrorClient
-
Find all checkpoint topics on this cluster.
- checkpointTopics(Map<String, Object>) - Static method in class org.apache.kafka.connect.mirror.RemoteClusterUtils
-
Find all checkpoint topics
- checksum() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
- checksum() - Method in class org.apache.kafka.clients.producer.RecordMetadata
-
- child(String) - Static method in class org.apache.kafka.streams.processor.To
-
Forward the key/value pair to one of the downstream processors designated by the downstream processor name.
- childName() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedForward
-
The child this data was forwarded to.
- childName - Variable in class org.apache.kafka.streams.processor.To
-
- cleanUp() - Method in class org.apache.kafka.streams.KafkaStreams
-
- CLEANUP_POLICY_COMPACT - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- CLEANUP_POLICY_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- CLEANUP_POLICY_DELETE - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- CLEANUP_POLICY_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- clear() - Method in class org.apache.kafka.clients.producer.MockProducer
-
Clear the stored history of sent records, consumer group offsets, and transactional state
- 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_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
- CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
client.id
- CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
client.id
- CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
client.id
- CLIENT_RACK_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
client.rack
- clientAddress() - Method in interface org.apache.kafka.common.security.auth.AuthenticationContext
-
Address of the authenticated client
- clientAddress() - Method in class org.apache.kafka.common.security.auth.PlaintextAuthenticationContext
-
- clientAddress() - Method in class org.apache.kafka.common.security.auth.SaslAuthenticationContext
-
- clientAddress() - Method in class org.apache.kafka.common.security.auth.SslAuthenticationContext
-
- clientAddress() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
-
Returns client IP address from which request was sent.
- clientId() - Method in class org.apache.kafka.clients.admin.MemberDescription
-
The client id of the group member.
- clientId() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
-
Returns the client id from the request header.
- clientProps() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
-
- ClientQuotaCallback - Interface in org.apache.kafka.server.quota
-
Quota callback interface for brokers that enables customization of client quota computation.
- ClientQuotaEntity - Interface in org.apache.kafka.server.quota
-
The metadata for an entity for which quota is configured.
- ClientQuotaEntity.ConfigEntity - Interface in org.apache.kafka.server.quota
-
Interface representing a quota configuration entity.
- ClientQuotaEntity.ConfigEntityType - Enum in org.apache.kafka.server.quota
-
- ClientQuotaType - Enum in org.apache.kafka.server.quota
-
Types of quotas that may be configured on brokers for client requests.
- clientType() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
-
- close() - Method in interface org.apache.kafka.clients.admin.Admin
-
Close the Admin and release all associated resources.
- close(long, TimeUnit) - Method in interface org.apache.kafka.clients.admin.Admin
-
- close(Duration) - Method in interface org.apache.kafka.clients.admin.Admin
-
Close the Admin client and release all associated resources.
- close(Duration) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- close() - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- close(long, TimeUnit) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
Deprecated.
- close(Duration) - 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(long, TimeUnit) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
- close(Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Tries to close the consumer cleanly within the specified timeout.
- close() - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- close(long, TimeUnit) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- close(Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- close() - Method in class org.apache.kafka.clients.producer.KafkaProducer
-
Close this producer.
- 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() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- close(Duration) - 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(long, TimeUnit) - Method in interface org.apache.kafka.clients.producer.Producer
-
Deprecated.
- close(Duration) - Method in interface org.apache.kafka.clients.producer.Producer
-
- close() - Method in interface org.apache.kafka.clients.producer.ProducerInterceptor
-
This is called when interceptor is closed
- close() - Method in class org.apache.kafka.clients.producer.RoundRobinPartitioner
-
- close() - Method in class org.apache.kafka.clients.producer.UniformStickyPartitioner
-
- close() - Method in class org.apache.kafka.common.config.provider.FileConfigProvider
-
- close() - Method in interface org.apache.kafka.common.security.auth.AuthenticateCallbackHandler
-
Closes this instance.
- close() - Method in class org.apache.kafka.common.security.auth.DefaultPrincipalBuilder
-
Deprecated.
- close() - Method in interface org.apache.kafka.common.security.auth.Login
-
Closes this instance.
- close() - Method in interface org.apache.kafka.common.security.auth.PrincipalBuilder
-
Deprecated.
Closes this instance.
- close() - Method in interface org.apache.kafka.common.serialization.Deserializer
-
Close this deserializer.
- close() - Method in class org.apache.kafka.common.serialization.ExtendedDeserializer.Wrapper
-
Deprecated.
- close() - Method in class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
-
Deprecated.
- close() - Method in interface org.apache.kafka.common.serialization.Serde
-
Close this serde class, which will close the underlying serializer and deserializer.
- close() - Method in class org.apache.kafka.common.serialization.Serdes.WrapperSerde
-
- close() - Method in interface org.apache.kafka.common.serialization.Serializer
-
Close this serializer.
- close() - Method in class org.apache.kafka.connect.mirror.MirrorClient
-
Close internal clients.
- close(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() - 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.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(long, TimeUnit) - Method in class org.apache.kafka.streams.KafkaStreams
-
- 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() - Method in class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
-
- close() - Method in class org.apache.kafka.streams.kstream.SessionWindowedSerializer
-
- close() - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
-
- close() - Method in class org.apache.kafka.streams.kstream.TimeWindowedSerializer
-
- close() - Method in interface org.apache.kafka.streams.kstream.Transformer
-
Close this transformer and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
-
Close this transformer and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKey
-
Close this processor and clean up any resources.
- close() - Method in class org.apache.kafka.streams.processor.AbstractProcessor
-
Close this processor and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.processor.Processor
-
Close this processor and clean up any resources.
- close() - Method in interface org.apache.kafka.streams.processor.StateStore
-
Close the storage engine.
- close() - Method in interface org.apache.kafka.streams.state.KeyValueIterator
-
- close(String, Options) - Method in interface org.apache.kafka.streams.state.RocksDBConfigSetter
-
Close any user-constructed objects that inherit from org.rocksdb.RocksObject
.
- 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.
- closed() - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- closed() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- Cluster - Class in org.apache.kafka.common
-
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>, 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) - Constructor for class org.apache.kafka.common.Cluster
-
Create a new cluster with the given id, nodes and partitions
- CLUSTER - Static variable in class org.apache.kafka.common.resource.Resource
-
A resource representing the whole cluster.
- 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 - 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
-
- clusterResource() - Method in interface org.apache.kafka.server.authorizer.AuthorizerServerInfo
-
Returns cluster metadata for the broker running this authorizer including cluster id.
- ClusterResourceListener - Interface in org.apache.kafka.common
-
A callback interface that users can implement when they wish to get notified about changes in the Cluster metadata.
- clusterState() - Method in interface org.apache.kafka.connect.rest.ConnectRestExtensionContext
-
Provides the cluster state and health information about the connectors and tasks.
- code() - Method in enum org.apache.kafka.common.acl.AclOperation
-
Return the code of this operation.
- code() - Method in enum org.apache.kafka.common.acl.AclPermissionType
-
Return the code of this permission type.
- code() - Method in enum org.apache.kafka.common.resource.PatternType
-
- code() - Method in enum org.apache.kafka.common.resource.ResourceType
-
Return the code of this resource.
- 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() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- commit() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Requests a commit
- COMMIT_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
commit.interval.ms
- commitAsync() - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- commitAsync(OffsetCommitCallback) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- commitAsync(Map<TopicPartition, OffsetAndMetadata>, OffsetCommitCallback) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- commitAsync() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
- 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(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() - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- commitAsync(OffsetCommitCallback) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- commitCount() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- CommitFailedException - Exception in org.apache.kafka.clients.consumer
-
- CommitFailedException() - Constructor for exception org.apache.kafka.clients.consumer.CommitFailedException
-
- commitRecord(SourceRecord) - Method in class org.apache.kafka.connect.source.SourceTask
-
Commit an individual
SourceRecord
when the callback from the producer client is received.
- 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(Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- commitSync(Map<TopicPartition, OffsetAndMetadata>) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- commitSync(Map<TopicPartition, OffsetAndMetadata>, Duration) - 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(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(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>, 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>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- commitSync() - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- commitSync(Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- commitSync(Map<TopicPartition, OffsetAndMetadata>, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- committed(TopicPartition) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
Deprecated.
- committed(TopicPartition, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
Deprecated.
- committed(Set<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- committed(Set<TopicPartition>, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- committed(TopicPartition) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
- committed(TopicPartition, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
- 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>, 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(TopicPartition) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
Deprecated.
- committed(TopicPartition, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
Deprecated.
- committed(Set<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- committed(Set<TopicPartition>, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- committed() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- 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
-
- commonSchemaFor(Schema, SchemaAndValue) - Static method in class org.apache.kafka.connect.data.Values
-
- compareKeyValue(ProducerRecord<K, V>, K, V) - Static method in class org.apache.kafka.streams.test.OutputVerifier
-
Deprecated.
Compares a
ProducerRecord
with the provided key and value and throws an
AssertionError
if the
ProducerRecord
's key or value is not equal to the expected key or value.
- compareKeyValue(ProducerRecord<K, V>, ProducerRecord<K, V>) - Static method in class org.apache.kafka.streams.test.OutputVerifier
-
Deprecated.
- compareKeyValueHeaders(ProducerRecord<K, V>, K, V, Headers) - Static method in class org.apache.kafka.streams.test.OutputVerifier
-
Deprecated.
Compares a
ProducerRecord
with the provided key, value, and headers and throws an
AssertionError
if the
ProducerRecord
's key, value, or headers is not equal to the expected key,
value, or headers.
- compareKeyValueHeaders(ProducerRecord<K, V>, ProducerRecord<K, V>) - Static method in class org.apache.kafka.streams.test.OutputVerifier
-
Deprecated.
Compares the keys, values, and headers of two
ProducerRecord
's and throws an
AssertionError
if
the keys, values, or headers are not equal to each other.
- compareKeyValueHeadersTimestamp(ProducerRecord<K, V>, K, V, Headers, long) - Static method in class org.apache.kafka.streams.test.OutputVerifier
-
Deprecated.
Compares a
ProducerRecord
with the provided key, value, headers, and timestamp and throws an
AssertionError
if the
ProducerRecord
's key, value, headers, or timestamp is not equal to the expected key,
value, headers, or timestamp.
- compareKeyValueHeadersTimestamp(ProducerRecord<K, V>, ProducerRecord<K, V>) - Static method in class org.apache.kafka.streams.test.OutputVerifier
-
Deprecated.
Compares the keys, values, headers, and timestamp of two
ProducerRecord
's and throws an
AssertionError
if
the keys, values, headers, or timestamps are not equal to each other.
- compareKeyValueTimestamp(ProducerRecord<K, V>, K, V, long) - Static method in class org.apache.kafka.streams.test.OutputVerifier
-
Deprecated.
Compares a
ProducerRecord
with the provided key, value, and timestamp and throws an
AssertionError
if the
ProducerRecord
's key, value, or timestamp is not equal to the expected key,
value, or timestamp.
- compareKeyValueTimestamp(ProducerRecord<K, V>, ProducerRecord<K, V>) - Static method in class org.apache.kafka.streams.test.OutputVerifier
-
Deprecated.
Compares the keys, values, and timestamps of two
ProducerRecord
's and throws an
AssertionError
if
the keys, values, or timestamps are not equal to each other.
- compareTo(TaskId) - Method in class org.apache.kafka.streams.processor.TaskId
-
- compareValue(ProducerRecord<K, V>, V) - Static method in class org.apache.kafka.streams.test.OutputVerifier
-
Deprecated.
Compares a
ProducerRecord
with the provided value and throws an
AssertionError
if the
ProducerRecord
's value is not equal to the expected value.
- compareValue(ProducerRecord<K, V>, ProducerRecord<K, V>) - Static method in class org.apache.kafka.streams.test.OutputVerifier
-
Deprecated.
- compareValueHeaders(ProducerRecord<K, V>, V, Headers) - Static method in class org.apache.kafka.streams.test.OutputVerifier
-
Deprecated.
Compares a
ProducerRecord
with the provided value and headers and throws an
AssertionError
if
the
ProducerRecord
's value or headers is not equal to the expected value or headers.
- compareValueHeaders(ProducerRecord<K, V>, ProducerRecord<K, V>) - Static method in class org.apache.kafka.streams.test.OutputVerifier
-
Deprecated.
- compareValueTimestamp(ProducerRecord<K, V>, V, long) - Static method in class org.apache.kafka.streams.test.OutputVerifier
-
Deprecated.
Compares a
ProducerRecord
with the provided value and timestamp and throws an
AssertionError
if
the
ProducerRecord
's value or timestamp is not equal to the expected value or timestamp.
- compareValueTimestamp(ProducerRecord<K, V>, ProducerRecord<K, V>) - Static method in class org.apache.kafka.streams.test.OutputVerifier
-
Deprecated.
Compares the values and timestamps of two
ProducerRecord
's and throws an
AssertionError
if the
values or timestamps are not equal to each other.
- complete(T) - Method in class org.apache.kafka.common.KafkaFuture
-
If not already completed, sets the value returned by get() and related methods to the given
value.
- completedFuture(U) - Static method in class org.apache.kafka.common.KafkaFuture
-
Returns a new KafkaFuture that is already completed with the given value.
- completeExceptionally(Throwable) - Method in class org.apache.kafka.common.KafkaFuture
-
If not already completed, causes invocations of get() and related methods to throw the given
exception.
- completeNext() - Method in class org.apache.kafka.clients.producer.MockProducer
-
Complete the earliest uncompleted call successfully.
- COMPRESSION_TYPE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
compression.type
- COMPRESSION_TYPE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- COMPRESSION_TYPE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- ConcurrentTransactionsException - Exception in org.apache.kafka.common.errors
-
- ConcurrentTransactionsException(String) - Constructor for exception org.apache.kafka.common.errors.ConcurrentTransactionsException
-
- Config - Class in org.apache.kafka.clients.admin
-
A configuration object containing the configuration entries for a resource.
- Config(Collection<ConfigEntry>) - Constructor for class org.apache.kafka.clients.admin.Config
-
Create a configuration instance with the provided entries.
- 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 - Class in org.apache.kafka.common.config
-
- Config(List<ConfigValue>) - Constructor for class org.apache.kafka.common.config.Config
-
- config() - Method in class org.apache.kafka.connect.connector.Connector
-
Define the configuration for the connector.
- config() - Method in interface org.apache.kafka.connect.storage.HeaderConverter
-
Configuration specification for this set of header converters.
- config() - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
-
- config() - Method in class org.apache.kafka.connect.storage.StringConverter
-
- config() - Method in interface org.apache.kafka.connect.transforms.Transformation
-
Configuration specification for this transformation.
- CONFIG_PROVIDERS_CONFIG - Static variable in class org.apache.kafka.common.config.AbstractConfig
-
- ConfigChangeCallback - Interface in org.apache.kafka.common.config
-
- ConfigData - Class in org.apache.kafka.common.config
-
- 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).
- ConfigData(Map<String, String>) - Constructor for class org.apache.kafka.common.config.ConfigData
-
Creates a new ConfigData with the given data.
- 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 - 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() - 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.CaseInsensitiveValidString - Class in org.apache.kafka.common.config
-
- ConfigDef.CompositeValidator - Class in org.apache.kafka.common.config
-
- ConfigDef.ConfigKey - Class in org.apache.kafka.common.config
-
- ConfigDef.Importance - Enum in org.apache.kafka.common.config
-
The importance level for a configuration
- ConfigDef.LambdaValidator - Class in org.apache.kafka.common.config
-
- ConfigDef.NonEmptyString - Class in org.apache.kafka.common.config
-
- ConfigDef.NonEmptyStringWithoutControlChars - Class in org.apache.kafka.common.config
-
- ConfigDef.NonNullValidator - Class in org.apache.kafka.common.config
-
- ConfigDef.Range - Class in org.apache.kafka.common.config
-
Validation logic for numeric ranges
- ConfigDef.Recommender - Interface in org.apache.kafka.common.config
-
This is used by the
ConfigDef.validate(Map)
to get valid values for a configuration given the current
configuration values in order to perform full configuration validation and visibility modification.
- ConfigDef.Type - Enum in org.apache.kafka.common.config
-
The config types
- ConfigDef.Validator - Interface in org.apache.kafka.common.config
-
Validation logic the user may provide to perform single configuration validation.
- ConfigDef.ValidList - Class in org.apache.kafka.common.config
-
- ConfigDef.ValidString - Class in org.apache.kafka.common.config
-
- ConfigDef.Width - Enum in org.apache.kafka.common.config
-
The width of a configuration value
- configEntities() - Method in interface org.apache.kafka.server.quota.ClientQuotaEntity
-
Returns the list of configuration entities that this quota entity is comprised of.
- configEntry() - Method in class org.apache.kafka.clients.admin.AlterConfigOp
-
- ConfigEntry - Class in org.apache.kafka.clients.admin
-
A class representing a configuration entry containing name, value and additional metadata.
- ConfigEntry(String, String) - Constructor for class org.apache.kafka.clients.admin.ConfigEntry
-
Create a configuration entry with the provided values.
- ConfigEntry(String, String, boolean, boolean, boolean) - Constructor for class org.apache.kafka.clients.admin.ConfigEntry
-
- ConfigEntry.ConfigSource - Enum in org.apache.kafka.clients.admin
-
Source of configuration entries.
- ConfigEntry.ConfigSynonym - Class in org.apache.kafka.clients.admin
-
Class representing a configuration synonym of a
ConfigEntry
.
- ConfigException - Exception in org.apache.kafka.common.config
-
Thrown if the user supplies an invalid configuration
- ConfigException(String) - Constructor for exception org.apache.kafka.common.config.ConfigException
-
- ConfigException(String, Object) - Constructor for exception org.apache.kafka.common.config.ConfigException
-
- ConfigException(String, Object, String) - Constructor for exception org.apache.kafka.common.config.ConfigException
-
- ConfigKey(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender, boolean) - Constructor for class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- configKeys() - Method in class org.apache.kafka.common.config.ConfigDef
-
Get the configuration keys
- configNames() - Static method in class org.apache.kafka.clients.admin.AdminClientConfig
-
- configNames() - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- configNames() - Static method in class org.apache.kafka.clients.producer.ProducerConfig
-
- ConfigProvider - Interface in org.apache.kafka.common.config.provider
-
A provider of configuration data, which may optionally support subscriptions to configuration changes.
- ConfigResource - Class in org.apache.kafka.common.config
-
A class representing resources that have configs.
- ConfigResource(ConfigResource.Type, String) - Constructor for class org.apache.kafka.common.config.ConfigResource
-
Create an instance of this class with the provided parameters.
- ConfigResource.Type - Enum in org.apache.kafka.common.config
-
Type of resource.
- configs(Map<String, String>) - Method in class org.apache.kafka.clients.admin.NewTopic
-
Set the configuration to use on the new topic.
- 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.
- 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
-
- ConfigTransformerResult(Map<String, String>, Map<String, Long>) - Constructor for class org.apache.kafka.common.config.ConfigTransformerResult
-
Creates a new ConfigTransformerResult with the given data and TTL values for a set of paths.
- Configurable - Interface in org.apache.kafka.common
-
A Mix-in style interface for classes that are instantiated by reflection and need to take configuration parameters
- configurable() - Method in interface org.apache.kafka.connect.rest.ConnectRestExtensionContext
-
Provides an implementation of Configurable
that be used to register JAX-RS resources.
- configure(Map<String, ?>) - Method in class org.apache.kafka.clients.producer.RoundRobinPartitioner
-
- configure(Map<String, ?>) - Method in class org.apache.kafka.clients.producer.UniformStickyPartitioner
-
- configure(Map<String, ?>) - Method in class org.apache.kafka.common.config.provider.FileConfigProvider
-
- configure(Map<String, ?>) - Method in interface org.apache.kafka.common.Configurable
-
Configure this class with the given key-value pairs
- 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, ?>) - Method in class org.apache.kafka.common.security.auth.DefaultPrincipalBuilder
-
Deprecated.
- configure(Map<String, ?>, String, Configuration, AuthenticateCallbackHandler) - Method in interface org.apache.kafka.common.security.auth.Login
-
Configures this login instance.
- configure(Map<String, ?>) - Method in interface org.apache.kafka.common.security.auth.PrincipalBuilder
-
Deprecated.
Configures this class with given key-value pairs.
- configure(Map<String, ?>) - Method in interface org.apache.kafka.common.security.auth.SecurityProviderCreator
-
Configure method is used to configure the generator to create the Security Provider
- configure(Map<String, ?>, boolean) - Method in interface org.apache.kafka.common.serialization.Deserializer
-
Configure this class.
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.ExtendedDeserializer.Wrapper
-
Deprecated.
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
-
Deprecated.
- configure(Map<String, ?>, boolean) - Method in interface org.apache.kafka.common.serialization.Serde
-
Configure this class, which will configure the underlying serializer and deserializer.
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.Serdes.WrapperSerde
-
- configure(Map<String, ?>, boolean) - Method in interface org.apache.kafka.common.serialization.Serializer
-
Configure this class.
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.StringDeserializer
-
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.StringSerializer
-
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.UUIDDeserializer
-
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.common.serialization.UUIDSerializer
-
- configure(Map<String, ?>) - Method in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
-
- configure(Map<String, ?>, boolean) - Method in interface org.apache.kafka.connect.storage.Converter
-
Configure this class.
- 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, ?>, boolean) - 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 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
-
- 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.
- 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
-
- ConnectHeaders() - Constructor for class org.apache.kafka.connect.header.ConnectHeaders
-
- ConnectHeaders(Iterable<Header>) - Constructor for class org.apache.kafka.connect.header.ConnectHeaders
-
- CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
connections.max.idle.ms
- CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
connections.max.idle.ms
- CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
connections.max.idle.ms
- CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
connections.max.idle.ms
- Connector - Class in org.apache.kafka.connect.connector
-
Connectors manage integration of Kafka Connect with another system, either as an input that ingests
data into Kafka or an output that passes data to an external system.
- Connector() - Constructor for class org.apache.kafka.connect.connector.Connector
-
- connectorClass() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
-
The class of the Connector.
- ConnectorClientConfigOverridePolicy - Interface in org.apache.kafka.connect.connector.policy
-
An interface for enforcing a policy on overriding of client configs via the connector configs.
- ConnectorClientConfigRequest - Class in org.apache.kafka.connect.connector.policy
-
- ConnectorClientConfigRequest(String, ConnectorType, Class<? extends Connector>, Map<String, Object>, ConnectorClientConfigRequest.ClientType) - Constructor for class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
-
- ConnectorClientConfigRequest.ClientType - Enum in org.apache.kafka.connect.connector.policy
-
- connectorConfig(String) - Method in interface org.apache.kafka.connect.health.ConnectClusterState
-
Lookup the current configuration of a connector.
- ConnectorContext - Interface in org.apache.kafka.connect.connector
-
ConnectorContext allows Connectors to proactively interact with the Kafka Connect runtime.
- connectorHealth(String) - Method in interface org.apache.kafka.connect.health.ConnectClusterState
-
Lookup the current health of a connector and its tasks.
- ConnectorHealth - Class in org.apache.kafka.connect.health
-
Provides basic health information about the connector and its tasks.
- ConnectorHealth(String, ConnectorState, Map<Integer, TaskState>, ConnectorType) - Constructor for class org.apache.kafka.connect.health.ConnectorHealth
-
- connectorName() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
-
Name of the connector specified in the connector config.
- connectors() - Method in interface org.apache.kafka.connect.health.ConnectClusterState
-
Get the names of the connectors currently deployed in this cluster.
- connectorState() - Method in class org.apache.kafka.connect.health.ConnectorHealth
-
Provides the current state of the connector.
- ConnectorState - Class in org.apache.kafka.connect.health
-
Describes the status, worker ID, and any errors associated with a connector.
- ConnectorState(String, String, String) - Constructor for class org.apache.kafka.connect.health.ConnectorState
-
Provides an instance of the ConnectorState.
- connectorType() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
-
Type of the Connector.
- ConnectorType - Enum in org.apache.kafka.connect.health
-
Enum definition that identifies the type of the connector.
- ConnectorUtils - Class in org.apache.kafka.connect.util
-
Utilities that connector implementations might find useful.
- ConnectorUtils() - Constructor for class org.apache.kafka.connect.util.ConnectorUtils
-
- connectProcessorAndStateStores(String, String...) - Method in class org.apache.kafka.streams.Topology
-
Connects the processor and the state stores.
- ConnectRecord<R extends ConnectRecord<R>> - Class in org.apache.kafka.connect.connector
-
Base class for records containing data to be copied to/from Kafka.
- ConnectRecord(String, Integer, Schema, Object, Schema, Object, Long) - Constructor for class org.apache.kafka.connect.connector.ConnectRecord
-
- ConnectRecord(String, Integer, Schema, Object, Schema, Object, Long, Iterable<Header>) - Constructor for class org.apache.kafka.connect.connector.ConnectRecord
-
- ConnectRestExtension - Interface in org.apache.kafka.connect.rest
-
A plugin interface to allow registration of new JAX-RS resources like Filters, REST endpoints, providers, etc.
- ConnectRestExtensionContext - Interface in org.apache.kafka.connect.rest
-
- ConnectSchema - Class in org.apache.kafka.connect.data
-
- 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.
- 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) - Constructor for class org.apache.kafka.connect.data.ConnectSchema
-
Construct a default schema for a primitive type.
- Consumed<K,V> - Class in org.apache.kafka.streams.kstream
-
- 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_CLIENT_PREFIX - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
-
- CONSUMER_GROUP_ID_KEY - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
-
- CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to isolate
consumer
configs from other client configs.
- consumerClientId() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
- ConsumerConfig - Class in org.apache.kafka.clients.consumer
-
The consumer configuration keys
- ConsumerConfig(Properties) - Constructor for class org.apache.kafka.clients.consumer.ConsumerConfig
-
- ConsumerConfig(Map<String, Object>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerConfig
-
- ConsumerConfig(Map<?, ?>, boolean) - Constructor for class org.apache.kafka.clients.consumer.ConsumerConfig
-
- consumerConfig() - Method in class org.apache.kafka.connect.mirror.MirrorClientConfig
-
Sub-config for Consumer clients.
- ConsumerGroupDescription - Class in org.apache.kafka.clients.admin
-
A detailed description of a single consumer group in the cluster.
- ConsumerGroupDescription(String, boolean, Collection<MemberDescription>, String, ConsumerGroupState, Node) - Constructor for class org.apache.kafka.clients.admin.ConsumerGroupDescription
-
- consumerGroupId() - Method in class org.apache.kafka.connect.mirror.Checkpoint
-
- ConsumerGroupListing - Class in org.apache.kafka.clients.admin
-
A listing of a consumer group in the cluster.
- ConsumerGroupListing(String, boolean) - Constructor for class org.apache.kafka.clients.admin.ConsumerGroupListing
-
Create an instance with the specified parameters.
- ConsumerGroupMetadata - Class in org.apache.kafka.clients.consumer
-
- 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
-
- ConsumerGroupState - Enum in org.apache.kafka.common
-
The consumer group state.
- consumerId() - Method in class org.apache.kafka.clients.admin.MemberDescription
-
The consumer id of the group member.
- ConsumerInterceptor<K,V> - Interface in org.apache.kafka.clients.consumer
-
A plugin interface that allows you to intercept (and possibly mutate) records received by the consumer.
- ConsumerPartitionAssignor - Interface in org.apache.kafka.clients.consumer
-
This interface is used to define custom partition assignment for use in
KafkaConsumer
.
- ConsumerPartitionAssignor.Assignment - Class in org.apache.kafka.clients.consumer
-
- ConsumerPartitionAssignor.GroupAssignment - Class in org.apache.kafka.clients.consumer
-
- ConsumerPartitionAssignor.GroupSubscription - Class in org.apache.kafka.clients.consumer
-
- ConsumerPartitionAssignor.RebalanceProtocol - Enum in org.apache.kafka.clients.consumer
-
The rebalance protocol defines partition assignment and revocation semantics.
- ConsumerPartitionAssignor.Subscription - Class in org.apache.kafka.clients.consumer
-
- consumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
- 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, K, V) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
-
Creates a record to be received from a specified topic and partition (provided for
compatibility with Kafka 0.9 before the message format supported timestamps and before
serialized metadata were exposed).
- ConsumerRecord(String, int, long, long, TimestampType, long, int, int, K, V) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
-
Creates a record to be received from a specified topic and partition (provided for
compatibility with Kafka 0.10 before the message format supported headers).
- ConsumerRecord(String, int, long, long, TimestampType, Long, int, int, K, V, Headers) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
-
Creates a record to be received from a specified topic and partition
- ConsumerRecord(String, int, long, long, TimestampType, Long, int, int, K, V, Headers, Optional<Integer>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
-
Creates a record to be received from a specified topic and partition
- ConsumerRecordFactory<K,V> - Class in org.apache.kafka.streams.test
-
- ConsumerRecordFactory(Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a new factory for the given topic.
- ConsumerRecordFactory(String, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a new factory for the given topic.
- ConsumerRecordFactory(Serializer<K>, Serializer<V>, long) - Constructor for class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a new factory for the given topic.
- ConsumerRecordFactory(String, Serializer<K>, Serializer<V>, long) - Constructor for class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a new factory for the given topic.
- ConsumerRecordFactory(Serializer<K>, Serializer<V>, long, long) - Constructor for class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a new factory for the given topic.
- ConsumerRecordFactory(String, Serializer<K>, Serializer<V>, long, long) - Constructor for class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a new factory for the given topic.
- 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
-
- 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() - Method in class org.apache.kafka.streams.processor.AbstractProcessor
-
- controller() - Method in class org.apache.kafka.clients.admin.DescribeClusterResult
-
Returns a future which yields the current controller id.
- controller() - Method in class org.apache.kafka.common.Cluster
-
- ControllerMovedException - Exception in org.apache.kafka.common.errors
-
- ControllerMovedException(String) - Constructor for exception org.apache.kafka.common.errors.ControllerMovedException
-
- ControllerMovedException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ControllerMovedException
-
- 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
-
- ConverterConfig(ConfigDef, Map<String, ?>) - Constructor for class org.apache.kafka.connect.storage.ConverterConfig
-
- ConverterType - Enum in org.apache.kafka.connect.storage
-
- 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
-
- convertToByte(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
- 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
-
- convertToFloat(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
- convertToInteger(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
- convertToList(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
- convertToLong(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
- convertToMap(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
- convertToShort(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
- 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
-
- 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
-
- 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
-
- CooperativeStickyAssignor - Class in org.apache.kafka.clients.consumer
-
A cooperative version of the AbstractStickyAssignor
.
- CooperativeStickyAssignor() - Constructor for class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
-
- coordinator() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
-
The consumer group coordinator, or null if the coordinator is not known.
- CoordinatorLoadInProgressException - Exception in org.apache.kafka.common.errors
-
In the context of the group coordinator, the broker returns this error code for any coordinator request if
it is still loading the group metadata (e.g.
- CoordinatorLoadInProgressException(String) - Constructor for exception org.apache.kafka.common.errors.CoordinatorLoadInProgressException
-
- CoordinatorLoadInProgressException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.CoordinatorLoadInProgressException
-
- CoordinatorNotAvailableException - Exception in org.apache.kafka.common.errors
-
In the context of the group coordinator, the broker returns this error code for metadata or offset commit
requests if the group metadata topic has not been created yet.
- CoordinatorNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.CoordinatorNotAvailableException
-
- CoordinatorNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.CoordinatorNotAvailableException
-
- correlationId() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
-
Returns the correlation id from the request header.
- 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(Throwable) - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
-
- CorruptRecordException(String, 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(Named) - 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.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.KGroupedStream
-
Count the number of records in this stream by the grouped key.
- count(Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Count number of records of the original
KTable
that got
mapped
to
the same key into a new instance of
KTable
.
- count(Named, Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Count number of records of the original
KTable
that got
mapped
to
the same key into a new instance of
KTable
.
- count() - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Count number of records of the original
KTable
that got
mapped
to
the same key into a new instance of
KTable
.
- count(Named) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Count number of records of the original
KTable
that got
mapped
to
the same key into a new instance of
KTable
.
- count() - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Count the number of records in this stream by the grouped key into
SessionWindows
.
- count(Named) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
Count the number of records in this stream by the grouped key into
SessionWindows
.
- 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 into
SessionWindows
.
- 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 into
SessionWindows
.
- count() - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Count the number of records in this stream by the grouped key and the defined windows.
- count(Named) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Count the number of records in this stream by the grouped key and the defined windows.
- 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 the defined windows.
- 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 the defined windows.
- create(Properties) - 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 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(Map<String, Object>) - Static method in class org.apache.kafka.clients.admin.AdminClient
-
Create a new Admin with the given configuration.
- create(StateStoreProvider, String) - Method in interface org.apache.kafka.streams.state.QueryableStoreType
-
Create an instance of
T
(usually a facade) that developers can use
to query the underlying
StateStore
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(String, K, V, Headers, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a
ConsumerRecord
with the given topic name, key, value, headers, and timestamp.
- create(String, K, V, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a
ConsumerRecord
with the given topic name and given topic, key, value, and timestamp.
- create(K, V, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a
ConsumerRecord
with default topic name and given key, value, and timestamp.
- create(K, V, Headers, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a
ConsumerRecord
with default topic name and given key, value, headers, and timestamp.
- create(String, K, V) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
- create(String, K, V, Headers) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a
ConsumerRecord
with the given topic name, key, value, and headers.
- create(K, V) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a
ConsumerRecord
with default topic name and given key and value.
- create(K, V, Headers) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a
ConsumerRecord
with default topic name and given key, value, and headers.
- create(String, V, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a
ConsumerRecord
with
null
-key and the given topic name, value, and timestamp.
- create(String, V, Headers, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a
ConsumerRecord
with
null
-key and the given topic name, value, headers, and timestamp.
- create(V, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a
ConsumerRecord
with default topic name and
null
-key as well as given value and timestamp.
- create(V, Headers, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a
ConsumerRecord
with default topic name and
null
-key as well as given value, headers, and timestamp.
- create(String, V, Headers) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a
ConsumerRecord
with
null
-key and the given topic name, value, and headers.
- create(String, V) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a
ConsumerRecord
with
null
-key and the given topic name and value.
- create(V) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a
ConsumerRecord
with default topic name and
null
-key was well as given value.
- create(V, Headers) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Create a
ConsumerRecord
with default topic name and
null
-key was well as given value and headers.
- create(String, List<KeyValue<K, V>>) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
- create(List<KeyValue<K, V>>) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Creates
consumer records
with default topic name as well as given keys and values.
- create(String, List<KeyValue<K, V>>, long, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
- create(List<KeyValue<K, V>>, long, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
Creates
consumer records
with default topic name as well as given keys and values.
- create(String, List<KeyValue<K, V>>, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
- create(List<KeyValue<K, V>>, long) - Method in class org.apache.kafka.streams.test.ConsumerRecordFactory
-
Deprecated.
- createAcls(Collection<AclBinding>) - Method in interface org.apache.kafka.clients.admin.Admin
-
- createAcls(Collection<AclBinding>, CreateAclsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Creates access control lists (ACLs) which are bound to specific resources.
- createAcls(Collection<AclBinding>, CreateAclsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- createAcls(AuthorizableRequestContext, List<AclBinding>) - Method in interface org.apache.kafka.server.authorizer.Authorizer
-
Creates new ACL bindings.
- CreateAclsOptions - Class in org.apache.kafka.clients.admin
-
- CreateAclsOptions() - Constructor for class org.apache.kafka.clients.admin.CreateAclsOptions
-
- CreateAclsResult - Class in org.apache.kafka.clients.admin
-
- createDelegationToken() - Method in interface org.apache.kafka.clients.admin.Admin
-
Create a Delegation Token.
- createDelegationToken(CreateDelegationTokenOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Create a Delegation Token.
- createDelegationToken(CreateDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- CreateDelegationTokenOptions - Class in org.apache.kafka.clients.admin
-
- CreateDelegationTokenOptions() - Constructor for class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
-
- CreateDelegationTokenResult - Class in org.apache.kafka.clients.admin
-
- createInputTopic(String, Serializer<K>, Serializer<V>) - Method in class org.apache.kafka.streams.TopologyTestDriver
-
Create
TestInputTopic
to be used for piping records to topic
Uses current system time as start timestamp for records.
- createInputTopic(String, Serializer<K>, Serializer<V>, Instant, Duration) - Method in class org.apache.kafka.streams.TopologyTestDriver
-
Create
TestInputTopic
to be used for piping records to topic
Uses provided start timestamp and autoAdvance parameter for records
- createOutputTopic(String, Deserializer<K>, Deserializer<V>) - Method in class org.apache.kafka.streams.TopologyTestDriver
-
- createPartitions(Map<String, NewPartitions>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Increase the number of partitions of the topics given as the keys of newPartitions
according to the corresponding values.
- createPartitions(Map<String, NewPartitions>, CreatePartitionsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Increase the number of partitions of the topics given as the keys of newPartitions
according to the corresponding values.
- createPartitions(Map<String, NewPartitions>, CreatePartitionsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- CreatePartitionsOptions - Class in org.apache.kafka.clients.admin
-
- CreatePartitionsOptions() - Constructor for class org.apache.kafka.clients.admin.CreatePartitionsOptions
-
- CreatePartitionsResult - Class in org.apache.kafka.clients.admin
-
- CreateTopicPolicy - Interface in org.apache.kafka.server.policy
-
An interface for enforcing a policy on create topics requests.
- CreateTopicPolicy.RequestMetadata - Class in org.apache.kafka.server.policy
-
Class containing the create request parameters.
- createTopics(Collection<NewTopic>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Create a batch of new topics with the default options.
- createTopics(Collection<NewTopic>, CreateTopicsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Create a batch of new topics.
- createTopics(Collection<NewTopic>, CreateTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- CreateTopicsOptions - Class in org.apache.kafka.clients.admin
-
- CreateTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.CreateTopicsOptions
-
- CreateTopicsResult - Class in org.apache.kafka.clients.admin
-
- 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
-
- DEBUG_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
-
The DEBUG
level designates fine-grained
informational events that are most useful to debug Kafka
- Decimal - Class in org.apache.kafka.connect.data
-
An arbitrary-precision signed decimal number.
- Decimal() - Constructor for class org.apache.kafka.connect.data.Decimal
-
- DEFAULT_ALLOW_AUTO_CREATE_TOPICS - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- DEFAULT_API_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
default.api.timeout.ms
- DEFAULT_API_TIMEOUT_MS_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- DEFAULT_DESERIALIZATION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
default.deserialization.exception.handler
- DEFAULT_EXCLUDE_INTERNAL_TOPICS - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- DEFAULT_FETCH_MAX_BYTES - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- DEFAULT_ISOLATION_LEVEL - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- DEFAULT_KERBEROS_KINIT_CMD - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- DEFAULT_KERBEROS_MIN_TIME_BEFORE_RELOGIN - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- DEFAULT_KERBEROS_TICKET_RENEW_JITTER - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- DEFAULT_KERBEROS_TICKET_RENEW_WINDOW_FACTOR - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- DEFAULT_KEY_SERDE_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
default key.serde
- DEFAULT_LOGIN_REFRESH_BUFFER_SECONDS - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- DEFAULT_LOGIN_REFRESH_MIN_PERIOD_SECONDS - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- DEFAULT_LOGIN_REFRESH_WINDOW_FACTOR - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- DEFAULT_LOGIN_REFRESH_WINDOW_JITTER - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- DEFAULT_MAX_PARTITION_FETCH_BYTES - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- DEFAULT_PATTERN - Static variable in class org.apache.kafka.common.config.ConfigTransformer
-
- DEFAULT_PRINCIPAL_BUILDER_CLASS - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- DEFAULT_PRODUCTION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
default.production.exception.handler
- DEFAULT_SASL_ENABLED_MECHANISMS - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- DEFAULT_SASL_KERBEROS_PRINCIPAL_TO_LOCAL_RULES - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- DEFAULT_SASL_MECHANISM - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- DEFAULT_SECURITY_PROTOCOL - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
- DEFAULT_SSL_ENABLED_PROTOCOLS - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- DEFAULT_SSL_ENDPOINT_IDENTIFICATION_ALGORITHM - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- DEFAULT_SSL_KEYMANGER_ALGORITHM - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- DEFAULT_SSL_KEYSTORE_TYPE - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- DEFAULT_SSL_PROTOCOL - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- DEFAULT_SSL_TRUSTMANAGER_ALGORITHM - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- DEFAULT_SSL_TRUSTSTORE_TYPE - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- DEFAULT_TIMESTAMP_EXTRACTOR_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
default.timestamp.extractor
- DEFAULT_VALUE_SERDE_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
default value.serde
- DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS - Static variable in class org.apache.kafka.streams.StreamsConfig
-
default.windowed.key.serde.inner
- DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS - Static variable in class org.apache.kafka.streams.StreamsConfig
-
default.windowed.value.serde.inner
- defaultDeserializationExceptionHandler() - Method in class org.apache.kafka.streams.StreamsConfig
-
- defaultKeySerde() - Method in class org.apache.kafka.streams.StreamsConfig
-
- DefaultPartitionGrouper - Class in org.apache.kafka.streams.processor
-
- DefaultPartitionGrouper() - Constructor for class org.apache.kafka.streams.processor.DefaultPartitionGrouper
-
Deprecated.
- DefaultPrincipalBuilder - Class in org.apache.kafka.common.security.auth
-
- DefaultPrincipalBuilder() - Constructor for class org.apache.kafka.common.security.auth.DefaultPrincipalBuilder
-
Deprecated.
- 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
-
- defaultProductionExceptionHandler() - Method in class org.apache.kafka.streams.StreamsConfig
-
- 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
-
- define(ConfigDef.ConfigKey) - Method in class org.apache.kafka.common.config.ConfigDef
-
- define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender) - Method in class org.apache.kafka.common.config.ConfigDef
-
Define a new configuration
- define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>) - 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, ConfigDef.Recommender) - Method in class org.apache.kafka.common.config.ConfigDef
-
Define a new configuration with no dependents
- 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.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, 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, 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.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, 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, 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, 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(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, 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.Importance, String) - Method in class org.apache.kafka.common.config.ConfigDef
-
Define a new configuration with no special validation logic
- 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
- defineInternal(String, ConfigDef.Type, Object, ConfigDef.Importance) - Method in class org.apache.kafka.common.config.ConfigDef
-
Define a new internal configuration.
- 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_RETENTION_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- DELETE_RETENTION_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- deleteAcls(Collection<AclBindingFilter>) - Method in interface org.apache.kafka.clients.admin.Admin
-
- deleteAcls(Collection<AclBindingFilter>, DeleteAclsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Deletes access control lists (ACLs) according to the supplied filters.
- deleteAcls(Collection<AclBindingFilter>, DeleteAclsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- deleteAcls(AuthorizableRequestContext, List<AclBindingFilter>) - Method in interface org.apache.kafka.server.authorizer.Authorizer
-
Deletes all ACL bindings that match the provided filters.
- DeleteAclsOptions - Class in org.apache.kafka.clients.admin
-
- DeleteAclsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteAclsOptions
-
- DeleteAclsResult - Class in org.apache.kafka.clients.admin
-
- 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>, 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>) - 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 class org.apache.kafka.clients.admin.KafkaAdminClient
-
- DeleteConsumerGroupOffsetsOptions - Class in org.apache.kafka.clients.admin
-
- DeleteConsumerGroupOffsetsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteConsumerGroupOffsetsOptions
-
- DeleteConsumerGroupOffsetsResult - Class in org.apache.kafka.clients.admin
-
- deleteConsumerGroups(Collection<String>, DeleteConsumerGroupsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Delete consumer groups from the cluster.
- 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 class org.apache.kafka.clients.admin.KafkaAdminClient
-
- DeleteConsumerGroupsOptions - Class in org.apache.kafka.clients.admin
-
- DeleteConsumerGroupsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteConsumerGroupsOptions
-
- DeleteConsumerGroupsResult - Class in org.apache.kafka.clients.admin
-
- deletedGroups() - Method in class org.apache.kafka.clients.admin.DeleteConsumerGroupsResult
-
Return a map from group id to futures which can be used to check the status of
individual deletions.
- DeletedRecords - Class in org.apache.kafka.clients.admin
-
Represents information about deleted records
The API for this class is still evolving and we may break compatibility in minor releases, if necessary.
- DeletedRecords(long) - Constructor for class org.apache.kafka.clients.admin.DeletedRecords
-
Create an instance of this class with the provided parameters.
- deleteRecords(Map<TopicPartition, RecordsToDelete>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Delete records whose offset is smaller than the given offset of the corresponding partition.
- deleteRecords(Map<TopicPartition, RecordsToDelete>, DeleteRecordsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Delete records whose offset is smaller than the given offset of the corresponding partition.
- deleteRecords(Map<TopicPartition, RecordsToDelete>, DeleteRecordsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- DeleteRecordsOptions - Class in org.apache.kafka.clients.admin
-
- DeleteRecordsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteRecordsOptions
-
- DeleteRecordsResult - Class in org.apache.kafka.clients.admin
-
- 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
-
- deleteTopics(Collection<String>, DeleteTopicsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Delete a batch of topics.
- deleteTopics(Collection<String>, DeleteTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- DeleteTopicsOptions - Class in org.apache.kafka.clients.admin
-
- DeleteTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.DeleteTopicsOptions
-
- DeleteTopicsResult - Class in org.apache.kafka.clients.admin
-
- DELIVERY_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
delivery.timeout.ms
- dependents - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- describe() - Method in class org.apache.kafka.streams.Topology
-
Returns a description of the specified Topology
.
- describeAcls(AclBindingFilter) - Method in interface org.apache.kafka.clients.admin.Admin
-
- describeAcls(AclBindingFilter, DescribeAclsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Lists access control lists (ACLs) according to the supplied filter.
- describeAcls(AclBindingFilter, DescribeAclsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- DescribeAclsOptions - Class in org.apache.kafka.clients.admin
-
- DescribeAclsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeAclsOptions
-
- DescribeAclsResult - Class in org.apache.kafka.clients.admin
-
- describeCluster() - Method in interface org.apache.kafka.clients.admin.Admin
-
Get information about the nodes in the cluster, using the default options.
- describeCluster(DescribeClusterOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Get information about the nodes in the cluster.
- describeCluster(DescribeClusterOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- DescribeClusterOptions - Class in org.apache.kafka.clients.admin
-
- DescribeClusterOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeClusterOptions
-
- DescribeClusterResult - Class in org.apache.kafka.clients.admin
-
- describeConfigs(Collection<ConfigResource>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Get the configuration for the specified resources with the default options.
- describeConfigs(Collection<ConfigResource>, DescribeConfigsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Get the configuration for the specified resources.
- describeConfigs(Collection<ConfigResource>, DescribeConfigsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- DescribeConfigsOptions - Class in org.apache.kafka.clients.admin
-
- DescribeConfigsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeConfigsOptions
-
- DescribeConfigsResult - Class in org.apache.kafka.clients.admin
-
- describeConsumerGroups(Collection<String>, DescribeConsumerGroupsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Describe some group IDs in the cluster.
- 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 class org.apache.kafka.clients.admin.KafkaAdminClient
-
- DescribeConsumerGroupsOptions - Class in org.apache.kafka.clients.admin
-
- DescribeConsumerGroupsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeConsumerGroupsOptions
-
- DescribeConsumerGroupsResult - Class in org.apache.kafka.clients.admin
-
- DescribeConsumerGroupsResult(Map<String, KafkaFuture<ConsumerGroupDescription>>) - Constructor for class org.apache.kafka.clients.admin.DescribeConsumerGroupsResult
-
- describeDelegationToken() - Method in interface org.apache.kafka.clients.admin.Admin
-
Describe the Delegation Tokens.
- describeDelegationToken(DescribeDelegationTokenOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Describe the Delegation Tokens.
- describeDelegationToken(DescribeDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- DescribeDelegationTokenOptions - Class in org.apache.kafka.clients.admin
-
- DescribeDelegationTokenOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeDelegationTokenOptions
-
- DescribeDelegationTokenResult - Class in org.apache.kafka.clients.admin
-
- describedGroups() - Method in class org.apache.kafka.clients.admin.DescribeConsumerGroupsResult
-
Return a map from group id to futures which yield group descriptions.
- describeLogDirs(Collection<Integer>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Query the information of all log directories on the given set of brokers
- describeLogDirs(Collection<Integer>, DescribeLogDirsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Query the information of all log directories on the given set of brokers
- describeLogDirs(Collection<Integer>, DescribeLogDirsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- DescribeLogDirsOptions - Class in org.apache.kafka.clients.admin
-
- DescribeLogDirsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeLogDirsOptions
-
- DescribeLogDirsResult - 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.KafkaAdminClient
-
- DescribeReplicaLogDirsOptions - Class in org.apache.kafka.clients.admin
-
- DescribeReplicaLogDirsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeReplicaLogDirsOptions
-
- DescribeReplicaLogDirsResult - Class in org.apache.kafka.clients.admin
-
- DescribeReplicaLogDirsResult.ReplicaLogDirInfo - Class in org.apache.kafka.clients.admin
-
- describeTopics(Collection<String>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Describe some topics in the cluster, with the default options.
- describeTopics(Collection<String>, DescribeTopicsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Describe some topics in the cluster.
- describeTopics(Collection<String>, DescribeTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- DescribeTopicsOptions - Class in org.apache.kafka.clients.admin
-
- DescribeTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.DescribeTopicsOptions
-
- DescribeTopicsResult - Class in org.apache.kafka.clients.admin
-
- description() - Method in class org.apache.kafka.common.MetricName
-
- description() - Method in class org.apache.kafka.common.MetricNameTemplate
-
Get the description of the metric.
- DeserializationExceptionHandler - Interface in org.apache.kafka.streams.errors
-
Interface that specifies how an exception from source node deserialization
(e.g., reading from Kafka) should be handled.
- DeserializationExceptionHandler.DeserializationHandlerResponse - Enum in org.apache.kafka.streams.errors
-
Enumeration that describes the response from the exception handler.
- deserialize(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, Headers, byte[]) - Method in interface org.apache.kafka.common.serialization.Deserializer
-
Deserialize a record value from a byte array into a value or object.
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.DoubleDeserializer
-
- deserialize(String, Headers, byte[]) - Method in interface org.apache.kafka.common.serialization.ExtendedDeserializer
-
Deprecated.
Deserialize a record value from a byte array into a value or object.
- deserialize(String, Headers, byte[]) - Method in class org.apache.kafka.common.serialization.ExtendedDeserializer.Wrapper
-
Deprecated.
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ExtendedDeserializer.Wrapper
-
Deprecated.
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.FloatDeserializer
-
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.IntegerDeserializer
-
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.LongDeserializer
-
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ShortDeserializer
-
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.StringDeserializer
-
- deserialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.UUIDDeserializer
-
- deserialize(String, byte[]) - Method in class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
-
- deserialize(String, byte[]) - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
-
- Deserializer<T> - Interface in org.apache.kafka.common.serialization
-
An interface for converting bytes to objects.
- deserializer() - Method in interface org.apache.kafka.common.serialization.Serde
-
- deserializer() - Method in class org.apache.kafka.common.serialization.Serdes.WrapperSerde
-
- 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
-
- 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, Throwable) - Constructor for exception org.apache.kafka.common.errors.DisconnectException
-
- DisconnectException(String) - 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 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
-
- Double() - Static method in class org.apache.kafka.common.serialization.Serdes
-
- DoubleDeserializer - Class in org.apache.kafka.common.serialization
-
- DoubleDeserializer() - Constructor for class org.apache.kafka.common.serialization.DoubleDeserializer
-
- DoubleSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.DoubleSerde
-
- DoubleSerializer - Class in org.apache.kafka.common.serialization
-
- DoubleSerializer() - Constructor for class org.apache.kafka.common.serialization.DoubleSerializer
-
- DOWNSTREAM_OFFSET_KEY - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
-
- downstreamOffset() - Method in class org.apache.kafka.connect.mirror.Checkpoint
-
- DUMMY_THREAD_INDEX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
- duplicate() - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- duplicate() - Method in interface org.apache.kafka.connect.header.Headers
-
Create a copy of this
Headers
object.
- DuplicateSequenceException - Exception in org.apache.kafka.common.errors
-
- DuplicateSequenceException(String) - Constructor for exception org.apache.kafka.common.errors.DuplicateSequenceException
-
- FailOnInvalidTimestamp - Class in org.apache.kafka.streams.processor
-
Retrieves embedded metadata timestamps from Kafka messages.
- FailOnInvalidTimestamp() - Constructor for class org.apache.kafka.streams.processor.FailOnInvalidTimestamp
-
- FATAL_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
-
The FATAL
level designates a very severe error
that will lead the Kafka broker to abort.
- FencedInstanceIdException - Exception in org.apache.kafka.common.errors
-
- FencedInstanceIdException(String) - Constructor for exception org.apache.kafka.common.errors.FencedInstanceIdException
-
- FencedInstanceIdException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.FencedInstanceIdException
-
- FencedLeaderEpochException - Exception in org.apache.kafka.common.errors
-
The request contained a leader epoch which is smaller than that on the broker that received the
request.
- FencedLeaderEpochException(String) - Constructor for exception org.apache.kafka.common.errors.FencedLeaderEpochException
-
- FencedLeaderEpochException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.FencedLeaderEpochException
-
- fenceProducer() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- fenceProducerOnClose() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- fetch(K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Retrieve all aggregated sessions for the provided key.
- fetch(K, K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
-
Retrieve all aggregated sessions for the given range of keys.
- fetch(K, long) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
-
Get the value of key from a window.
- fetch(K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
-
- fetch(K, 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, K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
-
- 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, 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.WindowStore
-
- 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.WindowStore
-
- FETCH_MAX_BYTES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
fetch.max.bytes
- FETCH_MAX_WAIT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
fetch.max.wait.ms
- FETCH_MIN_BYTES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
fetch.min.bytes
- fetchAll(long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
-
- fetchAll(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(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.WindowStore
-
- fetchSession(K, long, long) - Method in interface org.apache.kafka.streams.state.SessionStore
-
Get the value of key from a single session.
- FetchSessionIdNotFoundException - Exception in org.apache.kafka.common.errors
-
- FetchSessionIdNotFoundException() - Constructor for exception org.apache.kafka.common.errors.FetchSessionIdNotFoundException
-
- FetchSessionIdNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.FetchSessionIdNotFoundException
-
- field(String) - Method in class org.apache.kafka.connect.data.ConnectSchema
-
- Field - Class in org.apache.kafka.connect.data
-
A field in a
Struct
, consisting of a field name, index, and
Schema
for the field value.
- Field(String, int, Schema) - Constructor for class org.apache.kafka.connect.data.Field
-
- field(String) - Method in interface org.apache.kafka.connect.data.Schema
-
Get a field for this Schema by name.
- field(String, Schema) - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Add a field to this struct schema.
- field(String) - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
- fields() - Method in class org.apache.kafka.connect.data.ConnectSchema
-
- fields() - Method in interface org.apache.kafka.connect.data.Schema
-
Get the list of fields for this Schema.
- fields() - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Get the list of fields for this Schema.
- FILE_DELETE_DELAY_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- FILE_DELETE_DELAY_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- FileConfigProvider - Class in org.apache.kafka.common.config.provider
-
An implementation of
ConfigProvider
that represents a Properties file.
- FileConfigProvider() - Constructor for class org.apache.kafka.common.config.provider.FileConfigProvider
-
- fillInStackTrace() - Method in exception org.apache.kafka.common.errors.ApiException
-
- fillInStackTrace() - Method in exception org.apache.kafka.common.errors.SerializationException
-
- 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>, 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>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
that consists of all records of this KTable
which satisfy the given
predicate, with default serializers, deserializers, and state store.
- filter(Predicate<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
that consists of all records of this KTable
which satisfy the given
predicate, with default serializers, deserializers, and state store.
- filter(Predicate<? super K, ? super V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- filter(Predicate<? super K, ? super V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- 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>, 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>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
that consists all records of this KTable
which do not satisfy the
given predicate, with default serializers, deserializers, and state store.
- filterNot(Predicate<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
that consists all records of this KTable
which do not satisfy the
given predicate, with default serializers, deserializers, and state store.
- filterNot(Predicate<? super K, ? super V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- filterNot(Predicate<? super K, ? super V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- findIndefiniteField() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
-
Returns a string describing an ANY or UNKNOWN field, or null if there is
no such field.
- findIndefiniteField() - Method in class org.apache.kafka.common.acl.AclBindingFilter
-
Return a string describing an ANY or UNKNOWN field, or null if there is no such field.
- findIndefiniteField() - Method in class org.apache.kafka.common.resource.ResourceFilter
-
Return a string describing an ANY or UNKNOWN field, or null if there is no such field.
- findIndefiniteField() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
-
- findSessions(K, long, long) - Method in interface org.apache.kafka.streams.state.SessionStore
-
Fetch any sessions with the matching key and the sessions end is ≥ earliestSessionEndTime and the sessions
start is ≤ latestSessionStartTime
This iterator must be closed after use.
- findSessions(K, K, long, long) - Method in interface org.apache.kafka.streams.state.SessionStore
-
Fetch any sessions in the given range of keys and the sessions end is ≥ earliestSessionEndTime and the sessions
start is ≤ latestSessionStartTime
This iterator must be closed after use.
- flatMap(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into zero or more records in the output stream (both key and value type
can be altered arbitrarily).
- flatMap(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into zero or more records in the output stream (both key and value type
can be altered arbitrarily).
- flatMapValues(ValueMapper<? super V, ? extends Iterable<? extends VR>>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Create a new KStream
by transforming the value of each record in this stream into zero or more values
with the same key in the new stream.
- flatMapValues(ValueMapper<? super V, ? extends Iterable<? extends VR>>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Create a new KStream
by transforming the value of each record in this stream into zero or more values
with the same key in the new stream.
- flatMapValues(ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Create a new KStream
by transforming the value of each record in this stream into zero or more values
with the same key in the new stream.
- flatMapValues(ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Create a new KStream
by transforming the value of each record in this stream into zero or more values
with the same key in the new stream.
- flatTransform(TransformerSupplier<? super K, ? super V, Iterable<KeyValue<K1, V1>>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into zero or more records in the output stream (both key and value type
can be altered arbitrarily).
- flatTransform(TransformerSupplier<? super K, ? super V, Iterable<KeyValue<K1, V1>>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into zero or more records in the output stream (both key and value type
can be altered arbitrarily).
- flatTransformValues(ValueTransformerSupplier<? super V, Iterable<VR>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into zero or more new values (with possibly a new
type) and emit for each new value a record with the same key of the input record and the value.
- flatTransformValues(ValueTransformerSupplier<? super V, Iterable<VR>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into zero or more new values (with possibly a new
type) and emit for each new value a record with the same key of the input record and the value.
- flatTransformValues(ValueTransformerWithKeySupplier<? super K, ? super V, Iterable<VR>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into zero or more new values (with possibly a new
type) and emit for each new value a record with the same key of the input record and the value.
- flatTransformValues(ValueTransformerWithKeySupplier<? super K, ? super V, Iterable<VR>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into zero or more new values (with possibly a new
type) and emit for each new value a record with the same key of the input record and the value.
- Float() - Static method in class org.apache.kafka.common.serialization.Serdes
-
- float32() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
-
- FLOAT32_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
-
- float64() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
-
- 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(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.apache.kafka.connect.sink.SinkTask
-
- flush() - Method in interface org.apache.kafka.streams.processor.StateStore
-
Flush any cached data
- 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
-
- forChangelog(boolean) - Method in class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
-
- forConfig(String) - Static method in enum org.apache.kafka.common.config.SslClientAuth
-
- foreach(ForeachAction<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Perform an action on each record of KStream
.
- foreach(ForeachAction<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Perform an action on each record of KStream
.
- ForeachAction<K,V> - Interface in org.apache.kafka.streams.kstream
-
The
ForeachAction
interface for performing an action on a
key-value
pair
.
- forGroupId(String) - Static method in exception org.apache.kafka.common.errors.GroupAuthorizationException
-
- forId(byte) - Static method in enum org.apache.kafka.clients.admin.AlterConfigOp.OpType
-
- forId(byte) - Static method in enum org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
-
- forId(byte) - Static method in enum org.apache.kafka.common.config.ConfigResource.Type
-
- forId(short) - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
-
- formatRemoteTopic(String, String) - Method in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
-
- formatRemoteTopic(String, String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
-
How to rename remote topics; generally should be like us-west.topic1.
- forName(String) - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
-
Case insensitive lookup by protocol name
- forward(K, V) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- forward(K, V, To) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- forward(K, V, int) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
Deprecated.
- forward(K, V, String) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
Deprecated.
- forward(K, V) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Forwards a key/value pair to all downstream processors.
- forward(K, V, To) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Forwards a key/value pair to the specified downstream processors.
- forward(K, V, int) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
- forward(K, V, String) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
- 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.MockProcessorContext
-
Get all the forwarded data this context has observed for a specific child by name.
- fromCode(byte) - Static method in enum org.apache.kafka.common.acl.AclOperation
-
Return the AclOperation with the provided code or `AclOperation.UNKNOWN` if one cannot be found.
- fromCode(byte) - Static method in enum org.apache.kafka.common.acl.AclPermissionType
-
Return the AclPermissionType with the provided code or `AclPermissionType.UNKNOWN` if one cannot be found.
- fromCode(byte) - Static method in enum org.apache.kafka.common.resource.PatternType
-
- fromCode(byte) - Static method in enum org.apache.kafka.common.resource.ResourceType
-
Return the ResourceType with the provided code or `ResourceType.UNKNOWN` if one cannot be found.
- fromConnectData(String, 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, 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 class org.apache.kafka.connect.storage.StringConverter
-
- fromConnectHeader(String, String, Schema, Object) - Method in interface org.apache.kafka.connect.storage.HeaderConverter
-
Convert the
Header
's
value
into its byte array representation.
- fromConnectHeader(String, String, Schema, Object) - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
-
- fromConnectHeader(String, String, Schema, Object) - Method in class org.apache.kafka.connect.storage.StringConverter
-
- fromLogical(Schema, 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, 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.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.
- fromString(String) - Static method in enum org.apache.kafka.common.acl.AclOperation
-
Parse the given string as an ACL operation.
- fromString(String) - Static method in enum org.apache.kafka.common.acl.AclPermissionType
-
Parse the given string as an ACL permission.
- fromString(String) - Static method in enum org.apache.kafka.common.resource.PatternType
-
- fromString(String) - Static method in enum org.apache.kafka.common.resource.ResourceType
-
Parse the given string as an ACL resource type.
- fromString(String) - Static method in class org.apache.kafka.common.security.auth.KafkaPrincipal
-
- Function() - Constructor for class org.apache.kafka.common.KafkaFuture.Function
-
- id() - Method in enum org.apache.kafka.clients.admin.AlterConfigOp.OpType
-
- id() - Method in enum org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
-
- id() - Method in enum org.apache.kafka.common.config.ConfigResource.Type
-
- id() - Method in class org.apache.kafka.common.Node
-
The node id of this node
- id - Variable in enum org.apache.kafka.common.security.auth.SecurityProtocol
-
The permanent and immutable id of a security protocol -- this can't change, and must match kafka.cluster.SecurityProtocol
- id - Variable in enum org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
-
the permanent and immutable id of an API--this can't change ever
- id - Variable in enum org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
-
the permanent and immutable id of an API--this can't change ever
- id() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
-
- id() - Method in interface org.apache.kafka.streams.TopologyDescription.Subtopology
-
Internally assigned unique ID.
- idString() - Method in class org.apache.kafka.common.Node
-
String representation of the node id.
- ignore(String) - Method in class org.apache.kafka.common.config.AbstractConfig
-
- ignoredExtensions() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
-
- IllegalGenerationException - Exception in org.apache.kafka.common.errors
-
- IllegalGenerationException() - Constructor for exception org.apache.kafka.common.errors.IllegalGenerationException
-
- IllegalGenerationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.IllegalGenerationException
-
- IllegalGenerationException(String) - Constructor for exception org.apache.kafka.common.errors.IllegalGenerationException
-
- IllegalGenerationException(Throwable) - Constructor for exception org.apache.kafka.common.errors.IllegalGenerationException
-
- IllegalSaslStateException - Exception in org.apache.kafka.common.errors
-
This exception indicates unexpected requests prior to SASL authentication.
- IllegalSaslStateException(String) - Constructor for exception org.apache.kafka.common.errors.IllegalSaslStateException
-
- IllegalSaslStateException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.IllegalSaslStateException
-
- IllegalWorkerStateException - Exception in org.apache.kafka.connect.errors
-
Indicates that a method has been invoked illegally or at an invalid time by a connector or task.
- IllegalWorkerStateException(String) - Constructor for exception org.apache.kafka.connect.errors.IllegalWorkerStateException
-
- IllegalWorkerStateException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.IllegalWorkerStateException
-
- IllegalWorkerStateException(Throwable) - Constructor for exception org.apache.kafka.connect.errors.IllegalWorkerStateException
-
- importance - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- in(String...) - Static method in class org.apache.kafka.common.config.ConfigDef.CaseInsensitiveValidString
-
- in(String...) - Static method in class org.apache.kafka.common.config.ConfigDef.ValidList
-
- in(String...) - Static method in class org.apache.kafka.common.config.ConfigDef.ValidString
-
- inactivityGap() - Method in class org.apache.kafka.streams.kstream.SessionWindows
-
Return the specified gap for the session windows in milliseconds.
- includeAuthorizedOperations(boolean) - Method in class org.apache.kafka.clients.admin.DescribeClusterOptions
-
- includeAuthorizedOperations() - Method in class org.apache.kafka.clients.admin.DescribeClusterOptions
-
Specify if authorized operations should be included in the response.
- includeAuthorizedOperations(boolean) - Method in class org.apache.kafka.clients.admin.DescribeConsumerGroupsOptions
-
- includeAuthorizedOperations() - Method in class org.apache.kafka.clients.admin.DescribeConsumerGroupsOptions
-
- includeAuthorizedOperations(boolean) - Method in class org.apache.kafka.clients.admin.DescribeTopicsOptions
-
- includeAuthorizedOperations() - Method in class org.apache.kafka.clients.admin.DescribeTopicsOptions
-
- includeSynonyms() - Method in class org.apache.kafka.clients.admin.DescribeConfigsOptions
-
Return true if synonym configs should be returned in the response.
- includeSynonyms(boolean) - Method in class org.apache.kafka.clients.admin.DescribeConfigsOptions
-
Set to true if synonym configs should be returned in the response.
- InconsistentGroupProtocolException - Exception in org.apache.kafka.common.errors
-
- InconsistentGroupProtocolException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InconsistentGroupProtocolException
-
- InconsistentGroupProtocolException(String) - Constructor for exception org.apache.kafka.common.errors.InconsistentGroupProtocolException
-
- increaseTo(int) - Static method in class org.apache.kafka.clients.admin.NewPartitions
-
Increase the partition count for a topic to the given totalCount
.
- increaseTo(int, List<List<Integer>>) - Static method in class org.apache.kafka.clients.admin.NewPartitions
-
Increase the partition count for a topic to the given totalCount
assigning the new partitions according to the given newAssignments
.
- incrementalAlterConfigs(Map<ConfigResource, Collection<AlterConfigOp>>) - Method in interface org.apache.kafka.clients.admin.Admin
-
Incrementally updates the configuration for the specified resources with default options.
- incrementalAlterConfigs(Map<ConfigResource, Collection<AlterConfigOp>>, AlterConfigsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Incrementally update the configuration for the specified resources.
- incrementalAlterConfigs(Map<ConfigResource, Collection<AlterConfigOp>>, AlterConfigsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- index() - Method in class org.apache.kafka.connect.data.Field
-
Get the index of this field within the struct.
- INDEX_INTERVAL_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- INDEX_INTERVAL_BYTES_DOCS - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- inferSchema(Object) - Static method in class org.apache.kafka.connect.data.Values
-
If possible infer a schema for the given value.
- INFO_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
-
The INFO
level designates informational messages
that highlight normal Kafka events at a coarse-grained level
- init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.Transformer
-
Initialize this transformer.
- init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
-
Initialize this transformer.
- init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKey
-
Initialize this transformer.
- init(ProcessorContext) - Method in class org.apache.kafka.streams.processor.AbstractProcessor
-
- init(ProcessorContext) - Method in interface org.apache.kafka.streams.processor.Processor
-
Initialize this processor with the given context.
- init(ProcessorContext, StateStore) - Method in interface org.apache.kafka.streams.processor.StateStore
-
Initializes this state store.
- initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
-
- initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.apache.kafka.common.security.plain.PlainLoginModule
-
- initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.apache.kafka.common.security.scram.ScramLoginModule
-
- initialize(ConnectorContext) - Method in class org.apache.kafka.connect.connector.Connector
-
Initialize this connector, using the provided ConnectorContext to notify the runtime of
input configuration changes.
- initialize(ConnectorContext, List<Map<String, String>>) - Method in class org.apache.kafka.connect.connector.Connector
-
Initialize this connector, using the provided ConnectorContext to notify the runtime of
input configuration changes and using the provided set of Task configurations.
- initialize(SinkTaskContext) - Method in class org.apache.kafka.connect.sink.SinkTask
-
Initialize the context of this task.
- initialize(SourceTaskContext) - Method in class org.apache.kafka.connect.source.SourceTask
-
Initialize this SourceTask with the specified context object.
- Initializer<VA> - Interface in org.apache.kafka.streams.kstream
-
The Initializer
interface for creating an initial value in aggregations.
- initTransactions() - Method in class org.apache.kafka.clients.producer.KafkaProducer
-
Needs to be called before any other methods when the transactional.id is set in the configuration.
- initTransactions() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- initTransactions() - Method in interface org.apache.kafka.clients.producer.Producer
-
- inMemoryKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
-
- inMemorySessionStore(String, Duration) - Static method in class org.apache.kafka.streams.state.Stores
-
- inMemoryWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
-
- inputExtensions() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
-
- INSTANCE - Static variable in exception org.apache.kafka.common.errors.CoordinatorNotAvailableException
-
- INSTANCE - Static variable in exception org.apache.kafka.common.errors.DisconnectException
-
- inSyncReplicas() - Method in class org.apache.kafka.common.PartitionInfo
-
The subset of the replicas that are in sync, that is caught-up to the leader and ready to take over as leader if
the leader should fail
- int16() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
-
- INT16_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
-
- int32() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
-
- INT32_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
-
- int64() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
-
- INT64_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
-
- int8() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
-
- INT8_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
-
- Integer() - Static method in class org.apache.kafka.common.serialization.Serdes
-
- IntegerDeserializer - Class in org.apache.kafka.common.serialization
-
- IntegerDeserializer() - Constructor for class org.apache.kafka.common.serialization.IntegerDeserializer
-
- IntegerSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.IntegerSerde
-
- IntegerSerializer - Class in org.apache.kafka.common.serialization
-
- IntegerSerializer() - Constructor for class org.apache.kafka.common.serialization.IntegerSerializer
-
- interBrokerEndpoint() - Method in interface org.apache.kafka.server.authorizer.AuthorizerServerInfo
-
Returns the inter-broker endpoint.
- INTERCEPTOR_CLASSES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
interceptor.classes
- INTERCEPTOR_CLASSES_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
interceptor.classes
- INTERCEPTOR_CLASSES_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- INTERCEPTOR_CLASSES_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
- InterfaceStability - Class in org.apache.kafka.common.annotation
-
Annotation to inform users of how much to rely on a particular package, class or method not changing over time.
- InterfaceStability() - Constructor for class org.apache.kafka.common.annotation.InterfaceStability
-
- InterfaceStability.Evolving - Annotation Type in org.apache.kafka.common.annotation
-
Compatibility may be broken at minor release (i.e.
- InterfaceStability.Stable - Annotation Type in org.apache.kafka.common.annotation
-
Compatibility is maintained in major, minor and patch releases with one exception: compatibility may be broken
in a major release (i.e.
- InterfaceStability.Unstable - Annotation Type in org.apache.kafka.common.annotation
-
No guarantee is provided as to reliability or stability across any level of release granularity.
- internalConfig - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- InternalConfig() - Constructor for class org.apache.kafka.streams.StreamsConfig.InternalConfig
-
- internalTopics() - Method in class org.apache.kafka.common.Cluster
-
- InterruptException - Exception in org.apache.kafka.common.errors
-
An unchecked wrapper for InterruptedException
- InterruptException(InterruptedException) - Constructor for exception org.apache.kafka.common.errors.InterruptException
-
- InterruptException(String, InterruptedException) - Constructor for exception org.apache.kafka.common.errors.InterruptException
-
- InterruptException(String) - Constructor for exception org.apache.kafka.common.errors.InterruptException
-
- InvalidCommitOffsetSizeException - Exception in org.apache.kafka.common.errors
-
- InvalidCommitOffsetSizeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidCommitOffsetSizeException
-
- InvalidCommitOffsetSizeException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidCommitOffsetSizeException
-
- InvalidConfigurationException - Exception in org.apache.kafka.common.errors
-
- InvalidConfigurationException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidConfigurationException
-
- InvalidConfigurationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidConfigurationException
-
- invalidExtensions() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
-
- InvalidFetchSessionEpochException - Exception in org.apache.kafka.common.errors
-
- InvalidFetchSessionEpochException() - Constructor for exception org.apache.kafka.common.errors.InvalidFetchSessionEpochException
-
- InvalidFetchSessionEpochException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidFetchSessionEpochException
-
- InvalidFetchSizeException - Exception in org.apache.kafka.common.errors
-
- InvalidFetchSizeException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidFetchSizeException
-
- InvalidFetchSizeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidFetchSizeException
-
- InvalidGroupIdException - Exception in org.apache.kafka.common.errors
-
- InvalidGroupIdException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidGroupIdException
-
- InvalidGroupIdException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidGroupIdException
-
- InvalidMetadataException - Exception in org.apache.kafka.common.errors
-
An exception that may indicate the client's metadata is out of date
- InvalidMetadataException() - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
-
- InvalidMetadataException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
-
- InvalidMetadataException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
-
- InvalidMetadataException(Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
-
- InvalidOffsetException - Exception in org.apache.kafka.clients.consumer
-
Thrown when the offset for a set of partitions is invalid (either undefined or out of range),
and no reset policy has been configured.
- InvalidOffsetException(String) - Constructor for exception org.apache.kafka.clients.consumer.InvalidOffsetException
-
- InvalidOffsetException - Exception in org.apache.kafka.common.errors
-
Thrown when the offset for a set of partitions is invalid (either undefined or out of range),
and no reset policy has been configured.
- InvalidOffsetException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidOffsetException
-
- InvalidOffsetException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidOffsetException
-
- InvalidPartitionsException - Exception in org.apache.kafka.common.errors
-
- InvalidPartitionsException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidPartitionsException
-
- InvalidPartitionsException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidPartitionsException
-
- InvalidPidMappingException - Exception in org.apache.kafka.common.errors
-
- InvalidPidMappingException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidPidMappingException
-
- InvalidPrincipalTypeException - Exception in org.apache.kafka.common.errors
-
- InvalidPrincipalTypeException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidPrincipalTypeException
-
- InvalidPrincipalTypeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidPrincipalTypeException
-
- InvalidRecordException - Exception in org.apache.kafka.common
-
- InvalidRecordException(String) - Constructor for exception org.apache.kafka.common.InvalidRecordException
-
- InvalidRecordException(String, Throwable) - Constructor for exception org.apache.kafka.common.InvalidRecordException
-
- InvalidReplicaAssignmentException - Exception in org.apache.kafka.common.errors
-
- InvalidReplicaAssignmentException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidReplicaAssignmentException
-
- InvalidReplicaAssignmentException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidReplicaAssignmentException
-
- InvalidReplicationFactorException - Exception in org.apache.kafka.common.errors
-
- InvalidReplicationFactorException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidReplicationFactorException
-
- InvalidReplicationFactorException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidReplicationFactorException
-
- InvalidRequestException - Exception in org.apache.kafka.common.errors
-
Thrown when a request breaks basic wire protocol rules.
- InvalidRequestException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidRequestException
-
- InvalidRequestException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidRequestException
-
- InvalidRequiredAcksException - Exception in org.apache.kafka.common.errors
-
- InvalidRequiredAcksException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidRequiredAcksException
-
- InvalidSessionTimeoutException - Exception in org.apache.kafka.common.errors
-
- InvalidSessionTimeoutException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidSessionTimeoutException
-
- InvalidSessionTimeoutException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidSessionTimeoutException
-
- InvalidStateStoreException - Exception in org.apache.kafka.streams.errors
-
Indicates that there was a problem when trying to access a
StateStore
, i.e, the Store is no longer valid because it is
closed or doesn't exist any more due to a rebalance.
- InvalidStateStoreException(String) - Constructor for exception org.apache.kafka.streams.errors.InvalidStateStoreException
-
- InvalidStateStoreException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.InvalidStateStoreException
-
- InvalidStateStoreException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.InvalidStateStoreException
-
- InvalidTimestampException - Exception in org.apache.kafka.common.errors
-
Indicate the timestamp of a record is invalid.
- InvalidTimestampException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidTimestampException
-
- InvalidTimestampException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidTimestampException
-
- InvalidTopicException - Exception in org.apache.kafka.common.errors
-
The client has attempted to perform an operation on an invalid topic.
- InvalidTopicException() - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
-
- InvalidTopicException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
-
- InvalidTopicException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
-
- InvalidTopicException(Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
-
- InvalidTopicException(Set<String>) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
-
- invalidTopics() - Method in class org.apache.kafka.common.Cluster
-
- invalidTopics() - Method in exception org.apache.kafka.common.errors.InvalidTopicException
-
- InvalidTxnStateException - Exception in org.apache.kafka.common.errors
-
- InvalidTxnStateException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidTxnStateException
-
- InvalidTxnTimeoutException - Exception in org.apache.kafka.common.errors
-
The transaction coordinator returns this error code if the timeout received via the InitProducerIdRequest is larger than
the `transaction.max.timeout.ms` config value.
- InvalidTxnTimeoutException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidTxnTimeoutException
-
- InvalidTxnTimeoutException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidTxnTimeoutException
-
- isBootstrapConfigured() - Method in class org.apache.kafka.common.Cluster
-
- isCancelled() - Method in class org.apache.kafka.common.KafkaFuture
-
Returns true if this CompletableFuture was cancelled before it completed normally.
- isCompletedExceptionally() - Method in class org.apache.kafka.common.KafkaFuture
-
Returns true if this CompletableFuture completed exceptionally, in any way.
- isDefault() - Method in class org.apache.kafka.clients.admin.ConfigEntry
-
Return whether the config value is the default or if it's been explicitly set.
- isDefault() - Method in class org.apache.kafka.common.config.ConfigResource
-
Returns true if this is the default resource of a resource type.
- isDone() - Method in class org.apache.kafka.common.KafkaFuture
-
Returns true if completed in any fashion: normally, exceptionally, or via cancellation.
- isEmpty() - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
-
- isEmpty() - Method in class org.apache.kafka.common.Node
-
Check whether this node is empty, which may be the case if noNode() is used as a placeholder
in a response payload with an error.
- isEmpty() - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- isEmpty() - Method in interface org.apache.kafka.connect.header.Headers
-
Determine whether this object has no headers.
- isEmpty() - Method in class org.apache.kafka.streams.TestOutputTopic
-
Verify if the topic queue is empty.
- isInternal() - Method in class org.apache.kafka.clients.admin.TopicDescription
-
Whether the topic is internal to Kafka.
- isInternal() - Method in class org.apache.kafka.clients.admin.TopicListing
-
Whether the topic is internal to Kafka.
- isInternalTopic(String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
-
Internal topics are never replicated.
- isNext(String, boolean) - Method in class org.apache.kafka.connect.data.Values.Parser
-
- ISOLATION_LEVEL_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
isolation.level
- ISOLATION_LEVEL_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- isOpen() - Method in interface org.apache.kafka.streams.processor.StateStore
-
Is this store open for reading and writing
- isOptional() - Method in class org.apache.kafka.connect.data.ConnectSchema
-
- isOptional() - Method in interface org.apache.kafka.connect.data.Schema
-
- isOptional() - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
- isPrimitive() - Method in enum org.apache.kafka.connect.data.Schema.Type
-
- isr() - Method in class org.apache.kafka.common.TopicPartitionInfo
-
Return the in-sync replicas of the partition.
- isReadOnly() - Method in class org.apache.kafka.clients.admin.ConfigEntry
-
Return whether the config is read-only and cannot be updated.
- isRunning() - Method in enum org.apache.kafka.streams.KafkaStreams.State
-
- isSensitive() - Method in class org.apache.kafka.clients.admin.ConfigEntry
-
Return whether the config value is sensitive.
- isSimpleConsumerGroup() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
-
If consumer group is simple or not.
- isSimpleConsumerGroup() - Method in class org.apache.kafka.clients.admin.ConsumerGroupListing
-
If Consumer Group is simple or not.
- isSpecific() - Method in enum org.apache.kafka.common.resource.PatternType
-
- issueTimestamp() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- isUnknown() - Method in class org.apache.kafka.common.acl.AccessControlEntry
-
Return true if this AclResource has any UNKNOWN components.
- isUnknown() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
-
Return true if there are any UNKNOWN components.
- isUnknown() - Method in class org.apache.kafka.common.acl.AclBinding
-
- isUnknown() - Method in class org.apache.kafka.common.acl.AclBindingFilter
-
- isUnknown() - Method in enum org.apache.kafka.common.acl.AclOperation
-
Return true if this operation is UNKNOWN.
- isUnknown() - Method in enum org.apache.kafka.common.acl.AclPermissionType
-
Return true if this permission type is UNKNOWN.
- isUnknown() - Method in enum org.apache.kafka.common.resource.PatternType
-
- isUnknown() - Method in class org.apache.kafka.common.resource.Resource
-
Return true if this Resource has any UNKNOWN components.
- isUnknown() - Method in class org.apache.kafka.common.resource.ResourceFilter
-
Return true if this ResourceFilter has any UNKNOWN components.
- isUnknown() - Method in class org.apache.kafka.common.resource.ResourcePattern
-
- isUnknown() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
-
- isUnknown() - Method in enum org.apache.kafka.common.resource.ResourceType
-
Return whether this resource type is UNKNOWN.
- isValidTransition(KafkaStreams.State) - Method in enum org.apache.kafka.streams.KafkaStreams.State
-
- iterations() - Method in class org.apache.kafka.common.security.scram.ScramCredential
-
Number of iterations used to process this credential using the SCRAM algorithm.
- iterator() - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
-
- iterator() - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- label - Variable in class org.apache.kafka.streams.kstream.Printed
-
- lastHeader(String) - Method in interface org.apache.kafka.common.header.Headers
-
Returns just one (the very last) header for the given key, if present.
- lastWithName(String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- lastWithName(String) - Method in interface org.apache.kafka.connect.header.Headers
-
Return the last
Header
with the specified key.
- leader() - Method in class org.apache.kafka.common.PartitionInfo
-
The node id of the node currently acting as a leader for this partition or null if there is no leader
- leader() - Method in class org.apache.kafka.common.TopicPartitionInfo
-
Return the leader of the partition or null if there is none.
- leaderEpoch() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
Get the leader epoch for the record if available
- leaderEpoch() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
-
Get the leader epoch of the previously consumed record (if one is known).
- leaderEpoch() - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
-
Get the leader epoch corresponding to the offset that was found (if one exists).
- leaderFor(TopicPartition) - Method in class org.apache.kafka.common.Cluster
-
Get the current leader for the given topic-partition
- LeaderNotAvailableException - Exception in org.apache.kafka.common.errors
-
There is no currently available leader for the given partition (either because a leadership election is in progress
or because all replicas are down).
- LeaderNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.LeaderNotAvailableException
-
- LeaderNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.LeaderNotAvailableException
-
- leftJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with another KStream
's records using windowed left equi join with default
serializers and deserializers.
- leftJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, Joined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
- leftJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
- leftJoin(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
KTable
's records using non-windowed left equi join with default
serializers and deserializers.
- leftJoin(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>, Joined<K, V, VT>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
KTable
's records using non-windowed left equi join with default
serializers and deserializers.
- leftJoin(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoiner<? super V, ? super GV, ? extends RV>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
GlobalKTable
's records using non-windowed left equi join.
- leftJoin(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoiner<? super V, ? super GV, ? extends RV>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with
GlobalKTable
's records using non-windowed left equi join.
- leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this KTable
(left input) with another KTable
's (right input) records using
non-windowed left equi join, with default serializers, deserializers, and state store.
- leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this KTable
(left input) with another KTable
's (right input) records using
non-windowed left equi join, with default serializers, deserializers, and state store.
- leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this KTable
with another KTable
using non-windowed left join.
- leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this KTable
with another KTable
using non-windowed left join.
- leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this KTable
with another KTable
using non-windowed left join.
- leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this KTable
with another KTable
using non-windowed left join.
- lifetimeMs() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
-
The token's lifetime, expressed as the number of milliseconds since the
epoch, as per
RFC
6749 Section 1.4
- LINGER_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
linger.ms
- listConsumerGroupOffsets(String, ListConsumerGroupOffsetsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
List the consumer group offsets available in the cluster.
- listConsumerGroupOffsets(String) - Method in interface org.apache.kafka.clients.admin.Admin
-
List the consumer group offsets available in the cluster with the default options.
- listConsumerGroupOffsets(String, ListConsumerGroupOffsetsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- ListConsumerGroupOffsetsOptions - Class in org.apache.kafka.clients.admin
-
- ListConsumerGroupOffsetsOptions() - Constructor for class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsOptions
-
- ListConsumerGroupOffsetsResult - Class in org.apache.kafka.clients.admin
-
- listConsumerGroups(ListConsumerGroupsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
List the consumer groups available in the cluster.
- listConsumerGroups() - Method in interface org.apache.kafka.clients.admin.Admin
-
List the consumer groups available in the cluster with the default options.
- listConsumerGroups(ListConsumerGroupsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- ListConsumerGroupsOptions - Class in org.apache.kafka.clients.admin
-
- ListConsumerGroupsOptions() - Constructor for class org.apache.kafka.clients.admin.ListConsumerGroupsOptions
-
- ListConsumerGroupsResult - Class in org.apache.kafka.clients.admin
-
- listenerName() - Method in class org.apache.kafka.common.Endpoint
-
Returns the listener name of this endpoint.
- listenerName() - Method in interface org.apache.kafka.common.security.auth.AuthenticationContext
-
Name of the listener used for the connection
- listenerName() - Method in class org.apache.kafka.common.security.auth.PlaintextAuthenticationContext
-
- listenerName() - Method in class org.apache.kafka.common.security.auth.SaslAuthenticationContext
-
- listenerName() - Method in class org.apache.kafka.common.security.auth.SslAuthenticationContext
-
- listenerName() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
-
Returns name of listener on which request was received.
- ListenerNotFoundException - Exception in org.apache.kafka.common.errors
-
The leader does not have an endpoint corresponding to the listener on which metadata was requested.
- ListenerNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.ListenerNotFoundException
-
- ListenerNotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ListenerNotFoundException
-
- listings() - Method in class org.apache.kafka.clients.admin.ListTopicsResult
-
Return a future which yields a collection of TopicListing objects.
- listInternal(boolean) - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
-
Set whether we should list internal topics.
- listPartitionReassignments() - Method in interface org.apache.kafka.clients.admin.Admin
-
- listPartitionReassignments(Set<TopicPartition>) - Method in interface org.apache.kafka.clients.admin.Admin
-
- listPartitionReassignments(Set<TopicPartition>, ListPartitionReassignmentsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
List the current reassignments for the given partitions
- listPartitionReassignments(ListPartitionReassignmentsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
List all of the current partition reassignments
- listPartitionReassignments(Optional<Set<TopicPartition>>, ListPartitionReassignmentsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
- listPartitionReassignments(Optional<Set<TopicPartition>>, ListPartitionReassignmentsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- ListPartitionReassignmentsOptions - Class in org.apache.kafka.clients.admin
-
- ListPartitionReassignmentsOptions() - Constructor for class org.apache.kafka.clients.admin.ListPartitionReassignmentsOptions
-
- ListPartitionReassignmentsResult - Class in org.apache.kafka.clients.admin
-
- listTopics() - Method in interface org.apache.kafka.clients.admin.Admin
-
List the topics available in the cluster with the default options.
- listTopics(ListTopicsOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
List the topics available in the cluster.
- listTopics(ListTopicsOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- listTopics() - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- listTopics(Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- listTopics() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Get metadata about partitions for all topics that the user is authorized to view.
- listTopics(Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Get metadata about partitions for all topics that the user is authorized to view.
- listTopics() - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- listTopics(Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- ListTopicsOptions - Class in org.apache.kafka.clients.admin
-
- ListTopicsOptions() - Constructor for class org.apache.kafka.clients.admin.ListTopicsOptions
-
- ListTopicsResult - Class in org.apache.kafka.clients.admin
-
- localThreadsMetadata() - Method in class org.apache.kafka.streams.KafkaStreams
-
Returns runtime information about the local threads of this
KafkaStreams
instance.
- LockException - Exception in org.apache.kafka.streams.errors
-
Indicates that the state store directory lock could not be acquired because another thread holds the lock.
- LockException(String) - Constructor for exception org.apache.kafka.streams.errors.LockException
-
- LockException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.LockException
-
- LockException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.LockException
-
- LOG - Static variable in interface org.apache.kafka.streams.state.RocksDBConfigSetter
-
- LogAndContinueExceptionHandler - Class in org.apache.kafka.streams.errors
-
Deserialization handler that logs a deserialization exception and then
signals the processing pipeline to continue processing more records.
- LogAndContinueExceptionHandler() - Constructor for class org.apache.kafka.streams.errors.LogAndContinueExceptionHandler
-
- LogAndFailExceptionHandler - Class in org.apache.kafka.streams.errors
-
Deserialization handler that logs a deserialization exception and then
signals the processing pipeline to stop processing more records and fail.
- LogAndFailExceptionHandler() - Constructor for class org.apache.kafka.streams.errors.LogAndFailExceptionHandler
-
- LogAndSkipOnInvalidTimestamp - Class in org.apache.kafka.streams.processor
-
Retrieves embedded metadata timestamps from Kafka messages.
- LogAndSkipOnInvalidTimestamp() - Constructor for class org.apache.kafka.streams.processor.LogAndSkipOnInvalidTimestamp
-
- logConfig() - Method in interface org.apache.kafka.streams.state.StoreBuilder
-
Returns a Map containing any log configs that will be used when creating the changelog for the
StateStore
.
- LogDirNotFoundException - Exception in org.apache.kafka.common.errors
-
Thrown when a request is made for a log directory that is not present on the broker
- LogDirNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.LogDirNotFoundException
-
- LogDirNotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.LogDirNotFoundException
-
- LogDirNotFoundException(Throwable) - Constructor for exception org.apache.kafka.common.errors.LogDirNotFoundException
-
- loggingEnabled - Variable in class org.apache.kafka.streams.kstream.Materialized
-
- loggingEnabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
-
- LOGICAL_NAME - Static variable in class org.apache.kafka.connect.data.Date
-
- LOGICAL_NAME - Static variable in class org.apache.kafka.connect.data.Decimal
-
- LOGICAL_NAME - Static variable in class org.apache.kafka.connect.data.Time
-
- LOGICAL_NAME - Static variable in class org.apache.kafka.connect.data.Timestamp
-
- logIfAllowed() - Method in class org.apache.kafka.server.authorizer.Action
-
Indicates if audit logs tracking ALLOWED access should include this action if result is
ALLOWED.
- logIfDenied() - Method in class org.apache.kafka.server.authorizer.Action
-
Indicates if audit logs tracking DENIED access should include this action if result is
DENIED.
- Login - Interface in org.apache.kafka.common.security.auth
-
Login interface for authentication.
- login() - Method in interface org.apache.kafka.common.security.auth.Login
-
Performs login for each login module specified for the login context of this instance.
- login() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
-
- login() - Method in class org.apache.kafka.common.security.plain.PlainLoginModule
-
- login() - Method in class org.apache.kafka.common.security.scram.ScramLoginModule
-
- LogLevelConfig - Class in org.apache.kafka.common.config
-
This class holds definitions for log level configurations related to Kafka's application logging.
- LogLevelConfig() - Constructor for class org.apache.kafka.common.config.LogLevelConfig
-
- logout() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
-
- logout() - Method in class org.apache.kafka.common.security.plain.PlainLoginModule
-
- logout() - Method in class org.apache.kafka.common.security.scram.ScramLoginModule
-
- LogTruncationException - Exception in org.apache.kafka.clients.consumer
-
In the even of unclean leader election, the log will be truncated,
previously committed data will be lost, and new data will be written
over these offsets.
- LogTruncationException(Map<TopicPartition, OffsetAndMetadata>) - Constructor for exception org.apache.kafka.clients.consumer.LogTruncationException
-
- logUnused() - Method in class org.apache.kafka.common.config.AbstractConfig
-
Log warnings for any unused configurations
- Long() - Static method in class org.apache.kafka.common.serialization.Serdes
-
- LongDeserializer - Class in org.apache.kafka.common.serialization
-
- LongDeserializer() - Constructor for class org.apache.kafka.common.serialization.LongDeserializer
-
- LongSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.LongSerde
-
- LongSerializer - Class in org.apache.kafka.common.serialization
-
- LongSerializer() - Constructor for class org.apache.kafka.common.serialization.LongSerializer
-
- lowWatermark() - Method in class org.apache.kafka.clients.admin.DeletedRecords
-
Return the "low watermark" for the topic partition on which the deletion was executed
- lowWatermarks() - Method in class org.apache.kafka.clients.admin.DeleteRecordsResult
-
Return a map from topic partition to futures which can be used to check the status of
individual deletions.
- lruMap(String, int) - Static method in class org.apache.kafka.streams.state.Stores
-
- main(String[]) - Static method in class org.apache.kafka.clients.admin.AdminClientConfig
-
- main(String[]) - Static method in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- main(String[]) - Static method in class org.apache.kafka.clients.producer.ProducerConfig
-
- main(String[]) - Static method in class org.apache.kafka.streams.StreamsConfig
-
- MAIN_CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to override
consumer
configs for the main consumer client from
the general consumer client configs.
- mainConsumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
- maintainMs() - Method in class org.apache.kafka.streams.kstream.JoinWindows
-
- maintainMs() - Method in class org.apache.kafka.streams.kstream.SessionWindows
-
- maintainMs() - Method in class org.apache.kafka.streams.kstream.TimeWindows
-
- maintainMs() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
- maintainMs() - Method in class org.apache.kafka.streams.kstream.Windows
-
- make(V, long) - Static method in class org.apache.kafka.streams.state.ValueAndTimestamp
-
- map() - Method in class org.apache.kafka.common.security.auth.SaslExtensions
-
Returns an immutable map of the extension names and their values
- map(Schema, Schema) - Static method in class org.apache.kafka.connect.data.SchemaBuilder
-
- map(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into a new record in the output stream (both key and value type can be
altered arbitrarily).
- map(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into a new record in the output stream (both key and value type can be
altered arbitrarily).
- mapper - Variable in class org.apache.kafka.streams.kstream.Printed
-
- mapValues(ValueMapper<? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into a new value (with possible new type) of the output record.
- mapValues(ValueMapper<? super V, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into a new value (with possible new type) of the output record.
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into a new value (with possible new type) of the output record.
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into a new value (with possible new type) of the output record.
- mapValues(ValueMapper<? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
by transforming the value of each record in this KTable
into a new value
(with possibly a new type) in the new KTable
, with default serializers, deserializers, and state store.
- mapValues(ValueMapper<? super V, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
by transforming the value of each record in this KTable
into a new value
(with possibly a new type) in the new KTable
, with default serializers, deserializers, and state store.
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
by transforming the value of each record in this KTable
into a new value
(with possibly a new type) in the new KTable
, with default serializers, deserializers, and state store.
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
by transforming the value of each record in this KTable
into a new value
(with possibly a new type) in the new KTable
, with default serializers, deserializers, and state store.
- mapValues(ValueMapper<? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- mapValues(ValueMapper<? super V, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- mark() - Method in class org.apache.kafka.connect.data.Values.Parser
-
- matches(AccessControlEntry) - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
-
Returns true if this filter matches the given AccessControlEntry.
- matches(AclBinding) - Method in class org.apache.kafka.common.acl.AclBindingFilter
-
Return true if the resource filter matches the binding's resource and the entry filter matches binding's entry.
- matches(Resource) - Method in class org.apache.kafka.common.resource.ResourceFilter
-
Return true if this filter matches the given Resource.
- matches(ResourcePattern) - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
-
- matchesAtMostOne() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
-
Returns true if this filter could only match one ACE -- in other words, if
there are no ANY or UNKNOWN fields.
- matchesAtMostOne() - Method in class org.apache.kafka.common.acl.AclBindingFilter
-
Return true if the resource and entry filters can only match one ACE.
- matchesAtMostOne() - Method in class org.apache.kafka.common.resource.ResourceFilter
-
Return true if this filter could only match one ACE.
- matchesAtMostOne() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
-
- Materialized<K,V,S extends StateStore> - Class in org.apache.kafka.streams.kstream
-
Used to describe how a
StateStore
should be materialized.
- Materialized(Materialized<K, V, S>) - Constructor for class org.apache.kafka.streams.kstream.Materialized
-
Copy constructor.
- MAX_BLOCK_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
max.block.ms
- MAX_COMPACTION_LAG_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MAX_COMPACTION_LAG_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MAX_IN_FLIGHT_REQUESTS_PER_CONNECTION - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
max.in.flight.requests.per.connection
- MAX_MESSAGE_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MAX_MESSAGE_BYTES_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MAX_PARTITION_FETCH_BYTES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
max.partition.fetch.bytes
- MAX_POLL_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
max.poll.interval.ms
- MAX_POLL_RECORDS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
max.poll.records
- MAX_REQUEST_SIZE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
max.request.size
- MAX_TASK_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
max.task.idle.ms
- maxBytes(long) - Static method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Create a size-constrained buffer in terms of the maximum number of bytes it will use.
- maxlifeTimeMs(long) - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
-
- maxlifeTimeMs() - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
-
- maxNumPartitions(Cluster, Set<String>) - Method in class org.apache.kafka.streams.processor.DefaultPartitionGrouper
-
Deprecated.
- maxRecords(long) - Static method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Create a size-constrained buffer in terms of the maximum number of keys it will store.
- maxTimestamp() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- MemberAssignment - Class in org.apache.kafka.clients.admin
-
A description of the assignments of a specific group member.
- MemberAssignment(Set<TopicPartition>) - Constructor for class org.apache.kafka.clients.admin.MemberAssignment
-
Creates an instance with the specified parameters.
- memberData(ConsumerPartitionAssignor.Subscription) - Method in class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
-
- memberData(ConsumerPartitionAssignor.Subscription) - Method in class org.apache.kafka.clients.consumer.StickyAssignor
-
- MemberDescription - Class in org.apache.kafka.clients.admin
-
A detailed description of a single group instance in the cluster.
- MemberDescription(String, Optional<String>, String, String, MemberAssignment) - Constructor for class org.apache.kafka.clients.admin.MemberDescription
-
- MemberDescription(String, String, String, MemberAssignment) - Constructor for class org.apache.kafka.clients.admin.MemberDescription
-
- memberId() - Method in class org.apache.kafka.clients.consumer.ConsumerGroupMetadata
-
- MemberIdRequiredException - Exception in org.apache.kafka.common.errors
-
- MemberIdRequiredException(String) - Constructor for exception org.apache.kafka.common.errors.MemberIdRequiredException
-
- MemberIdRequiredException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.MemberIdRequiredException
-
- memberResult(MemberToRemove) - Method in class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupResult
-
Returns the selected member future.
- members() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
-
A list of the members of the consumer group.
- members() - Method in class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupOptions
-
- MemberToRemove - Class in org.apache.kafka.clients.admin
-
A struct containing information about the member to be removed.
- MemberToRemove(String) - Constructor for class org.apache.kafka.clients.admin.MemberToRemove
-
- merge(KStream<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Merge this stream and the given stream into one larger stream.
- merge(KStream<K, V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Merge this stream and the given stream into one larger stream.
- Merger<K,V> - Interface in org.apache.kafka.streams.kstream
-
The interface for merging aggregate values for
SessionWindows
with the given key.
- MESSAGE_DOWNCONVERSION_ENABLE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MESSAGE_DOWNCONVERSION_ENABLE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MESSAGE_FORMAT_VERSION_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MESSAGE_FORMAT_VERSION_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MESSAGE_TIMESTAMP_DIFFERENCE_MAX_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MESSAGE_TIMESTAMP_DIFFERENCE_MAX_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MESSAGE_TIMESTAMP_TYPE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MESSAGE_TIMESTAMP_TYPE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- metadata() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
-
- metadata() - Method in class org.apache.kafka.connect.mirror.Checkpoint
-
- METADATA_KEY - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
-
- METADATA_MAX_AGE_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
- METADATA_MAX_AGE_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
metadata.max.age.ms
- METADATA_MAX_AGE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
metadata.max.age.ms
- METADATA_MAX_AGE_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
metadata.max.age.ms
- metadataForKey(String, K, Serializer<K>) - Method in class org.apache.kafka.streams.KafkaStreams
-
Find the currently running
KafkaStreams
instance (potentially remotely) that
use the same
application ID
as this instance (i.e., all
instances that belong to the same Kafka Streams application)
and that contain a
StateStore
with the given
storeName
and the
StateStore
contains the given
key
and return
StreamsMetadata
for it.
- metadataForKey(String, K, StreamPartitioner<? super K, ?>) - Method in class org.apache.kafka.streams.KafkaStreams
-
Find the currently running
KafkaStreams
instance (potentially remotely) that
use the same
application ID
as this instance (i.e., all
instances that belong to the same Kafka Streams application)
and that contain a
StateStore
with the given
storeName
and the
StateStore
contains the given
key
and return
StreamsMetadata
for it.
- Metric - Interface in org.apache.kafka.common
-
A metric tracked for monitoring purposes.
- METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
- METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
metric.reporters
- METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
metric.reporters
- METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
metric.reporters
- metricName() - Method in interface org.apache.kafka.common.Metric
-
A name for this metric
- MetricName - Class in org.apache.kafka.common
-
The MetricName
class encapsulates a metric's name, logical group and its related attributes.
- MetricName(String, String, String, Map<String, String>) - Constructor for class org.apache.kafka.common.MetricName
-
Please create MetricName by method Metrics.metricName(String, String, String, Map)
- MetricNameTemplate - Class in org.apache.kafka.common
-
A template for a MetricName.
- MetricNameTemplate(String, String, String, Set<String>) - Constructor for class org.apache.kafka.common.MetricNameTemplate
-
Create a new template.
- MetricNameTemplate(String, String, String, String...) - Constructor for class org.apache.kafka.common.MetricNameTemplate
-
Create a new template.
- metrics() - Method in interface org.apache.kafka.clients.admin.Admin
-
Get the metrics kept by the adminClient
- metrics() - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- metrics() - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- metrics() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Get the metrics kept by the consumer
- metrics() - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- metrics() - Method in class org.apache.kafka.clients.producer.KafkaProducer
-
Get the full set of internal metrics maintained by the producer.
- metrics() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- metrics() - Method in interface org.apache.kafka.clients.producer.Producer
-
- metrics() - Method in class org.apache.kafka.streams.KafkaStreams
-
Get read-only handle on global metrics registry, including streams client's own metrics plus
its embedded producer, consumer and admin clients' metrics.
- metrics() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- metrics() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Returns Metrics instance
- metrics() - Method in interface org.apache.kafka.streams.StreamsMetrics
-
Get read-only handle on global metrics registry.
- metrics() - Method in class org.apache.kafka.streams.TopologyTestDriver
-
Get read-only handle on global metrics registry.
- METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
- METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
metrics.num.samples
- METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
metrics.num.samples
- METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
metrics.num.samples
- METRICS_RECORDING_LEVEL_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
- METRICS_RECORDING_LEVEL_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
metrics.log.level
- METRICS_RECORDING_LEVEL_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
metrics.recording.level
- METRICS_RECORDING_LEVEL_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
metrics.record.level
- METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
- METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
metrics.sample.window.ms
- METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
metrics.sample.window.ms
- METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
metrics.sample.window.ms
- metricsScope() - Method in interface org.apache.kafka.streams.state.StoreSupplier
-
Return a String that is used as the scope for metrics recorded by Metered stores.
- metricValue() - Method in interface org.apache.kafka.common.Metric
-
The value of the metric, which may be measurable or a non-measurable gauge
- migratedTask() - Method in exception org.apache.kafka.streams.errors.TaskMigratedException
-
- MIN_CLEANABLE_DIRTY_RATIO_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MIN_CLEANABLE_DIRTY_RATIO_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MIN_COMPACTION_LAG_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MIN_COMPACTION_LAG_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MIN_IN_SYNC_REPLICAS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MIN_IN_SYNC_REPLICAS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- MirrorClient - Class in org.apache.kafka.connect.mirror
-
Interprets MM2's internal topics (checkpoints, heartbeats) on a given cluster.
- MirrorClient(Map<String, Object>) - Constructor for class org.apache.kafka.connect.mirror.MirrorClient
-
- MirrorClient(MirrorClientConfig) - Constructor for class org.apache.kafka.connect.mirror.MirrorClient
-
- MirrorClientConfig - Class in org.apache.kafka.connect.mirror
-
Configuration required for MirrorClient to talk to a given target cluster.
- MockConsumer<K,V> - Class in org.apache.kafka.clients.consumer
-
A mock of the
Consumer
interface you can use for testing code that uses Kafka.
- MockConsumer(OffsetResetStrategy) - Constructor for class org.apache.kafka.clients.consumer.MockConsumer
-
- MockProcessorContext - Class in org.apache.kafka.streams.processor
-
- MockProcessorContext() - Constructor for class org.apache.kafka.streams.processor.MockProcessorContext
-
- MockProcessorContext(Properties) - Constructor for class org.apache.kafka.streams.processor.MockProcessorContext
-
- MockProcessorContext(Properties, TaskId, File) - Constructor for class org.apache.kafka.streams.processor.MockProcessorContext
-
- MockProcessorContext.CapturedForward - Class in org.apache.kafka.streams.processor
-
- MockProcessorContext.CapturedPunctuator - Class in org.apache.kafka.streams.processor
-
- MockProducer<K,V> - Class in org.apache.kafka.clients.producer
-
A mock of the producer interface you can use for testing code that uses Kafka.
- MockProducer(Cluster, boolean, Partitioner, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.MockProducer
-
Create a mock producer
- MockProducer(boolean, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.MockProducer
-
Create a new mock producer with invented metadata the given autoComplete setting and key\value serializers.
- MockProducer(boolean, Partitioner, Serializer<K>, Serializer<V>) - Constructor for class org.apache.kafka.clients.producer.MockProducer
-
Create a new mock producer with invented metadata the given autoComplete setting, partitioner and key\value serializers.
- MockProducer() - Constructor for class org.apache.kafka.clients.producer.MockProducer
-
Create a new mock producer with invented metadata.
- name() - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
-
Returns the name of this configuration.
- name() - Method in class org.apache.kafka.clients.admin.ConfigEntry
-
Return the config name.
- name() - Method in class org.apache.kafka.clients.admin.NewTopic
-
The name of the topic to be created.
- name() - Method in class org.apache.kafka.clients.admin.TopicDescription
-
The name of the topic.
- name() - Method in class org.apache.kafka.clients.admin.TopicListing
-
The name of the topic.
- name() - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
-
Unique name for this assignor (e.g.
- name() - Method in class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
-
- name() - Method in class org.apache.kafka.clients.consumer.RangeAssignor
-
- name() - Method in class org.apache.kafka.clients.consumer.RoundRobinAssignor
-
- name() - Method in class org.apache.kafka.clients.consumer.StickyAssignor
-
- name - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- name() - Method in class org.apache.kafka.common.config.ConfigResource
-
Return the resource name.
- name() - Method in class org.apache.kafka.common.config.ConfigValue
-
- name() - Method in class org.apache.kafka.common.MetricName
-
- name() - Method in class org.apache.kafka.common.MetricNameTemplate
-
Get the name of the metric.
- name() - Method in class org.apache.kafka.common.resource.Resource
-
Return the resource name.
- name() - Method in class org.apache.kafka.common.resource.ResourceFilter
-
Return the resource name or null.
- name() - Method in class org.apache.kafka.common.resource.ResourcePattern
-
- name() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
-
- name - Variable in enum org.apache.kafka.common.security.auth.SecurityProtocol
-
Name of the security protocol.
- name() - Method in class org.apache.kafka.connect.data.ConnectSchema
-
- name() - Method in class org.apache.kafka.connect.data.Field
-
Get the name of this field.
- name() - Method in interface org.apache.kafka.connect.data.Schema
-
- name() - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
- name(String) - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Set the name of this schema.
- name() - Method in class org.apache.kafka.connect.health.ConnectorHealth
-
Provides the name of the connector.
- name() - Method in interface org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntity
-
Returns the name of this entity.
- name - Variable in enum org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
-
an english description of the api--this is for debugging and can change
- name - Variable in enum org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
-
an english description of the api--this is for debugging and can change
- name - Variable in class org.apache.kafka.streams.kstream.Grouped
-
- name - Variable in class org.apache.kafka.streams.kstream.Joined
-
- name() - Method in class org.apache.kafka.streams.kstream.Joined
-
- name - Variable in class org.apache.kafka.streams.kstream.Named
-
- name - Variable in class org.apache.kafka.streams.kstream.StreamJoined
-
- name() - Method in interface org.apache.kafka.streams.processor.StateStore
-
The name of this store.
- name() - Method in interface org.apache.kafka.streams.state.StoreBuilder
-
Return the name of this state store builder.
- name() - Method in interface org.apache.kafka.streams.state.StoreSupplier
-
Return the name of this state store supplier.
- name() - Method in interface org.apache.kafka.streams.TopologyDescription.Node
-
The name of the node.
- named(String) - Static method in class org.apache.kafka.streams.kstream.Joined
-
- Named - Class in org.apache.kafka.streams.kstream
-
- Named(Named) - Constructor for class org.apache.kafka.streams.kstream.Named
-
- Named(String) - Constructor for class org.apache.kafka.streams.kstream.Named
-
- names() - Method in class org.apache.kafka.clients.admin.ListTopicsResult
-
Return a future which yields a collection of topic names.
- names() - Method in class org.apache.kafka.common.config.ConfigDef
-
Returns unmodifiable set of properties names defined in this
ConfigDef
- names() - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
-
- namesToListings() - Method in class org.apache.kafka.clients.admin.ListTopicsResult
-
Return a future which yields a map of topic names to TopicListing objects.
- NETWORK_THREAD_PREFIX - Static variable in class org.apache.kafka.clients.producer.KafkaProducer
-
- NetworkException - Exception in org.apache.kafka.common.errors
-
A misc.
- NetworkException() - Constructor for exception org.apache.kafka.common.errors.NetworkException
-
- NetworkException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NetworkException
-
- NetworkException(String) - Constructor for exception org.apache.kafka.common.errors.NetworkException
-
- NetworkException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NetworkException
-
- newConfigDef() - Static method in class org.apache.kafka.connect.storage.ConverterConfig
-
Create a new
ConfigDef
instance containing the configurations defined by ConverterConfig.
- NewPartitionReassignment - Class in org.apache.kafka.clients.admin
-
- NewPartitionReassignment(List<Integer>) - Constructor for class org.apache.kafka.clients.admin.NewPartitionReassignment
-
- NewPartitions - Class in org.apache.kafka.clients.admin
-
- newRecord(String, Integer, Schema, Object, Schema, Object, Long) - Method in class org.apache.kafka.connect.connector.ConnectRecord
-
Create a new record of the same type as itself, with the specified parameter values.
- newRecord(String, Integer, Schema, Object, Schema, Object, Long, Iterable<Header>) - Method in class org.apache.kafka.connect.connector.ConnectRecord
-
Create a new record of the same type as itself, with the specified parameter values.
- newRecord(String, Integer, Schema, Object, Schema, Object, Long) - Method in class org.apache.kafka.connect.sink.SinkRecord
-
- newRecord(String, Integer, Schema, Object, Schema, Object, Long, Iterable<Header>) - Method in class org.apache.kafka.connect.sink.SinkRecord
-
- newRecord(String, Integer, Schema, Object, Schema, Object, Long) - Method in class org.apache.kafka.connect.source.SourceRecord
-
- newRecord(String, Integer, Schema, Object, Schema, Object, Long, Iterable<Header>) - Method in class org.apache.kafka.connect.source.SourceRecord
-
- NewTopic - Class in org.apache.kafka.clients.admin
-
- NewTopic(String, int, short) - Constructor for class org.apache.kafka.clients.admin.NewTopic
-
A new topic with the specified replication factor and number of partitions.
- NewTopic(String, Optional<Integer>, Optional<Short>) - Constructor for class org.apache.kafka.clients.admin.NewTopic
-
A new topic that optionally defaults numPartitions
and replicationFactor
to
the broker configurations for num.partitions
and default.replication.factor
respectively.
- NewTopic(String, Map<Integer, List<Integer>>) - Constructor for class org.apache.kafka.clients.admin.NewTopic
-
A new topic with the specified replica assignment configuration.
- next() - Method in class org.apache.kafka.connect.data.Values.Parser
-
- next(int) - Method in class org.apache.kafka.connect.data.Values.Parser
-
- NO_DEFAULT_VALUE - Static variable in class org.apache.kafka.common.config.ConfigDef
-
A unique Java object which represents the lack of a default value.
- NO_OPTIMIZATION - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter (@link #TOPOLOGY_OPTIMIZATION "topology.optimization" for disabling topology optimization
- NO_SASL_EXTENSIONS - Static variable in class org.apache.kafka.common.security.auth.SaslExtensions
-
An "empty" instance indicating no SASL extensions
- NO_TIMESTAMP - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecord
-
- Node - Class in org.apache.kafka.common
-
Information about a Kafka node
- Node(int, String, int) - Constructor for class org.apache.kafka.common.Node
-
- Node(int, String, int, String) - Constructor for class org.apache.kafka.common.Node
-
- nodeById(int) - Method in class org.apache.kafka.common.Cluster
-
Get the node by the node id (or null if no such node exists)
- nodeIfOnline(TopicPartition, int) - Method in class org.apache.kafka.common.Cluster
-
Get the node by node id if the replica for the given partition is online
- nodes() - Method in class org.apache.kafka.clients.admin.DescribeClusterResult
-
Returns a future which yields a collection of nodes.
- nodes() - Method in class org.apache.kafka.common.Cluster
-
- nodes() - Method in interface org.apache.kafka.streams.TopologyDescription.Subtopology
-
All nodes of this sub-topology.
- NON_RECONFIGURABLE_CONFIGS - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- NonEmptyString() - Constructor for class org.apache.kafka.common.config.ConfigDef.NonEmptyString
-
- NonEmptyStringWithoutControlChars() - Constructor for class org.apache.kafka.common.config.ConfigDef.NonEmptyStringWithoutControlChars
-
- nonEmptyStringWithoutControlChars() - Static method in class org.apache.kafka.common.config.ConfigDef.NonEmptyStringWithoutControlChars
-
- NonNullValidator() - Constructor for class org.apache.kafka.common.config.ConfigDef.NonNullValidator
-
- noNode() - Static method in class org.apache.kafka.common.Node
-
- NoOffsetForPartitionException - Exception in org.apache.kafka.clients.consumer
-
Indicates that there is no stored offset for a partition and no defined offset
reset policy.
- NoOffsetForPartitionException(TopicPartition) - Constructor for exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
-
- NoOffsetForPartitionException(Collection<TopicPartition>) - Constructor for exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
-
- NoReassignmentInProgressException - Exception in org.apache.kafka.common.errors
-
Thrown if a reassignment cannot be cancelled because none is in progress.
- NoReassignmentInProgressException(String) - Constructor for exception org.apache.kafka.common.errors.NoReassignmentInProgressException
-
- NoReassignmentInProgressException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NoReassignmentInProgressException
-
- NOT_AVAILABLE - Static variable in class org.apache.kafka.streams.state.StreamsMetadata
-
Sentinel to indicate that the StreamsMetadata is currently unavailable.
- NotControllerException - Exception in org.apache.kafka.common.errors
-
- NotControllerException(String) - Constructor for exception org.apache.kafka.common.errors.NotControllerException
-
- NotControllerException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotControllerException
-
- NotCoordinatorException - Exception in org.apache.kafka.common.errors
-
In the context of the group coordinator, the broker returns this error code if it receives an offset fetch
or commit request for a group it's not the coordinator of.
- NotCoordinatorException(String) - Constructor for exception org.apache.kafka.common.errors.NotCoordinatorException
-
- NotCoordinatorException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotCoordinatorException
-
- NotEnoughReplicasAfterAppendException - Exception in org.apache.kafka.common.errors
-
Number of insync replicas for the partition is lower than min.insync.replicas This exception is raised when the low
ISR size is discovered *after* the message was already appended to the log.
- NotEnoughReplicasAfterAppendException(String) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasAfterAppendException
-
- NotEnoughReplicasException - Exception in org.apache.kafka.common.errors
-
Number of insync replicas for the partition is lower than min.insync.replicas
- NotEnoughReplicasException() - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
-
- NotEnoughReplicasException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
-
- NotEnoughReplicasException(String) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
-
- NotEnoughReplicasException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
-
- NotFoundException - Exception in org.apache.kafka.connect.errors
-
Indicates that an operation attempted to modify or delete a connector or task that is not present on the worker.
- NotFoundException(String) - Constructor for exception org.apache.kafka.connect.errors.NotFoundException
-
- NotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.NotFoundException
-
- NotFoundException(Throwable) - Constructor for exception org.apache.kafka.connect.errors.NotFoundException
-
- NotLeaderForPartitionException - Exception in org.apache.kafka.common.errors
-
This server is not the leader for the given partition
- NotLeaderForPartitionException() - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
-
- NotLeaderForPartitionException(String) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
-
- NotLeaderForPartitionException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
-
- NotLeaderForPartitionException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
-
- NULL - Static variable in class org.apache.kafka.connect.data.SchemaAndValue
-
- NULL_CHECKSUM - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecord
-
- NULL_SIZE - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecord
-
- NUM_STANDBY_REPLICAS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
num.standby.replicas
- NUM_STREAM_THREADS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
num.stream.threads
- numPartitions(String) - Method in class org.apache.kafka.clients.admin.CreateTopicsResult
-
Returns a future that provides number of partitions in the topic when the request completes.
- numPartitions() - Method in class org.apache.kafka.clients.admin.NewTopic
-
The number of partitions for the new topic or -1 if a replica assignment has been specified.
- numPartitions() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
-
Return the number of partitions to create or null if replicaAssignments is not null.
- OAUTHBEARER_MECHANISM - Static variable in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
-
The SASL Mechanism name for OAuth 2: OAUTHBEARER
- OAuthBearerExtensionsValidatorCallback - Class in org.apache.kafka.common.security.oauthbearer
-
A
Callback
for use by the
SaslServer
implementation when it
needs to validate the SASL extensions for the OAUTHBEARER mechanism
Callback handlers should use the
OAuthBearerExtensionsValidatorCallback.valid(String)
method to communicate valid extensions back to the SASL server.
- OAuthBearerExtensionsValidatorCallback(OAuthBearerToken, SaslExtensions) - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
-
- OAuthBearerLoginModule - Class in org.apache.kafka.common.security.oauthbearer
-
The LoginModule
for the SASL/OAUTHBEARER mechanism.
- OAuthBearerLoginModule() - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
-
- OAuthBearerToken - Interface in org.apache.kafka.common.security.oauthbearer
-
The
b64token
value as defined in
RFC 6750 Section
2.1 along with the token's specific scope and lifetime and principal
name.
- OAuthBearerTokenCallback - Class in org.apache.kafka.common.security.oauthbearer
-
A Callback
for use by the SaslClient
and Login
implementations when they require an OAuth 2 bearer token.
- OAuthBearerTokenCallback() - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback
-
- OAuthBearerValidatorCallback - Class in org.apache.kafka.common.security.oauthbearer
-
A Callback
for use by the SaslServer
implementation when it
needs to provide an OAuth 2 bearer token compact serialization for
validation.
- OAuthBearerValidatorCallback(String) - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
-
Constructor
- of(ConfigDef.Validator...) - Static method in class org.apache.kafka.common.config.ConfigDef.CompositeValidator
-
- of(long) - Static method in class org.apache.kafka.streams.kstream.JoinWindows
-
- of(Duration) - Static method in class org.apache.kafka.streams.kstream.JoinWindows
-
Specifies that records of the same key are joinable if their timestamps are within timeDifference
,
i.e., the timestamp of a record from the secondary stream is max timeDifference
earlier or later than
the timestamp of the record from the primary stream.
- of(long) - Static method in class org.apache.kafka.streams.kstream.TimeWindows
-
- of(Duration) - Static method in class org.apache.kafka.streams.kstream.TimeWindows
-
Return a window definition with the given window size, and with the advance interval being equal to the window
size.
- of() - Static method in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
Return an unlimited window starting at timestamp zero.
- offlineReplicas() - Method in class org.apache.kafka.common.PartitionInfo
-
The subset of the replicas that are offline
- offset() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The position of this record in the corresponding Kafka partition.
- offset() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
-
- offset() - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
-
- offset() - Method in class org.apache.kafka.clients.producer.RecordMetadata
-
The offset of the record in the topic/partition.
- offset(Map<TopicPartition, Long>) - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Reset the consumer offsets for the given topic partitions.
- offset(TopicPartition, long) - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Reset the consumer offsets for the given topic partition.
- offset(Map<String, T>) - Method in interface org.apache.kafka.connect.storage.OffsetStorageReader
-
Get the offset for the specified partition.
- offset() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- offset() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Returns the offset of the current input record; could be -1 if it is not
available (for example, if this method is invoked from the punctuate call)
- offset() - Method in interface org.apache.kafka.streams.processor.RecordContext
-
- OffsetAndMetadata - Class in org.apache.kafka.clients.consumer
-
The Kafka offset commit API allows users to provide additional metadata (in the form of a string)
when an offset is committed.
- OffsetAndMetadata(long, Optional<Integer>, String) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndMetadata
-
Construct a new OffsetAndMetadata object for committing through
KafkaConsumer
.
- OffsetAndMetadata(long, String) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndMetadata
-
Construct a new OffsetAndMetadata object for committing through
KafkaConsumer
.
- OffsetAndMetadata(long) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndMetadata
-
Construct a new OffsetAndMetadata object for committing through
KafkaConsumer
.
- offsetAndMetadata() - Method in class org.apache.kafka.connect.mirror.Checkpoint
-
- OffsetAndTimestamp - Class in org.apache.kafka.clients.consumer
-
A container class for offset and timestamp.
- OffsetAndTimestamp(long, long) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndTimestamp
-
- OffsetAndTimestamp(long, long, Optional<Integer>) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndTimestamp
-
- OffsetCommitCallback - Interface in org.apache.kafka.clients.consumer
-
A callback interface that the user can implement to trigger custom actions when a commit request completes.
- OffsetMetadataTooLarge - Exception in org.apache.kafka.common.errors
-
The client has tried to save its offset with associated metadata larger than the maximum size allowed by the server.
- OffsetMetadataTooLarge() - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
-
- OffsetMetadataTooLarge(String) - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
-
- OffsetMetadataTooLarge(Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
-
- OffsetMetadataTooLarge(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
-
- OffsetNotAvailableException - Exception in org.apache.kafka.common.errors
-
Indicates that the leader is not able to guarantee monotonically increasing offsets
due to the high watermark lagging behind the epoch start offset after a recent leader election
- OffsetNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.OffsetNotAvailableException
-
- OffsetOutOfRangeException - Exception in org.apache.kafka.clients.consumer
-
No reset policy has been defined, and the offsets for these partitions are either larger or smaller
than the range of offsets the server has for the given partition.
- OffsetOutOfRangeException(Map<TopicPartition, Long>) - Constructor for exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
-
- OffsetOutOfRangeException - Exception in org.apache.kafka.common.errors
-
No reset policy has been defined, and the offsets for these partitions are either larger or smaller
than the range of offsets the server has for the given partition.
- OffsetOutOfRangeException(String) - Constructor for exception org.apache.kafka.common.errors.OffsetOutOfRangeException
-
- OffsetOutOfRangeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetOutOfRangeException
-
- offsetOutOfRangePartitions() - Method in exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
-
- OffsetResetStrategy - Enum in org.apache.kafka.clients.consumer
-
- offsets(Collection<Map<String, T>>) - Method in interface org.apache.kafka.connect.storage.OffsetStorageReader
-
Get a set of offsets for the specified partition identifiers.
- offsetsForTimes(Map<TopicPartition, Long>) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- offsetsForTimes(Map<TopicPartition, Long>, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- offsetsForTimes(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Look up the offsets for the given partitions by timestamp.
- offsetsForTimes(Map<TopicPartition, Long>, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Look up the offsets for the given partitions by timestamp.
- offsetsForTimes(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- offsetsForTimes(Map<TopicPartition, Long>, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- offsetStorageReader() - Method in interface org.apache.kafka.connect.source.SourceTaskContext
-
Get the OffsetStorageReader for this SourceTask.
- OffsetStorageReader - Interface in org.apache.kafka.connect.storage
-
OffsetStorageReader provides access to the offset storage used by sources.
- onAcknowledgement(RecordMetadata, Exception) - Method in interface org.apache.kafka.clients.producer.ProducerInterceptor
-
This method is called when the record sent to the server has been acknowledged, or when sending the record fails before
it gets sent to the server.
- onAssignment(ConsumerPartitionAssignor.Assignment, ConsumerGroupMetadata) - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
-
Callback which is invoked when a group member receives its assignment from the leader.
- onAssignment(ConsumerPartitionAssignor.Assignment, ConsumerGroupMetadata) - Method in class org.apache.kafka.clients.consumer.StickyAssignor
-
- onBatchRestored(TopicPartition, String, long, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingBatchingRestoreCallback
-
- onBatchRestored(TopicPartition, String, long, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingRestoreCallback
-
- onBatchRestored(TopicPartition, String, long, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
-
Method called after restoring a batch of records.
- onChange(String, ConfigData) - Method in interface org.apache.kafka.common.config.ConfigChangeCallback
-
Performs an action when configuration data changes.
- onChange(KafkaStreams.State, KafkaStreams.State) - Method in interface org.apache.kafka.streams.KafkaStreams.StateListener
-
Called when state changes.
- onCommit(Map<TopicPartition, OffsetAndMetadata>) - Method in interface org.apache.kafka.clients.consumer.ConsumerInterceptor
-
This is called when offsets get committed.
- onComplete(Map<TopicPartition, OffsetAndMetadata>, Exception) - Method in interface org.apache.kafka.clients.consumer.OffsetCommitCallback
-
A callback method the user can implement to provide asynchronous handling of commit request completion.
- onCompletion(RecordMetadata, Exception) - Method in interface org.apache.kafka.clients.producer.Callback
-
A callback method the user can implement to provide asynchronous handling of request completion.
- onConsume(ConsumerRecords<K, V>) - Method in interface org.apache.kafka.clients.consumer.ConsumerInterceptor
-
- onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.FailOnInvalidTimestamp
-
Raises an exception on every call.
- onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.LogAndSkipOnInvalidTimestamp
-
Writes a log WARN message when the extracted timestamp is invalid (negative) but returns the invalid timestamp as-is,
which ultimately causes the record to be skipped and not to be processed.
- onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestamp
-
Returns the current stream-time as new timestamp for the record.
- onNewBatch(String, Cluster, int) - Method in interface org.apache.kafka.clients.producer.Partitioner
-
Notifies the partitioner a new batch is about to be created.
- onNewBatch(String, Cluster, int) - Method in class org.apache.kafka.clients.producer.UniformStickyPartitioner
-
If a batch completed for the current sticky partition, change the sticky partition.
- onPartitionsAssigned(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.ConsumerRebalanceListener
-
A callback method the user can implement to provide handling of customized offsets on completion of a successful
partition re-assignment.
- onPartitionsAssigned(Collection<TopicPartition>) - Method in class org.apache.kafka.connect.sink.SinkTask
-
- onPartitionsLost(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.ConsumerRebalanceListener
-
A callback method you can implement to provide handling of cleaning up resources for partitions that have already
been reassigned to other consumers.
- onPartitionsRevoked(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.ConsumerRebalanceListener
-
A callback method the user can implement to provide handling of offset commits to a customized store.
- onPartitionsRevoked(Collection<TopicPartition>) - Method in class org.apache.kafka.connect.sink.SinkTask
-
- onRestoreEnd(TopicPartition, String, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingBatchingRestoreCallback
-
- onRestoreEnd(TopicPartition, String, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingRestoreCallback
-
- onRestoreEnd(TopicPartition, String, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
-
Method called when restoring the
StateStore
is complete.
- onRestoreStart(TopicPartition, String, long, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingBatchingRestoreCallback
-
- onRestoreStart(TopicPartition, String, long, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingRestoreCallback
-
- onRestoreStart(TopicPartition, String, long, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
-
Method called at the very beginning of
StateStore
restoration.
- onSend(ProducerRecord<K, V>) - Method in interface org.apache.kafka.clients.producer.ProducerInterceptor
-
- onUpdate(ClusterResource) - Method in interface org.apache.kafka.common.ClusterResourceListener
-
A callback method that a user can implement to get updates for
ClusterResource
.
- open(Collection<TopicPartition>) - Method in class org.apache.kafka.connect.sink.SinkTask
-
The SinkTask use this method to create writers for newly assigned partitions in case of partition
rebalance.
- operation() - Method in class org.apache.kafka.common.acl.AccessControlEntry
-
Return the AclOperation.
- operation() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
-
Return the AclOperation.
- operation() - Method in class org.apache.kafka.server.authorizer.Action
-
Operation being performed.
- OperationNotAttemptedException - Exception in org.apache.kafka.common.errors
-
Indicates that the broker did not attempt to execute this operation.
- OperationNotAttemptedException(String) - Constructor for exception org.apache.kafka.common.errors.OperationNotAttemptedException
-
- OPTIMIZE - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Config value for parameter (@link #TOPOLOGY_OPTIMIZATION "topology.optimization" for enabling topology optimization
- optional() - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Set this schema as optional.
- OPTIONAL_BOOLEAN_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
-
- OPTIONAL_BYTES_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
-
- OPTIONAL_FLOAT32_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
-
- OPTIONAL_FLOAT64_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
-
- OPTIONAL_INT16_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
-
- OPTIONAL_INT32_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
-
- OPTIONAL_INT64_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
-
- OPTIONAL_INT8_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
-
- OPTIONAL_STRING_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
-
- opType() - Method in class org.apache.kafka.clients.admin.AlterConfigOp
-
- orderInGroup - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- org.apache.kafka.clients.admin - package org.apache.kafka.clients.admin
-
- org.apache.kafka.clients.consumer - package org.apache.kafka.clients.consumer
-
- org.apache.kafka.clients.producer - package org.apache.kafka.clients.producer
-
- org.apache.kafka.common - package org.apache.kafka.common
-
- org.apache.kafka.common.acl - package org.apache.kafka.common.acl
-
- org.apache.kafka.common.annotation - package org.apache.kafka.common.annotation
-
- org.apache.kafka.common.config - package org.apache.kafka.common.config
-
- org.apache.kafka.common.config.provider - package org.apache.kafka.common.config.provider
-
- org.apache.kafka.common.errors - package org.apache.kafka.common.errors
-
- org.apache.kafka.common.header - package org.apache.kafka.common.header
-
- org.apache.kafka.common.resource - package org.apache.kafka.common.resource
-
- org.apache.kafka.common.security.auth - package org.apache.kafka.common.security.auth
-
- org.apache.kafka.common.security.oauthbearer - package org.apache.kafka.common.security.oauthbearer
-
- org.apache.kafka.common.security.plain - package org.apache.kafka.common.security.plain
-
- org.apache.kafka.common.security.scram - package org.apache.kafka.common.security.scram
-
- org.apache.kafka.common.security.token.delegation - package org.apache.kafka.common.security.token.delegation
-
- org.apache.kafka.common.serialization - package org.apache.kafka.common.serialization
-
- org.apache.kafka.connect.components - package org.apache.kafka.connect.components
-
- org.apache.kafka.connect.connector - package org.apache.kafka.connect.connector
-
- org.apache.kafka.connect.connector.policy - package org.apache.kafka.connect.connector.policy
-
- org.apache.kafka.connect.data - package org.apache.kafka.connect.data
-
- org.apache.kafka.connect.errors - package org.apache.kafka.connect.errors
-
- org.apache.kafka.connect.header - package org.apache.kafka.connect.header
-
- org.apache.kafka.connect.health - package org.apache.kafka.connect.health
-
- org.apache.kafka.connect.mirror - package org.apache.kafka.connect.mirror
-
- org.apache.kafka.connect.rest - package org.apache.kafka.connect.rest
-
- org.apache.kafka.connect.sink - package org.apache.kafka.connect.sink
-
- org.apache.kafka.connect.source - package org.apache.kafka.connect.source
-
- org.apache.kafka.connect.storage - package org.apache.kafka.connect.storage
-
- org.apache.kafka.connect.transforms - package org.apache.kafka.connect.transforms
-
- org.apache.kafka.connect.util - package org.apache.kafka.connect.util
-
- org.apache.kafka.server.authorizer - package org.apache.kafka.server.authorizer
-
- org.apache.kafka.server.policy - package org.apache.kafka.server.policy
-
- org.apache.kafka.server.quota - package org.apache.kafka.server.quota
-
- org.apache.kafka.streams - package org.apache.kafka.streams
-
- org.apache.kafka.streams.errors - package org.apache.kafka.streams.errors
-
- org.apache.kafka.streams.kstream - package org.apache.kafka.streams.kstream
-
- org.apache.kafka.streams.processor - package org.apache.kafka.streams.processor
-
- org.apache.kafka.streams.state - package org.apache.kafka.streams.state
-
- org.apache.kafka.streams.test - package org.apache.kafka.streams.test
-
- original() - Method in class org.apache.kafka.connect.data.Values.Parser
-
- originals() - Method in class org.apache.kafka.common.config.AbstractConfig
-
- originalsStrings() - Method in class org.apache.kafka.common.config.AbstractConfig
-
Get all the original settings, ensuring that all values are of type String.
- originalsWithPrefix(String) - Method in class org.apache.kafka.common.config.AbstractConfig
-
Gets all original settings with the given prefix, stripping the prefix before adding it to the output.
- originalsWithPrefix(String, boolean) - Method in class org.apache.kafka.common.config.AbstractConfig
-
Gets all original settings with the given prefix.
- originalTopic(String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
-
The name of the original source-topic, which may have been replicated multiple hops.
- otherStoreSupplier - Variable in class org.apache.kafka.streams.kstream.StreamJoined
-
- otherValueSerde - Variable in class org.apache.kafka.streams.kstream.Joined
-
- otherValueSerde(Serde<VO>) - Static method in class org.apache.kafka.streams.kstream.Joined
-
Create an instance of
Joined
with an other value
Serde
.
- otherValueSerde() - Method in class org.apache.kafka.streams.kstream.Joined
-
- otherValueSerde - Variable in class org.apache.kafka.streams.kstream.StreamJoined
-
- outerJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Join records of this stream with another KStream
's records using windowed outer equi join with default
serializers and deserializers.
- outerJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, Joined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
- outerJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
- outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this KTable
(left input) with another KTable
's (right input) records using
non-windowed outer equi join, with default serializers, deserializers, and state store.
- outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Join records of this KTable
(left input) with another KTable
's (right input) records using
non-windowed outer equi join, with default serializers, deserializers, and state store.
- outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- OutOfOrderSequenceException - Exception in org.apache.kafka.common.errors
-
This exception indicates that the broker received an unexpected sequence number from the producer,
which means that data may have been lost.
- OutOfOrderSequenceException(String) - Constructor for exception org.apache.kafka.common.errors.OutOfOrderSequenceException
-
- outputStream - Variable in class org.apache.kafka.streams.kstream.Printed
-
- OutputVerifier - Class in org.apache.kafka.streams.test
-
- OutputVerifier() - Constructor for class org.apache.kafka.streams.test.OutputVerifier
-
Deprecated.
- overlap(Window) - Method in class org.apache.kafka.streams.kstream.Window
-
Check if the given window overlaps with this window.
- ownedPartitions() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
-
- owner() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- ownerAsString() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- ownerOrRenewer(KafkaPrincipal) - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- owners(List<KafkaPrincipal>) - Method in class org.apache.kafka.clients.admin.DescribeDelegationTokenOptions
-
if owners is null, all the user owned tokens and tokens where user have Describe permission
will be returned.
- owners() - Method in class org.apache.kafka.clients.admin.DescribeDelegationTokenOptions
-
- pair(K, V) - Static method in class org.apache.kafka.streams.KeyValue
-
Create a new key-value pair.
- parameter(String, String) - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Set a schema parameter.
- parameters() - Method in class org.apache.kafka.connect.data.ConnectSchema
-
- parameters() - Method in interface org.apache.kafka.connect.data.Schema
-
Get a map of schema parameters.
- parameters() - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
- parameters(Map<String, String>) - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Set schema parameters.
- parse(Map<?, ?>) - Method in class org.apache.kafka.common.config.ConfigDef
-
Parse and validate configs against this configuration definition.
- parse(String) - Static method in enum org.apache.kafka.common.ConsumerGroupState
-
Parse a string into a consumer group state.
- parse(Values.Parser, boolean) - Static method in class org.apache.kafka.connect.data.Values
-
- parse(String) - Static method in class org.apache.kafka.streams.processor.TaskId
-
- Parser(String) - Constructor for class org.apache.kafka.connect.data.Values.Parser
-
- parseString(String) - Static method in class org.apache.kafka.connect.data.Values
-
Parse the specified string representation of a value into its schema and value.
- parseType(String, Object, ConfigDef.Type) - Static method in class org.apache.kafka.common.config.ConfigDef
-
Parse a value according to its expected type.
- partition() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The partition from which this record is received
- partition() - Method in exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
-
- partition(String, Object, byte[], Object, byte[], Cluster) - Method in interface org.apache.kafka.clients.producer.Partitioner
-
Compute the partition for the given record.
- partition() - Method in class org.apache.kafka.clients.producer.ProducerRecord
-
- partition() - Method in class org.apache.kafka.clients.producer.RecordMetadata
-
The partition the record was sent to
- partition(String, Object, byte[], Object, byte[], Cluster) - Method in class org.apache.kafka.clients.producer.RoundRobinPartitioner
-
Compute the partition for the given record.
- partition(String, Object, byte[], Object, byte[], Cluster) - Method in class org.apache.kafka.clients.producer.UniformStickyPartitioner
-
Compute the partition for the given record.
- partition(TopicPartition) - Method in class org.apache.kafka.common.Cluster
-
Get the metadata for the specified partition
- partition() - Method in class org.apache.kafka.common.PartitionInfo
-
The partition id
- partition() - Method in class org.apache.kafka.common.TopicPartition
-
- partition() - Method in class org.apache.kafka.common.TopicPartitionInfo
-
Return the partition id.
- partition() - Method in class org.apache.kafka.common.TopicPartitionReplica
-
- partition() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- partition() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Returns the partition id of the current input record; could be -1 if it is not
available (for example, if this method is invoked from the punctuate call)
- partition() - Method in interface org.apache.kafka.streams.processor.RecordContext
-
- partition(String, K, V, int) - Method in interface org.apache.kafka.streams.processor.StreamPartitioner
-
Determine the partition number for a record with the given key and value and the current number of partitions.
- partition - Variable in class org.apache.kafka.streams.processor.TaskId
-
The ID of the partition.
- PARTITION_ASSIGNMENT_STRATEGY_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
partition.assignment.strategy
- PARTITION_GROUPER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Deprecated.
- PARTITION_KEY - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
-
- partitionAssignor() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
-
The consumer group partition assignor.
- partitionCountForTopic(String) - Method in class org.apache.kafka.common.Cluster
-
Get the number of partitions for the given topic.
- Partitioner - Interface in org.apache.kafka.clients.producer
-
Partitioner Interface
- partitioner - Variable in class org.apache.kafka.streams.kstream.Produced
-
- PARTITIONER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
partitioner.class
- PartitionGrouper - Interface in org.apache.kafka.streams.processor
-
- partitionGroups(Map<Integer, Set<String>>, Cluster) - Method in class org.apache.kafka.streams.processor.DefaultPartitionGrouper
-
Deprecated.
Generate tasks with the assigned topic partitions.
- partitionGroups(Map<Integer, Set<String>>, Cluster) - Method in interface org.apache.kafka.streams.processor.PartitionGrouper
-
Deprecated.
Returns a map of task ids to groups of partitions.
- PartitionInfo - Class in org.apache.kafka.common
-
This is used to describe per-partition state in the MetadataResponse.
- PartitionInfo(String, int, Node, Node[], Node[]) - Constructor for class org.apache.kafka.common.PartitionInfo
-
- PartitionInfo(String, int, Node, Node[], Node[], Node[]) - Constructor for class org.apache.kafka.common.PartitionInfo
-
- PartitionReassignment - Class in org.apache.kafka.clients.admin
-
- PartitionReassignment(List<Integer>, List<Integer>, List<Integer>) - Constructor for class org.apache.kafka.clients.admin.PartitionReassignment
-
- partitionResult(TopicPartition) - Method in class org.apache.kafka.clients.admin.DeleteConsumerGroupOffsetsResult
-
Return a future which can be used to check the result for a given partition.
- partitionResult(TopicPartition) - Method in class org.apache.kafka.clients.admin.ElectPreferredLeadersResult
-
Deprecated.
Get the result of the election for the given partition
.
- partitions() - Method in class org.apache.kafka.clients.admin.ElectLeadersResult
-
Get a future for the topic partitions for which a leader election was attempted.
- partitions() - Method in class org.apache.kafka.clients.admin.ElectPreferredLeadersResult
-
Deprecated.
Get a future for the topic partitions for which a leader election
was attempted.
- partitions() - Method in class org.apache.kafka.clients.admin.TopicDescription
-
A list of partitions where the index represents the partition id and the element contains leadership and replica
information for that partition.
- partitions() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Assignment
-
- partitions() - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
-
Get the partitions which have records contained in this record set.
- partitions() - Method in exception org.apache.kafka.clients.consumer.InvalidOffsetException
-
- partitions() - Method in exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
-
returns all partitions for which no offests are defined.
- partitions() - Method in exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
-
- partitionsFor(String) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- partitionsFor(String, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- partitionsFor(String) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Get metadata about the partitions for a given topic.
- partitionsFor(String, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Get metadata about the partitions for a given topic.
- partitionsFor(String) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- partitionsFor(String, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- partitionsFor(String) - Method in class org.apache.kafka.clients.producer.KafkaProducer
-
Get the partition metadata for the given topic.
- partitionsFor(String) - Method in class org.apache.kafka.clients.producer.MockProducer
-
- partitionsFor(String) - Method in interface org.apache.kafka.clients.producer.Producer
-
- partitionsForNode(int) - Method in class org.apache.kafka.common.Cluster
-
Get the list of partitions whose leader is this node
- partitionsForTopic(String) - Method in class org.apache.kafka.common.Cluster
-
Get the list of partitions for this topic
- partitionsToOffsetAndMetadata() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsResult
-
Return a future which yields a map of topic partitions to OffsetAndMetadata objects.
- password() - Method in class org.apache.kafka.common.security.plain.PlainAuthenticateCallback
-
Returns the password provided by the client during SASL/PLAIN authentication
- pattern() - Method in class org.apache.kafka.common.acl.AclBinding
-
- patternFilter() - Method in class org.apache.kafka.common.acl.AclBindingFilter
-
- PatternType - Enum in org.apache.kafka.common.resource
-
Resource pattern type.
- patternType() - Method in class org.apache.kafka.common.resource.ResourcePattern
-
- patternType() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
-
- pause(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- pause(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Suspend fetching from the requested partitions.
- pause(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- pause(TopicPartition...) - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Pause consumption of messages from the specified TopicPartitions.
- paused() - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- paused() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
- paused() - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- peek(ForeachAction<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Perform an action on each record of KStream
.
- peek(ForeachAction<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Perform an action on each record of KStream
.
- peekNextKey() - Method in interface org.apache.kafka.streams.state.KeyValueIterator
-
Peek at the next key without advancing the iterator
- permissionType() - Method in class org.apache.kafka.common.acl.AccessControlEntry
-
Return the AclPermissionType.
- permissionType() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
-
Return the AclPermissionType.
- persistent() - Method in interface org.apache.kafka.streams.processor.StateStore
-
Return if the storage is persistent or not.
- persistentKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
-
- persistentSessionStore(String, long) - Static method in class org.apache.kafka.streams.state.Stores
-
- persistentSessionStore(String, Duration) - Static method in class org.apache.kafka.streams.state.Stores
-
- persistentTimestampedKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
-
- persistentTimestampedWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
-
- persistentWindowStore(String, long, int, long, boolean) - Static method in class org.apache.kafka.streams.state.Stores
-
- persistentWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
-
- pipeInput(TestRecord<K, V>) - Method in class org.apache.kafka.streams.TestInputTopic
-
Send an input record with the given record on the topic and then commit the records.
- pipeInput(V) - Method in class org.apache.kafka.streams.TestInputTopic
-
Send an input record with the given value on the topic and then commit the records.
- pipeInput(K, V) - Method in class org.apache.kafka.streams.TestInputTopic
-
Send an input record with the given key and value on the topic and then commit the records.
- pipeInput(V, Instant) - Method in class org.apache.kafka.streams.TestInputTopic
-
Send an input record with the given value and timestamp on the topic and then commit the records.
- pipeInput(K, V, long) - Method in class org.apache.kafka.streams.TestInputTopic
-
Send an input record with the given key, value and timestamp on the topic and then commit the records.
- pipeInput(K, V, Instant) - Method in class org.apache.kafka.streams.TestInputTopic
-
Send an input record with the given key, value and timestamp on the topic and then commit the records.
- pipeInput(ConsumerRecord<byte[], byte[]>) - Method in class org.apache.kafka.streams.TopologyTestDriver
-
- pipeInput(List<ConsumerRecord<byte[], byte[]>>) - Method in class org.apache.kafka.streams.TopologyTestDriver
-
- pipeKeyValueList(List<KeyValue<K, V>>) - Method in class org.apache.kafka.streams.TestInputTopic
-
Send input records with the given KeyValue list on the topic then commit each record individually.
- pipeKeyValueList(List<KeyValue<K, V>>, Instant, Duration) - Method in class org.apache.kafka.streams.TestInputTopic
-
Send input records with the given
KeyValue
list on the topic then commit each record individually.
- pipeRecordList(List<? extends TestRecord<K, V>>) - Method in class org.apache.kafka.streams.TestInputTopic
-
Send input records with the given KeyValue list on the topic then commit each record individually.
- pipeValueList(List<V>) - Method in class org.apache.kafka.streams.TestInputTopic
-
Send input records with the given value list on the topic then commit each record individually.
- pipeValueList(List<V>, Instant, Duration) - Method in class org.apache.kafka.streams.TestInputTopic
-
Send input records with the given value list on the topic then commit each record individually.
- PlainAuthenticateCallback - Class in org.apache.kafka.common.security.plain
-
- PlainAuthenticateCallback(char[]) - Constructor for class org.apache.kafka.common.security.plain.PlainAuthenticateCallback
-
Creates a callback with the password provided by the client
- PlainLoginModule - Class in org.apache.kafka.common.security.plain
-
- PlainLoginModule() - Constructor for class org.apache.kafka.common.security.plain.PlainLoginModule
-
- PlaintextAuthenticationContext - Class in org.apache.kafka.common.security.auth
-
- PlaintextAuthenticationContext(InetAddress, String) - Constructor for class org.apache.kafka.common.security.auth.PlaintextAuthenticationContext
-
- PolicyViolationException - Exception in org.apache.kafka.common.errors
-
Exception thrown if a create topics request does not satisfy the configured policy for a topic.
- PolicyViolationException(String) - Constructor for exception org.apache.kafka.common.errors.PolicyViolationException
-
- PolicyViolationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.PolicyViolationException
-
- poll(long) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
Deprecated.
- poll(Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- poll(long) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
- poll(Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Fetch data for the topics or partitions specified using one of the subscribe/assign APIs.
- poll(long) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
Deprecated.
- poll(Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- poll() - Method in class org.apache.kafka.connect.source.SourceTask
-
Poll this source task for new records.
- POLL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
poll.ms
- port() - Method in class org.apache.kafka.common.Endpoint
-
Returns the port to which the listener is bound.
- port() - Method in class org.apache.kafka.common.Node
-
The port for this node
- port() - Method in class org.apache.kafka.streams.state.HostInfo
-
- port() - Method in class org.apache.kafka.streams.state.StreamsMetadata
-
- position(TopicPartition) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- position(TopicPartition, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- position(TopicPartition) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Get the offset of the next record that will be fetched (if a record with that offset exists).
- position(TopicPartition, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Get the offset of the next record that will be fetched (if a record with that offset exists).
- position(TopicPartition) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- position(TopicPartition, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- position() - Method in class org.apache.kafka.connect.data.Values.Parser
-
- postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.clients.admin.AdminClientConfig
-
- postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.clients.producer.ProducerConfig
-
- postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.common.config.AbstractConfig
-
Called directly after user configs got parsed (and thus default values got set).
- postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.streams.StreamsConfig
-
- PREALLOCATE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- PREALLOCATE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- preCommit(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.apache.kafka.connect.sink.SinkTask
-
Pre-commit hook invoked prior to an offset commit.
- predecessors() - Method in interface org.apache.kafka.streams.TopologyDescription.Node
-
The predecessors of this node within a sub-topology.
- Predicate<K,V> - Interface in org.apache.kafka.streams.kstream
-
The
Predicate
interface represents a predicate (boolean-valued function) of a
KeyValue
pair.
- PreferredLeaderNotAvailableException - Exception in org.apache.kafka.common.errors
-
- PreferredLeaderNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.PreferredLeaderNotAvailableException
-
- PreferredLeaderNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.PreferredLeaderNotAvailableException
-
- previous() - Method in class org.apache.kafka.connect.data.Values.Parser
-
- principal() - Method in class org.apache.kafka.common.acl.AccessControlEntry
-
Return the principal for this entry.
- principal() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
-
Return the principal or null.
- principal() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
-
Returns authenticated principal for the connection on which request was received.
- PRINCIPAL_BUILDER_CLASS_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- PRINCIPAL_BUILDER_CLASS_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- PrincipalBuilder - Interface in org.apache.kafka.common.security.auth
-
- principalName() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
-
The name of the principal to which this credential applies
- print(Printed<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Print the records of this KStream using the options provided by
Printed
Note that this is mainly for debugging/testing purposes, and it will try to flush on each record print.
- Printed<K,V> - Class in org.apache.kafka.streams.kstream
-
An object to define the options used when printing a
KStream
.
- Printed(Printed<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Printed
-
Copy constructor.
- process(ProcessorSupplier<? super K, ? super V>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
- process(ProcessorSupplier<? super K, ? super V>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
- process(K, V) - Method in interface org.apache.kafka.streams.processor.Processor
-
Process the record with the given key and value.
- PROCESSING_GUARANTEE_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
processing.guarantee
- Processor<K,V> - Interface in org.apache.kafka.streams.processor
-
A processor of key-value pair records.
- processor() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
-
The processor node maintaining the global store.
- ProcessorContext - Interface in org.apache.kafka.streams.processor
-
Processor context interface.
- processorName - Variable in class org.apache.kafka.streams.kstream.Consumed
-
- processorName - Variable in class org.apache.kafka.streams.kstream.Printed
-
- processorName - Variable in class org.apache.kafka.streams.kstream.Produced
-
- ProcessorStateException - Exception in org.apache.kafka.streams.errors
-
Indicates a processor state operation (e.g.
- ProcessorStateException(String) - Constructor for exception org.apache.kafka.streams.errors.ProcessorStateException
-
- ProcessorStateException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.ProcessorStateException
-
- ProcessorStateException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.ProcessorStateException
-
- ProcessorSupplier<K,V> - Interface in org.apache.kafka.streams.processor
-
A processor supplier that can create one or more
Processor
instances.
- Produced<K,V> - Class in org.apache.kafka.streams.kstream
-
- Produced(Produced<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Produced
-
- Producer<K,V> - Interface in org.apache.kafka.clients.producer
-
- PRODUCER_CLIENT_PREFIX - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
-
- PRODUCER_METRIC_GROUP_NAME - Static variable in class org.apache.kafka.clients.producer.KafkaProducer
-
- PRODUCER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to isolate
producer
configs from other client configs.
- producerClientIds() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
- ProducerConfig - Class in org.apache.kafka.clients.producer
-
Configuration for the Kafka Producer.
- ProducerConfig(Properties) - Constructor for class org.apache.kafka.clients.producer.ProducerConfig
-
- ProducerConfig(Map<String, Object>) - Constructor for class org.apache.kafka.clients.producer.ProducerConfig
-
- producerConfig() - Method in class org.apache.kafka.connect.mirror.MirrorClientConfig
-
Sub-config for Producer clients.
- ProducerFencedException - Exception in org.apache.kafka.common.errors
-
This fatal exception indicates that another producer with the same transactional.id
has been
started.
- ProducerFencedException(String) - Constructor for exception org.apache.kafka.common.errors.ProducerFencedException
-
- ProducerInterceptor<K,V> - Interface in org.apache.kafka.clients.producer
-
A plugin interface that allows you to intercept (and possibly mutate) the records received by the producer before
they are published to the Kafka cluster.
- producerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
- ProducerRecord<K,V> - Class in org.apache.kafka.clients.producer
-
A key/value pair to be sent to Kafka.
- ProducerRecord(String, Integer, Long, K, V, Iterable<Header>) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
-
Creates a record with a specified timestamp to be sent to a specified topic and partition
- ProducerRecord(String, Integer, Long, K, V) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
-
Creates a record with a specified timestamp to be sent to a specified topic and partition
- ProducerRecord(String, Integer, K, V, Iterable<Header>) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
-
Creates a record to be sent to a specified topic and partition
- ProducerRecord(String, Integer, K, V) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
-
Creates a record to be sent to a specified topic and partition
- ProducerRecord(String, K, V) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
-
Create a record to be sent to Kafka
- ProducerRecord(String, V) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
-
Create a record with no key
- ProductionExceptionHandler - Interface in org.apache.kafka.streams.errors
-
Interface that specifies how an exception when attempting to produce a result to
Kafka should be handled.
- ProductionExceptionHandler.ProductionExceptionHandlerResponse - Enum in org.apache.kafka.streams.errors
-
- project(Schema, Object, Schema) - Static method in class org.apache.kafka.connect.data.SchemaProjector
-
This method project a value between compatible schemas and throw exceptions when non compatible schemas are provided
- punctuate(long) - Method in interface org.apache.kafka.streams.processor.Punctuator
-
Perform the scheduled periodic operation.
- PunctuationType - Enum in org.apache.kafka.streams.processor
-
- Punctuator - Interface in org.apache.kafka.streams.processor
-
- put(String, Object) - Method in class org.apache.kafka.connect.data.Struct
-
Set the value of a field.
- put(Field, Object) - Method in class org.apache.kafka.connect.data.Struct
-
Set the value of a field.
- put(Collection<SinkRecord>) - Method in class org.apache.kafka.connect.sink.SinkTask
-
Put the records in the sink.
- put(K, V) - Method in interface org.apache.kafka.streams.state.KeyValueStore
-
Update the value associated with this key.
- put(Windowed<K>, AGG) - Method in interface org.apache.kafka.streams.state.SessionStore
-
Write the aggregated value for the provided key to the store
- put(K, V) - Method in interface org.apache.kafka.streams.state.WindowStore
-
- put(K, V, long) - Method in interface org.apache.kafka.streams.state.WindowStore
-
Put a key-value pair into the window with given window start timestamp
- putAll(List<KeyValue<K, V>>) - Method in interface org.apache.kafka.streams.state.KeyValueStore
-
Update all the given key/value pairs.
- putIfAbsent(K, V) - Method in interface org.apache.kafka.streams.state.KeyValueStore
-
Update the value associated with this key, unless a value is already associated with the key.
- rack() - Method in class org.apache.kafka.common.Node
-
The rack for this node
- raiseError(Exception) - Method in interface org.apache.kafka.connect.connector.ConnectorContext
-
Raise an unrecoverable exception to the Connect framework.
- range(K, K) - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
-
Get an iterator over a given range of keys.
- RangeAssignor - Class in org.apache.kafka.clients.consumer
-
The range assignor works on a per-topic basis.
- RangeAssignor() - Constructor for class org.apache.kafka.clients.consumer.RangeAssignor
-
- rawKey(K) - Method in class org.apache.kafka.streams.state.StateSerdes
-
Serialize the given key.
- rawValue(V) - Method in class org.apache.kafka.streams.state.StateSerdes
-
Serialize the given value.
- reader(String) - Method in class org.apache.kafka.common.config.provider.FileConfigProvider
-
- readFrom(DataInputStream) - Static method in class org.apache.kafka.streams.processor.TaskId
-
- readFrom(ByteBuffer) - Static method in class org.apache.kafka.streams.processor.TaskId
-
- readKeyValue() - Method in class org.apache.kafka.streams.TestOutputTopic
-
Read one record from the output topic and return its key and value as pair.
- readKeyValuesToList() - Method in class org.apache.kafka.streams.TestOutputTopic
-
Read all KeyValues from topic to List.
- readKeyValuesToMap() - Method in class org.apache.kafka.streams.TestOutputTopic
-
Read output to map.
- ReadOnlyKeyValueStore<K,V> - Interface in org.apache.kafka.streams.state
-
A key-value store that only supports read operations.
- ReadOnlySessionStore<K,AGG> - Interface in org.apache.kafka.streams.state
-
A session store that only supports read operations.
- ReadOnlyWindowStore<K,V> - Interface in org.apache.kafka.streams.state
-
A window store that only supports read operations.
- readOutput(String) - Method in class org.apache.kafka.streams.TopologyTestDriver
-
- readOutput(String, Deserializer<K>, Deserializer<V>) - Method in class org.apache.kafka.streams.TopologyTestDriver
-
- readRecord() - Method in class org.apache.kafka.streams.TestOutputTopic
-
Read one Record from output topic.
- readRecordsToList() - Method in class org.apache.kafka.streams.TestOutputTopic
-
Read output to List.
- readValue() - Method in class org.apache.kafka.streams.TestOutputTopic
-
Read one record from the output topic and return record's value.
- readValuesToList() - Method in class org.apache.kafka.streams.TestOutputTopic
-
Read all values from topic to List.
- ReassignmentInProgressException - Exception in org.apache.kafka.common.errors
-
Thrown if a request cannot be completed because a partition reassignment is in progress.
- ReassignmentInProgressException(String) - Constructor for exception org.apache.kafka.common.errors.ReassignmentInProgressException
-
- ReassignmentInProgressException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ReassignmentInProgressException
-
- reassignments() - Method in class org.apache.kafka.clients.admin.ListPartitionReassignmentsResult
-
Return a future which yields a map containing each partition's reassignments
- rebalance(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
Simulate a rebalance event.
- RebalanceInProgressException - Exception in org.apache.kafka.common.errors
-
- RebalanceInProgressException() - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
-
- RebalanceInProgressException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
-
- RebalanceInProgressException(String) - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
-
- RebalanceInProgressException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
-
- RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
- RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
receive.buffer.bytes
- RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
receive.buffer.bytes
- RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
receive.buffer.bytes
- recommendedValues() - Method in class org.apache.kafka.common.config.ConfigValue
-
- recommendedValues(List<Object>) - Method in class org.apache.kafka.common.config.ConfigValue
-
- recommender - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- Reconfigurable - Interface in org.apache.kafka.common
-
Interface for reconfigurable classes that support dynamic configuration.
- RECONFIGURABLE_CONFIGS - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- reconfigurableConfigs() - Method in interface org.apache.kafka.common.Reconfigurable
-
Returns the names of configs that may be reconfigured.
- reconfigure(Map<String, ?>) - Method in interface org.apache.kafka.common.Reconfigurable
-
Reconfigures this instance with the given key-value pairs.
- reconfigure(Map<String, String>) - Method in class org.apache.kafka.connect.connector.Connector
-
Reconfigure this Connector.
- RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
reconnect.backoff.max.ms
- RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
reconnect.backoff.max.ms
- RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
reconnect.backoff.max.ms
- RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
reconnect.backoff.max
- RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
reconnect.backoff.ms
- RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
reconnect.backoff.ms
- RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
reconnect.backoff.ms
- RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
reconnect.backoff.ms
- RecordBatchTooLargeException - Exception in org.apache.kafka.common.errors
-
This record batch is larger than the maximum allowable size
- RecordBatchTooLargeException() - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
-
- RecordBatchTooLargeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
-
- RecordBatchTooLargeException(String) - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
-
- RecordBatchTooLargeException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
-
- recordCollector() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- RecordContext - Interface in org.apache.kafka.streams.processor
-
The context associated with the current record being processed by
an
Processor
- recordLatency(Sensor, long, long) - Method in interface org.apache.kafka.streams.StreamsMetrics
-
Record the given latency value of the sensor.
- RecordMetadata - Class in org.apache.kafka.clients.producer
-
The metadata for a record that has been acknowledged by the server
- RecordMetadata(TopicPartition, long, long, long, Long, int, int) - Constructor for class org.apache.kafka.clients.producer.RecordMetadata
-
- records(TopicPartition) - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
-
Get just the records for the given partition
- records(String) - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
-
Get just the records for the given topic
- RecordsToDelete - Class in org.apache.kafka.clients.admin
-
- recordThroughput(Sensor, long) - Method in interface org.apache.kafka.streams.StreamsMetrics
-
Record the throughput value of a sensor.
- RecordTooLargeException - Exception in org.apache.kafka.common.errors
-
This record is larger than the maximum allowable size
- RecordTooLargeException() - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
-
- RecordTooLargeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
-
- RecordTooLargeException(String) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
-
- RecordTooLargeException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
-
- RecordTooLargeException(String, Map<TopicPartition, Long>) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
-
- recordTooLargePartitions() - Method in exception org.apache.kafka.common.errors.RecordTooLargeException
-
- reduce(Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Combine the values of records in this stream by the grouped key.
- reduce(Reducer<V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Combine the value of records in this stream by the grouped key.
- reduce(Reducer<V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
Combine the value of records in this stream by the grouped key.
- reduce(Reducer<V>, Reducer<V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Combine the value of records of the original
KTable
that got
mapped
to the same key into a new instance of
KTable
.
- reduce(Reducer<V>, Reducer<V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Combine the value of records of the original
KTable
that got
mapped
to the same key into a new instance of
KTable
.
- reduce(Reducer<V>, Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
-
Combine the value of records of the original
KTable
that got
mapped
to the same key into a new instance of
KTable
.
- reduce(Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
- reduce(Reducer<V>, Named) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
- reduce(Reducer<V>, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
- reduce(Reducer<V>, Named, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
-
- reduce(Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Combine the values of records in this stream by the grouped key.
- reduce(Reducer<V>, Named) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Combine the values of records in this stream by the grouped key.
- reduce(Reducer<V>, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Combine the values of records in this stream by the grouped key.
- reduce(Reducer<V>, Named, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
-
Combine the values of records in this stream by the grouped key.
- Reducer<V> - Interface in org.apache.kafka.streams.kstream
-
The Reducer
interface for combining two values of the same type into a new value.
- register(ConnectRestExtensionContext) - Method in interface org.apache.kafka.connect.rest.ConnectRestExtension
-
- register(StateStore, StateRestoreCallback) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- register(StateStore, StateRestoreCallback) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Registers and possibly restores the specified storage engine.
- RemoteClusterUtils - Class in org.apache.kafka.connect.mirror
-
Convenience methods for multi-cluster environments.
- remoteConsumerOffsets(String, String, Duration) - Method in class org.apache.kafka.connect.mirror.MirrorClient
-
Translate a remote consumer group's offsets into corresponding local offsets.
- remoteTopics() - Method in class org.apache.kafka.connect.mirror.MirrorClient
-
Find all remote topics on this cluster.
- remoteTopics(String) - Method in class org.apache.kafka.connect.mirror.MirrorClient
-
Find all remote topics that have been replicated directly from the given source cluster.
- remove(String) - Method in interface org.apache.kafka.common.header.Headers
-
Removes all headers for the given key returning if the operation succeeded.
- remove(String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- remove(String) - Method in interface org.apache.kafka.connect.header.Headers
-
Removes all
Header
objects whose
key
matches the specified key.
- remove(Windowed<K>) - Method in interface org.apache.kafka.streams.state.SessionStore
-
Remove the session aggregated with provided
Windowed
key from the store
- removeMembersFromConsumerGroup(String, RemoveMembersFromConsumerGroupOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Remove members from the consumer group by given member identities.
- removeMembersFromConsumerGroup(String, RemoveMembersFromConsumerGroupOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- RemoveMembersFromConsumerGroupOptions - Class in org.apache.kafka.clients.admin
-
- RemoveMembersFromConsumerGroupOptions(Collection<MemberToRemove>) - Constructor for class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupOptions
-
- RemoveMembersFromConsumerGroupResult - Class in org.apache.kafka.clients.admin
-
- removeQuota(ClientQuotaType, ClientQuotaEntity) - Method in interface org.apache.kafka.server.quota.ClientQuotaCallback
-
Quota configuration removal callback that is invoked when quota configuration for an entity is
removed in ZooKeeper.
- removeSensor(Sensor) - Method in interface org.apache.kafka.streams.StreamsMetrics
-
Remove a sensor.
- removingReplicas() - Method in class org.apache.kafka.clients.admin.PartitionReassignment
-
The brokers that we are removing this partition from as part of a reassignment.
- rename(String) - Method in interface org.apache.kafka.connect.header.Header
-
Return a new
Header
object that has the same schema and value but with the supplied key.
- renewDelegationToken(byte[]) - Method in interface org.apache.kafka.clients.admin.Admin
-
Renew a Delegation Token.
- renewDelegationToken(byte[], RenewDelegationTokenOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Renew a Delegation Token.
- renewDelegationToken(byte[], RenewDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- RenewDelegationTokenOptions - Class in org.apache.kafka.clients.admin
-
- RenewDelegationTokenOptions() - Constructor for class org.apache.kafka.clients.admin.RenewDelegationTokenOptions
-
- RenewDelegationTokenResult - Class in org.apache.kafka.clients.admin
-
- renewers(List<KafkaPrincipal>) - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
-
- renewers() - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
-
- renewers() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- renewersAsString() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- renewTimePeriodMs(long) - Method in class org.apache.kafka.clients.admin.RenewDelegationTokenOptions
-
- renewTimePeriodMs() - Method in class org.apache.kafka.clients.admin.RenewDelegationTokenOptions
-
- ReplicaNotAvailableException - Exception in org.apache.kafka.common.errors
-
- ReplicaNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.ReplicaNotAvailableException
-
- ReplicaNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ReplicaNotAvailableException
-
- ReplicaNotAvailableException(Throwable) - Constructor for exception org.apache.kafka.common.errors.ReplicaNotAvailableException
-
- replicas() - Method in class org.apache.kafka.clients.admin.PartitionReassignment
-
The brokers which this partition currently resides on.
- replicas() - Method in class org.apache.kafka.common.PartitionInfo
-
The complete set of replicas for this partition regardless of whether they are alive or up-to-date
- replicas() - Method in class org.apache.kafka.common.TopicPartitionInfo
-
Return the replicas of the partition in the same order as the replica assignment.
- replicasAssignments() - Method in class org.apache.kafka.clients.admin.NewTopic
-
A map from partition id to replica ids (i.e.
- replicasAssignments() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
-
Return a map from partition id to replica (broker) ids or null if numPartitions and replicationFactor are
set instead.
- REPLICATION_FACTOR_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
replication.factor
- REPLICATION_POLICY_CLASS - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
-
- REPLICATION_POLICY_CLASS_DEFAULT - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
-
- REPLICATION_POLICY_SEPARATOR - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
-
- REPLICATION_POLICY_SEPARATOR_DEFAULT - Static variable in class org.apache.kafka.connect.mirror.MirrorClientConfig
-
- replicationFactor(String) - Method in class org.apache.kafka.clients.admin.CreateTopicsResult
-
Returns a future that provides replication factor for the topic when the request completes.
- replicationFactor() - Method in class org.apache.kafka.clients.admin.NewTopic
-
The replication factor for the new topic or -1 if a replica assignment has been specified.
- replicationFactor() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
-
Return the number of replicas to create or null if replicaAssignments is not null.
- replicationHops(String) - Method in class org.apache.kafka.connect.mirror.MirrorClient
-
Compute shortest number of hops from an upstream source cluster.
- replicationHops(Map<String, Object>, String) - Static method in class org.apache.kafka.connect.mirror.RemoteClusterUtils
-
Find shortest number of hops from an upstream cluster.
- replicationPolicy() - Method in class org.apache.kafka.connect.mirror.MirrorClient
-
Get the ReplicationPolicy instance used to interpret remote topics.
- replicationPolicy() - Method in class org.apache.kafka.connect.mirror.MirrorClientConfig
-
- ReplicationPolicy - Interface in org.apache.kafka.connect.mirror
-
Defines which topics are "remote topics".
- REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
request.timeout.ms
- REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
request.timeout.ms
- REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
request.timeout.ms
- REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
request.timeout.ms
- requestCommit() - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Request an offset commit.
- RequestMetadata(ConfigResource, Map<String, String>) - Constructor for class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
-
Create an instance of this class with the provided parameters.
- RequestMetadata(String, Integer, Short, Map<Integer, List<Integer>>, Map<String, String>) - Constructor for class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
-
Create an instance of this class with the provided parameters.
- requestTaskReconfiguration() - Method in interface org.apache.kafka.connect.connector.ConnectorContext
-
Requests that the runtime reconfigure the Tasks for this source.
- requestType() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
-
16-bit API key of the request from the request header.
- requestVersion() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
-
Returns the request version from the request header.
- required() - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Set this schema as required.
- resetCommit() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
Reset the commit capture to false
(whether or not it was previously true
).
- resetForwards() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
Clear the captured forwarded data.
- resetPolicy - Variable in class org.apache.kafka.streams.kstream.Consumed
-
- Resource - Class in org.apache.kafka.common.resource
-
Represents a cluster resource with a tuple of (type, name).
- Resource(ResourceType, String) - Constructor for class org.apache.kafka.common.resource.Resource
-
Create an instance of this class with the provided parameters.
- resource() - Method in class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
-
- ResourceFilter - Class in org.apache.kafka.common.resource
-
A filter which matches Resource objects.
- ResourceFilter(ResourceType, String) - Constructor for class org.apache.kafka.common.resource.ResourceFilter
-
Create an instance of this class with the provided parameters.
- ResourcePattern - Class in org.apache.kafka.common.resource
-
Represents a pattern that is used by ACLs to match zero or more
Resources
.
- ResourcePattern(ResourceType, String, PatternType) - Constructor for class org.apache.kafka.common.resource.ResourcePattern
-
Create a pattern using the supplied parameters.
- resourcePattern() - Method in class org.apache.kafka.server.authorizer.Action
-
Resource on which action is being performed.
- ResourcePatternFilter - Class in org.apache.kafka.common.resource
-
- ResourcePatternFilter(ResourceType, String, PatternType) - Constructor for class org.apache.kafka.common.resource.ResourcePatternFilter
-
Create a filter using the supplied parameters.
- resourceReferenceCount() - Method in class org.apache.kafka.server.authorizer.Action
-
Number of times the resource being authorized is referenced within the request.
- resourceType() - Method in class org.apache.kafka.common.resource.Resource
-
Return the resource type.
- resourceType() - Method in class org.apache.kafka.common.resource.ResourceFilter
-
Return the resource type.
- resourceType() - Method in class org.apache.kafka.common.resource.ResourcePattern
-
- resourceType() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
-
- ResourceType - Enum in org.apache.kafka.common.resource
-
Represents a type of resource which an ACL can be applied to.
- restore(byte[], byte[]) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingBatchingRestoreCallback
-
- restore(byte[], byte[]) - Method in interface org.apache.kafka.streams.processor.StateRestoreCallback
-
- RESTORE_CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to override
consumer
configs for the restore consumer client from
the general consumer client configs.
- restoreAll(Collection<KeyValue<byte[], byte[]>>) - Method in interface org.apache.kafka.streams.processor.BatchingStateRestoreCallback
-
Called to restore a number of records.
- restoreConsumerClientId() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
- restoreConsumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
- resume(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- resume(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
- resume(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- resume(TopicPartition...) - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Resume consumption of messages from previously paused TopicPartitions.
- retainDuplicates() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
-
Whether or not this store is retaining duplicate keys.
- retainLatest() - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- retainLatest(String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- retainLatest(String) - Method in interface org.apache.kafka.connect.header.Headers
-
Removes all but the latest
Header
objects whose
key
matches the specified key.
- retainLatest() - Method in interface org.apache.kafka.connect.header.Headers
-
Removes all but the last
Header
object with each key.
- retention - Variable in class org.apache.kafka.streams.kstream.Materialized
-
- RETENTION_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- RETENTION_BYTES_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- RETENTION_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- RETENTION_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- retentionPeriod() - Method in interface org.apache.kafka.streams.state.SessionBytesStoreSupplier
-
The time period for which the
SessionStore
will retain historic data.
- retentionPeriod() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
-
The time period for which the
WindowStore
will retain historic data.
- RetriableCommitFailedException - Exception in org.apache.kafka.clients.consumer
-
- RetriableCommitFailedException(Throwable) - Constructor for exception org.apache.kafka.clients.consumer.RetriableCommitFailedException
-
- RetriableCommitFailedException(String) - Constructor for exception org.apache.kafka.clients.consumer.RetriableCommitFailedException
-
- RetriableCommitFailedException(String, Throwable) - Constructor for exception org.apache.kafka.clients.consumer.RetriableCommitFailedException
-
- RetriableException - Exception in org.apache.kafka.common.errors
-
A retryable exception is a transient exception that if retried may succeed.
- RetriableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RetriableException
-
- RetriableException(String) - Constructor for exception org.apache.kafka.common.errors.RetriableException
-
- RetriableException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RetriableException
-
- RetriableException() - Constructor for exception org.apache.kafka.common.errors.RetriableException
-
- RetriableException - Exception in org.apache.kafka.connect.errors
-
An exception that indicates the operation can be reattempted.
- RetriableException(String) - Constructor for exception org.apache.kafka.connect.errors.RetriableException
-
- RetriableException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.RetriableException
-
- RetriableException(Throwable) - Constructor for exception org.apache.kafka.connect.errors.RetriableException
-
- RETRIES_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
- RETRIES_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
retries
- RETRIES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
retries
- RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
retry.backoff.ms
- RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
retry.backoff.ms
- RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
retry.backoff.ms
- RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
retry.backoff.ms
- rewindTo(int) - Method in class org.apache.kafka.connect.data.Values.Parser
-
- ROCKSDB_CONFIG_SETTER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
rocksdb.config.setter
- RocksDBConfigSetter - Interface in org.apache.kafka.streams.state
-
An interface to that allows developers to customize the RocksDB settings for a given Store.
- RoundRobinAssignor - Class in org.apache.kafka.clients.consumer
-
The round robin assignor lays out all the available partitions and all the available consumers.
- RoundRobinAssignor() - Constructor for class org.apache.kafka.clients.consumer.RoundRobinAssignor
-
- RoundRobinPartitioner - Class in org.apache.kafka.clients.producer
-
The "Round-Robin" partitioner
This partitioning strategy can be used when user wants
to distribute the writes to all partitions equally.
- RoundRobinPartitioner() - Constructor for class org.apache.kafka.clients.producer.RoundRobinPartitioner
-
- salt() - Method in class org.apache.kafka.common.security.scram.ScramCredential
-
Returns the salt used to process this credential using the SCRAM algorithm.
- SASL_CLIENT_CALLBACK_HANDLER_CLASS - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_CLIENT_CALLBACK_HANDLER_CLASS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_ENABLED_MECHANISMS - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_ENABLED_MECHANISMS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_JAAS_CONFIG - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_JAAS_CONFIG_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_KINIT_CMD - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_KINIT_CMD_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_MIN_TIME_BEFORE_RELOGIN - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_MIN_TIME_BEFORE_RELOGIN_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_PRINCIPAL_TO_LOCAL_RULES - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_PRINCIPAL_TO_LOCAL_RULES_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_SERVICE_NAME - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_SERVICE_NAME_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_TICKET_RENEW_JITTER - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_TICKET_RENEW_JITTER_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_TICKET_RENEW_WINDOW_FACTOR - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_TICKET_RENEW_WINDOW_FACTOR_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_CALLBACK_HANDLER_CLASS - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_CALLBACK_HANDLER_CLASS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_CLASS - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_CLASS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_REFRESH_BUFFER_SECONDS - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_REFRESH_BUFFER_SECONDS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_REFRESH_MIN_PERIOD_SECONDS - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_REFRESH_MIN_PERIOD_SECONDS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_REFRESH_WINDOW_FACTOR - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_REFRESH_WINDOW_FACTOR_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_REFRESH_WINDOW_JITTER - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_REFRESH_WINDOW_JITTER_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_MECHANISM - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
SASL mechanism configuration - standard mechanism names are listed
here.
- SASL_MECHANISM_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SaslAuthenticationContext - Class in org.apache.kafka.common.security.auth
-
- SaslAuthenticationContext(SaslServer, SecurityProtocol, InetAddress, String) - Constructor for class org.apache.kafka.common.security.auth.SaslAuthenticationContext
-
- SaslAuthenticationException - Exception in org.apache.kafka.common.errors
-
This exception indicates that SASL authentication has failed.
- SaslAuthenticationException(String) - Constructor for exception org.apache.kafka.common.errors.SaslAuthenticationException
-
- SaslAuthenticationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SaslAuthenticationException
-
- SaslConfigs - Class in org.apache.kafka.common.config
-
- SaslConfigs() - Constructor for class org.apache.kafka.common.config.SaslConfigs
-
- SaslExtensions - Class in org.apache.kafka.common.security.auth
-
A simple immutable value object class holding customizable SASL extensions
- SaslExtensions(Map<String, String>) - Constructor for class org.apache.kafka.common.security.auth.SaslExtensions
-
- SaslExtensionsCallback - Class in org.apache.kafka.common.security.auth
-
Optional callback used for SASL mechanisms if any extensions need to be set
in the SASL exchange.
- SaslExtensionsCallback() - Constructor for class org.apache.kafka.common.security.auth.SaslExtensionsCallback
-
- SCALE_FIELD - Static variable in class org.apache.kafka.connect.data.Decimal
-
- schedule(long, PunctuationType, Punctuator) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
Deprecated.
- schedule(Duration, PunctuationType, Punctuator) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- schedule(long, PunctuationType, Punctuator) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
- schedule(Duration, PunctuationType, Punctuator) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Schedules a periodic operation for processors.
- scheduledPunctuators() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
Get the punctuators scheduled so far.
- scheduleNopPollTask() - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- schedulePollTask(Runnable) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
Schedule a task to be executed during a poll().
- schema() - Method in class org.apache.kafka.connect.data.ConnectSchema
-
- SCHEMA - Static variable in class org.apache.kafka.connect.data.Date
-
- schema(int) - Static method in class org.apache.kafka.connect.data.Decimal
-
- schema() - Method in class org.apache.kafka.connect.data.Field
-
Get the schema of this field
- Schema - Interface in org.apache.kafka.connect.data
-
Definition of an abstract data type.
- schema() - Method in interface org.apache.kafka.connect.data.Schema
-
Return a concrete instance of the
Schema
- schema() - Method in class org.apache.kafka.connect.data.SchemaAndValue
-
- schema() - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Return a concrete instance of the
Schema
specified by this builder
- schema() - Method in class org.apache.kafka.connect.data.Struct
-
Get the schema for this Struct.
- SCHEMA - Static variable in class org.apache.kafka.connect.data.Time
-
- SCHEMA - Static variable in class org.apache.kafka.connect.data.Timestamp
-
- schema() - Method in class org.apache.kafka.connect.data.Values.SchemaDetector
-
- schema() - Method in interface org.apache.kafka.connect.header.Header
-
Return the
Schema
associated with this header, if there is one.
- Schema.Type - Enum in org.apache.kafka.connect.data
-
The type of a schema.
- SchemaAndValue - Class in org.apache.kafka.connect.data
-
- SchemaAndValue(Schema, Object) - Constructor for class org.apache.kafka.connect.data.SchemaAndValue
-
- SchemaBuilder - Class in org.apache.kafka.connect.data
-
SchemaBuilder provides a fluent API for constructing
Schema
objects.
- SchemaBuilder(Schema.Type) - Constructor for class org.apache.kafka.connect.data.SchemaBuilder
-
- SchemaBuilderException - Exception in org.apache.kafka.connect.errors
-
- SchemaBuilderException(String) - Constructor for exception org.apache.kafka.connect.errors.SchemaBuilderException
-
- SchemaBuilderException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.SchemaBuilderException
-
- SchemaBuilderException(Throwable) - Constructor for exception org.apache.kafka.connect.errors.SchemaBuilderException
-
- SchemaDetector() - Constructor for class org.apache.kafka.connect.data.Values.SchemaDetector
-
- SchemaProjector - Class in org.apache.kafka.connect.data
-
SchemaProjector is utility to project a value between compatible schemas and throw exceptions
when non compatible schemas are provided.
- SchemaProjector() - Constructor for class org.apache.kafka.connect.data.SchemaProjector
-
- SchemaProjectorException - Exception in org.apache.kafka.connect.errors
-
- SchemaProjectorException(String) - Constructor for exception org.apache.kafka.connect.errors.SchemaProjectorException
-
- SchemaProjectorException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.SchemaProjectorException
-
- SchemaProjectorException(Throwable) - Constructor for exception org.apache.kafka.connect.errors.SchemaProjectorException
-
- schemaType(Class<?>) - Static method in class org.apache.kafka.connect.data.ConnectSchema
-
- scope() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
-
- ScramCredential - Class in org.apache.kafka.common.security.scram
-
SCRAM credential class that encapsulates the credential data persisted for each user that is
accessible to the server.
- ScramCredential(byte[], byte[], byte[], int) - Constructor for class org.apache.kafka.common.security.scram.ScramCredential
-
Constructs a new credential.
- scramCredential(ScramCredential) - Method in class org.apache.kafka.common.security.scram.ScramCredentialCallback
-
Sets the SCRAM credential for this instance.
- scramCredential() - Method in class org.apache.kafka.common.security.scram.ScramCredentialCallback
-
Returns the SCRAM credential if set on this instance.
- ScramCredentialCallback - Class in org.apache.kafka.common.security.scram
-
Callback used for SCRAM mechanisms.
- ScramCredentialCallback() - Constructor for class org.apache.kafka.common.security.scram.ScramCredentialCallback
-
- ScramExtensionsCallback - Class in org.apache.kafka.common.security.scram
-
Optional callback used for SCRAM mechanisms if any extensions need to be set
in the SASL/SCRAM exchange.
- ScramExtensionsCallback() - Constructor for class org.apache.kafka.common.security.scram.ScramExtensionsCallback
-
- ScramLoginModule - Class in org.apache.kafka.common.security.scram
-
- ScramLoginModule() - Constructor for class org.apache.kafka.common.security.scram.ScramLoginModule
-
- SECURITY_PROTOCOL_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
- SECURITY_PROTOCOL_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
security.protocol
- SECURITY_PROVIDERS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
security.providers
- SECURITY_PROVIDERS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
security.providers
- SECURITY_PROVIDERS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
security.providers
- SECURITY_PROVIDERS_CONFIG - Static variable in class org.apache.kafka.common.config.SecurityConfig
-
- SECURITY_PROVIDERS_DOC - Static variable in class org.apache.kafka.common.config.SecurityConfig
-
- SecurityConfig - Class in org.apache.kafka.common.config
-
Contains the common security config for SSL and SASL
- SecurityConfig() - Constructor for class org.apache.kafka.common.config.SecurityConfig
-
- SecurityDisabledException - Exception in org.apache.kafka.common.errors
-
An error indicating that security is disabled on the broker.
- SecurityDisabledException(String) - Constructor for exception org.apache.kafka.common.errors.SecurityDisabledException
-
- SecurityDisabledException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SecurityDisabledException
-
- securityProtocol() - Method in class org.apache.kafka.common.Endpoint
-
Returns the security protocol of this endpoint.
- securityProtocol() - Method in interface org.apache.kafka.common.security.auth.AuthenticationContext
-
Underlying security protocol of the authentication session.
- securityProtocol() - Method in class org.apache.kafka.common.security.auth.PlaintextAuthenticationContext
-
- securityProtocol() - Method in class org.apache.kafka.common.security.auth.SaslAuthenticationContext
-
- SecurityProtocol - Enum in org.apache.kafka.common.security.auth
-
- securityProtocol() - Method in class org.apache.kafka.common.security.auth.SslAuthenticationContext
-
- securityProtocol() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
-
Returns the security protocol for the listener on which request was received.
- SecurityProviderCreator - Interface in org.apache.kafka.common.security.auth
-
An interface for generating security providers.
- seek(TopicPartition, long) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- seek(TopicPartition, OffsetAndMetadata) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- seek(TopicPartition, long) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Overrides the fetch offsets that the consumer will use on the next
poll(timeout)
.
- seek(TopicPartition, OffsetAndMetadata) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Overrides the fetch offsets that the consumer will use on the next
poll(timeout)
.
- seek(TopicPartition, long) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- seek(TopicPartition, OffsetAndMetadata) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- seekToBeginning(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- seekToBeginning(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Seek to the first offset for each of the given partitions.
- seekToBeginning(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- seekToEnd(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- seekToEnd(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Seek to the last offset for each of the given partitions.
- seekToEnd(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- SEGMENT_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- SEGMENT_BYTES_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- SEGMENT_INDEX_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- SEGMENT_INDEX_BYTES_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- SEGMENT_JITTER_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- SEGMENT_JITTER_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- SEGMENT_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- SEGMENT_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- segmentIntervalMs() - Method in interface org.apache.kafka.streams.state.SessionBytesStoreSupplier
-
The size of a segment, in milliseconds.
- segmentIntervalMs() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
-
The size of the segments (in milliseconds) the store has.
- segments - Variable in class org.apache.kafka.streams.kstream.Windows
-
Deprecated.
- segments(int) - Method in class org.apache.kafka.streams.kstream.Windows
-
- segments() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
-
- selectKey(KeyValueMapper<? super K, ? super V, ? extends KR>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Set a new key (with possibly new type) for each input record.
- selectKey(KeyValueMapper<? super K, ? super V, ? extends KR>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Set a new key (with possibly new type) for each input record.
- send(ProducerRecord<K, V>) - Method in class org.apache.kafka.clients.producer.KafkaProducer
-
Asynchronously send a record to a topic.
- send(ProducerRecord<K, V>, Callback) - Method in class org.apache.kafka.clients.producer.KafkaProducer
-
Asynchronously send a record to a topic and invoke the provided callback when the send has been acknowledged.
- send(ProducerRecord<K, V>) - Method in class org.apache.kafka.clients.producer.MockProducer
-
Adds the record to the list of sent records.
- send(ProducerRecord<K, V>, Callback) - Method in class org.apache.kafka.clients.producer.MockProducer
-
Adds the record to the list of sent records.
- send(ProducerRecord<K, V>) - Method in interface org.apache.kafka.clients.producer.Producer
-
- send(ProducerRecord<K, V>, Callback) - Method in interface org.apache.kafka.clients.producer.Producer
-
- SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
- SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
send.buffer.bytes
- SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
send.buffer.bytes
- SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
send.buffer.bytes
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class org.apache.kafka.clients.producer.KafkaProducer
-
Sends a list of specified offsets to the consumer group coordinator, and also marks
those offsets as part of the current transaction.
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class org.apache.kafka.clients.producer.MockProducer
-
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in interface org.apache.kafka.clients.producer.Producer
-
- sentOffsets() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- SEPARATOR_CONFIG - Static variable in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
-
- SEPARATOR_DEFAULT - Static variable in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
-
- Serde<T> - Interface in org.apache.kafka.common.serialization
-
The interface for wrapping a serializer and deserializer for the given data type.
- serdeFrom(Class<T>) - Static method in class org.apache.kafka.common.serialization.Serdes
-
- serdeFrom(Serializer<T>, Deserializer<T>) - Static method in class org.apache.kafka.common.serialization.Serdes
-
Construct a serde object from separate serializer and deserializer
- Serdes - Class in org.apache.kafka.common.serialization
-
Factory for creating serializers / deserializers.
- Serdes() - Constructor for class org.apache.kafka.common.serialization.Serdes
-
- Serdes.ByteArraySerde - Class in org.apache.kafka.common.serialization
-
- Serdes.ByteBufferSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.BytesSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.DoubleSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.FloatSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.IntegerSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.LongSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.ShortSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.StringSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.UUIDSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.WrapperSerde<T> - Class in org.apache.kafka.common.serialization
-
- SerializationException - Exception in org.apache.kafka.common.errors
-
Any exception during serialization in the producer
- SerializationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SerializationException
-
- SerializationException(String) - Constructor for exception org.apache.kafka.common.errors.SerializationException
-
- SerializationException(Throwable) - Constructor for exception org.apache.kafka.common.errors.SerializationException
-
- SerializationException() - Constructor for exception org.apache.kafka.common.errors.SerializationException
-
- serialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ByteArraySerializer
-
- serialize(String, ByteBuffer) - Method in class org.apache.kafka.common.serialization.ByteBufferSerializer
-
- serialize(String, Bytes) - Method in class org.apache.kafka.common.serialization.BytesSerializer
-
- serialize(String, Double) - Method in class org.apache.kafka.common.serialization.DoubleSerializer
-
- serialize(String, Headers, T) - Method in interface org.apache.kafka.common.serialization.ExtendedSerializer
-
Deprecated.
Convert data
into a byte array.
- serialize(String, Headers, T) - Method in class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
-
Deprecated.
- serialize(String, T) - Method in class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
-
Deprecated.
- serialize(String, Float) - Method in class org.apache.kafka.common.serialization.FloatSerializer
-
- serialize(String, Integer) - Method in class org.apache.kafka.common.serialization.IntegerSerializer
-
- serialize(String, Long) - Method in class org.apache.kafka.common.serialization.LongSerializer
-
- serialize(String, T) - Method in interface org.apache.kafka.common.serialization.Serializer
-
Convert data
into a byte array.
- serialize(String, Headers, T) - Method in interface org.apache.kafka.common.serialization.Serializer
-
Convert data
into a byte array.
- serialize(String, Short) - Method in class org.apache.kafka.common.serialization.ShortSerializer
-
- serialize(String, String) - Method in class org.apache.kafka.common.serialization.StringSerializer
-
- serialize(String, UUID) - Method in class org.apache.kafka.common.serialization.UUIDSerializer
-
- serialize(String, Windowed<T>) - Method in class org.apache.kafka.streams.kstream.SessionWindowedSerializer
-
- serialize(String, Windowed<T>) - Method in class org.apache.kafka.streams.kstream.TimeWindowedSerializer
-
- serializeBaseKey(String, Windowed<T>) - Method in class org.apache.kafka.streams.kstream.SessionWindowedSerializer
-
- serializeBaseKey(String, Windowed<T>) - Method in class org.apache.kafka.streams.kstream.TimeWindowedSerializer
-
- Serialized<K,V> - Class in org.apache.kafka.streams.kstream
-
- Serialized(Serialized<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Serialized
-
Deprecated.
- serializedKeySize() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The size of the serialized, uncompressed key in bytes.
- serializedKeySize() - Method in class org.apache.kafka.clients.producer.RecordMetadata
-
The size of the serialized, uncompressed key in bytes.
- serializedValueSize() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The size of the serialized, uncompressed value in bytes.
- serializedValueSize() - Method in class org.apache.kafka.clients.producer.RecordMetadata
-
The size of the serialized, uncompressed value in bytes.
- serializer() - Method in interface org.apache.kafka.common.serialization.Serde
-
- serializer() - Method in class org.apache.kafka.common.serialization.Serdes.WrapperSerde
-
- Serializer<T> - Interface in org.apache.kafka.common.serialization
-
An interface for converting objects to bytes.
- server() - Method in class org.apache.kafka.common.security.auth.SaslAuthenticationContext
-
- serverKey() - Method in class org.apache.kafka.common.security.scram.ScramCredential
-
Server key computed from the client password using the SCRAM algorithm.
- serviceName() - Method in interface org.apache.kafka.common.security.auth.Login
-
Returns the service name to be used for SASL.
- session() - Method in class org.apache.kafka.common.security.auth.SslAuthenticationContext
-
- SESSION_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
session.timeout.ms
- SessionBytesStoreSupplier - Interface in org.apache.kafka.streams.state
-
- sessionStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
-
- SessionStore<K,AGG> - Interface in org.apache.kafka.streams.state
-
Interface for storing the aggregated values of sessions.
- sessionStoreBuilder(SessionBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
-
- SessionWindowedDeserializer<T> - Class in org.apache.kafka.streams.kstream
-
- SessionWindowedDeserializer() - Constructor for class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
-
- SessionWindowedDeserializer(Deserializer<T>) - Constructor for class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
-
- SessionWindowedKStream<K,V> - Interface in org.apache.kafka.streams.kstream
-
SessionWindowedKStream
is an abstraction of a
windowed record stream of
KeyValue
pairs.
- SessionWindowedSerde() - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.SessionWindowedSerde
-
- SessionWindowedSerde(Serde<T>) - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.SessionWindowedSerde
-
- sessionWindowedSerdeFrom(Class<T>) - Static method in class org.apache.kafka.streams.kstream.WindowedSerdes
-
Construct a SessionWindowedSerde
object for the specified inner class type.
- SessionWindowedSerializer<T> - Class in org.apache.kafka.streams.kstream
-
- SessionWindowedSerializer() - Constructor for class org.apache.kafka.streams.kstream.SessionWindowedSerializer
-
- SessionWindowedSerializer(Serializer<T>) - Constructor for class org.apache.kafka.streams.kstream.SessionWindowedSerializer
-
- SessionWindows - Class in org.apache.kafka.streams.kstream
-
A session based window specification used for aggregating events into sessions.
- setConfig(String, Options, Map<String, Object>) - Method in interface org.apache.kafka.streams.state.RocksDBConfigSetter
-
Set the rocks db options for the provided storeName.
- setException(KafkaException) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- setExpiryTimestamp(long) - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- setGlobalStateRestoreListener(StateRestoreListener) - Method in class org.apache.kafka.streams.KafkaStreams
-
Set the listener which is triggered whenever a
StateStore
is being restored in order to resume
processing.
- setGroupInstanceId(Optional<String>) - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
-
- setHeaders(Headers) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
The context exposes this metadata for use in the processor.
- setIsChangelogTopic(boolean) - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
-
- setMockMetrics(MetricName, Metric) - Method in class org.apache.kafka.clients.producer.MockProducer
-
Set a mock metric for testing purpose
- setOffset(long) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
The context exposes this metadata for use in the processor.
- setOffsetsException(KafkaException) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- setPartition(int) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
The context exposes this metadata for use in the processor.
- setPollException(KafkaException) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- setRecordMetadata(String, int, long, Headers, long) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
The context exposes these metadata for use in the processor.
- setStateListener(KafkaStreams.StateListener) - Method in class org.apache.kafka.streams.KafkaStreams
-
- setTimestamp(long) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
The context exposes this metadata for use in the processor.
- setTopic(String) - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
The context exposes this metadata for use in the processor.
- setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.kafka.streams.KafkaStreams
-
Set the handler invoked when a
internal thread
abruptly
terminates due to an uncaught exception.
- Short() - Static method in class org.apache.kafka.common.serialization.Serdes
-
- ShortDeserializer - Class in org.apache.kafka.common.serialization
-
- ShortDeserializer() - Constructor for class org.apache.kafka.common.serialization.ShortDeserializer
-
- ShortSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.ShortSerde
-
- ShortSerializer - Class in org.apache.kafka.common.serialization
-
- ShortSerializer() - Constructor for class org.apache.kafka.common.serialization.ShortSerializer
-
- shouldListInternal() - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
-
Return true if we should list internal topics.
- shouldValidateOnly() - Method in class org.apache.kafka.clients.admin.AlterConfigsOptions
-
Return true if the request should be validated without altering the configs.
- shouldValidateOnly() - Method in class org.apache.kafka.clients.admin.CreateTopicsOptions
-
Return true if the request should be validated without creating the topic.
- shutDownWhenFull() - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Set the buffer to gracefully shut down the application when any of its constraints are violated
This buffer is "strict" in the sense that it will enforce the time bound or shut down.
- SimpleHeaderConverter - Class in org.apache.kafka.connect.storage
-
A
HeaderConverter
that serializes header values as strings and that deserializes header values to the most appropriate
numeric, boolean, array, or map representation.
- SimpleHeaderConverter() - Constructor for class org.apache.kafka.connect.storage.SimpleHeaderConverter
-
- SinkConnector - Class in org.apache.kafka.connect.sink
-
SinkConnectors implement the Connector interface to send Kafka data to another system.
- SinkConnector() - Constructor for class org.apache.kafka.connect.sink.SinkConnector
-
- SinkRecord - Class in org.apache.kafka.connect.sink
-
SinkRecord is a
ConnectRecord
that has been read from Kafka and includes the kafkaOffset of
the record in the Kafka topic-partition in addition to the standard fields.
- SinkRecord(String, int, Schema, Object, Schema, Object, long) - Constructor for class org.apache.kafka.connect.sink.SinkRecord
-
- SinkRecord(String, int, Schema, Object, Schema, Object, long, Long, TimestampType) - Constructor for class org.apache.kafka.connect.sink.SinkRecord
-
- SinkRecord(String, int, Schema, Object, Schema, Object, long, Long, TimestampType, Iterable<Header>) - Constructor for class org.apache.kafka.connect.sink.SinkRecord
-
- SinkTask - Class in org.apache.kafka.connect.sink
-
SinkTask is a Task that takes records loaded from Kafka and sends them to another system.
- SinkTask() - Constructor for class org.apache.kafka.connect.sink.SinkTask
-
- SinkTaskContext - Interface in org.apache.kafka.connect.sink
-
Context passed to SinkTasks, allowing them to access utilities in the Kafka Connect runtime.
- size() - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- size() - Method in interface org.apache.kafka.connect.header.Headers
-
Get the number of headers in this object.
- size() - Method in class org.apache.kafka.streams.kstream.JoinWindows
-
- size() - Method in class org.apache.kafka.streams.kstream.TimeWindows
-
- size() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
Return the size of the specified windows in milliseconds.
- size() - Method in class org.apache.kafka.streams.kstream.Windows
-
Return the size of the specified windows in milliseconds.
- sizeMs - Variable in class org.apache.kafka.streams.kstream.TimeWindows
-
The size of the windows in milliseconds.
- source() - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
-
Returns the source of this configuration.
- source() - Method in class org.apache.kafka.clients.admin.ConfigEntry
-
Return the source of this configuration entry.
- source() - Method in class org.apache.kafka.connect.mirror.SourceAndTarget
-
- source() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
-
The source node reading from a "global" topic.
- SOURCE_CLUSTER_ALIAS_KEY - Static variable in class org.apache.kafka.connect.mirror.Heartbeat
-
- SourceAndTarget - Class in org.apache.kafka.connect.mirror
-
Directional pair of clustes, where source is replicated to target.
- SourceAndTarget(String, String) - Constructor for class org.apache.kafka.connect.mirror.SourceAndTarget
-
- sourceClusterAlias() - Method in class org.apache.kafka.connect.mirror.Heartbeat
-
- SourceConnector - Class in org.apache.kafka.connect.source
-
SourceConnectors implement the connector interface to pull data from another system and send
it to Kafka.
- SourceConnector() - Constructor for class org.apache.kafka.connect.source.SourceConnector
-
- sourceOffset() - Method in class org.apache.kafka.connect.source.SourceRecord
-
- sourcePartition() - Method in class org.apache.kafka.connect.source.SourceRecord
-
- SourceRecord - Class in org.apache.kafka.connect.source
-
SourceRecords are generated by SourceTasks and passed to Kafka Connect for storage in
Kafka.
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Integer, Schema, Object) - Constructor for class org.apache.kafka.connect.source.SourceRecord
-
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Schema, Object) - Constructor for class org.apache.kafka.connect.source.SourceRecord
-
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Schema, Object, Schema, Object) - Constructor for class org.apache.kafka.connect.source.SourceRecord
-
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Integer, Schema, Object, Schema, Object) - Constructor for class org.apache.kafka.connect.source.SourceRecord
-
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Integer, Schema, Object, Schema, Object, Long) - Constructor for class org.apache.kafka.connect.source.SourceRecord
-
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Integer, Schema, Object, Schema, Object, Long, Iterable<Header>) - Constructor for class org.apache.kafka.connect.source.SourceRecord
-
- SourceTask - Class in org.apache.kafka.connect.source
-
SourceTask is a Task that pulls records from another system for storage in Kafka.
- SourceTask() - Constructor for class org.apache.kafka.connect.source.SourceTask
-
- SourceTaskContext - Interface in org.apache.kafka.connect.source
-
SourceTaskContext is provided to SourceTasks to allow them to interact with the underlying
runtime.
- SSL_CIPHER_SUITES_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_CIPHER_SUITES_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_CLIENT_AUTH_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_CLIENT_AUTH_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_ENABLED_PROTOCOLS_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_ENABLED_PROTOCOLS_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_ENDPOINT_IDENTIFICATION_ALGORITHM_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_ENDPOINT_IDENTIFICATION_ALGORITHM_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEY_PASSWORD_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEY_PASSWORD_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYMANAGER_ALGORITHM_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYMANAGER_ALGORITHM_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYSTORE_LOCATION_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYSTORE_LOCATION_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYSTORE_PASSWORD_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYSTORE_PASSWORD_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYSTORE_TYPE_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYSTORE_TYPE_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_PROTOCOL_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_PROTOCOL_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_PROVIDER_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_PROVIDER_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_SECURE_RANDOM_IMPLEMENTATION_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_SECURE_RANDOM_IMPLEMENTATION_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTMANAGER_ALGORITHM_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTMANAGER_ALGORITHM_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTSTORE_LOCATION_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTSTORE_LOCATION_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTSTORE_PASSWORD_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTSTORE_PASSWORD_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTSTORE_TYPE_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTSTORE_TYPE_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SslAuthenticationContext - Class in org.apache.kafka.common.security.auth
-
- SslAuthenticationContext(SSLSession, InetAddress, String) - Constructor for class org.apache.kafka.common.security.auth.SslAuthenticationContext
-
- SslAuthenticationException - Exception in org.apache.kafka.common.errors
-
This exception indicates that SSL handshake has failed.
- SslAuthenticationException(String) - Constructor for exception org.apache.kafka.common.errors.SslAuthenticationException
-
- SslAuthenticationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SslAuthenticationException
-
- SslClientAuth - Enum in org.apache.kafka.common.config
-
Describes whether the server should require or request client authentication.
- SslConfigs - Class in org.apache.kafka.common.config
-
- SslConfigs() - Constructor for class org.apache.kafka.common.config.SslConfigs
-
- StaleBrokerEpochException - Exception in org.apache.kafka.common.errors
-
- StaleBrokerEpochException(String) - Constructor for exception org.apache.kafka.common.errors.StaleBrokerEpochException
-
- StaleBrokerEpochException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.StaleBrokerEpochException
-
- standbyTasks() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
- start(Map<String, String>) - Method in class org.apache.kafka.connect.connector.Connector
-
Start this Connector.
- start(Map<String, String>) - Method in interface org.apache.kafka.connect.connector.Task
-
Start the Task
- start(Map<String, String>) - Method in class org.apache.kafka.connect.sink.SinkTask
-
Start the Task.
- start(Map<String, String>) - Method in class org.apache.kafka.connect.source.SourceTask
-
Start the Task.
- start(AuthorizerServerInfo) - Method in interface org.apache.kafka.server.authorizer.Authorizer
-
Starts loading authorization metadata and returns futures that can be used to wait until
metadata for authorizing requests on each listener is available.
- start() - Method in class org.apache.kafka.streams.KafkaStreams
-
Start the KafkaStreams
instance by starting all its threads.
- start() - Method in class org.apache.kafka.streams.kstream.Window
-
Return the start timestamp of this window.
- startMs - Variable in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
The start timestamp of the window.
- startMs - Variable in class org.apache.kafka.streams.kstream.Window
-
- startOn(long) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
- startOn(Instant) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
Return a new unlimited window for the specified start timestamp.
- startTime() - Method in class org.apache.kafka.streams.kstream.Window
-
Return the start time of this window.
- startTimeMs() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
-
When the credential became valid, in terms of the number of milliseconds
since the epoch, if known, otherwise null.
- state() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
-
The consumer group state, or UNKNOWN if the state is too new for us to parse.
- state() - Method in class org.apache.kafka.connect.health.AbstractState
-
Provides the current state of the connector or task.
- state - Variable in class org.apache.kafka.streams.KafkaStreams
-
- state() - Method in class org.apache.kafka.streams.KafkaStreams
-
- STATE_CLEANUP_DELAY_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
state.cleanup.delay
- STATE_DIR_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
state.dir
- stateDir() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- stateDir() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Returns the state directory for the partition.
- StateRestoreCallback - Interface in org.apache.kafka.streams.processor
-
Restoration logic for log-backed state stores upon restart,
it takes one record at a time from the logs to apply to the restoring state.
- StateRestoreListener - Interface in org.apache.kafka.streams.processor
-
Class for listening to various states of the restoration process of a StateStore.
- StateSerdes<K,V> - Class in org.apache.kafka.streams.state
-
Factory for creating serializers / deserializers for state stores in Kafka Streams.
- StateSerdes(String, Serde<K>, Serde<V>) - Constructor for class org.apache.kafka.streams.state.StateSerdes
-
Create a context for serialization using the specified serializers and deserializers which
must match the key and value types used as parameters for this object; the state changelog topic
is provided to bind this serde factory to, so that future calls for serialize / deserialize do not
need to provide the topic name any more.
- StateStore - Interface in org.apache.kafka.streams.processor
-
A storage engine for managing state maintained by a stream processor.
- stateStoreNames() - Method in class org.apache.kafka.streams.state.StreamsMetadata
-
- StickyAssignor - Class in org.apache.kafka.clients.consumer
-
The sticky assignor serves two purposes.
- StickyAssignor() - Constructor for class org.apache.kafka.clients.consumer.StickyAssignor
-
- stop() - Method in class org.apache.kafka.connect.connector.Connector
-
Stop this connector.
- stop() - Method in interface org.apache.kafka.connect.connector.Task
-
Stop this task.
- stop() - Method in class org.apache.kafka.connect.sink.SinkTask
-
Perform any cleanup to stop this task.
- stop() - Method in class org.apache.kafka.connect.source.SourceTask
-
Signal this SourceTask to stop.
- store(String, QueryableStoreType<T>) - Method in class org.apache.kafka.streams.KafkaStreams
-
Get a facade wrapping the local
StateStore
instances with the provided
storeName
if the Store's
type is accepted by the provided
queryableStoreType
.
- StoreBuilder<T extends StateStore> - Interface in org.apache.kafka.streams.state
-
Build a
StateStore
wrapped with optional caching and logging.
- storedKey() - Method in class org.apache.kafka.common.security.scram.ScramCredential
-
Stored key computed from the client password using the SCRAM algorithm.
- storeName - Variable in class org.apache.kafka.streams.kstream.Materialized
-
- storeName - Variable in class org.apache.kafka.streams.kstream.StreamJoined
-
- Stores - Class in org.apache.kafka.streams.state
-
Factory for creating state stores in Kafka Streams.
- Stores() - Constructor for class org.apache.kafka.streams.state.Stores
-
- stores() - Method in interface org.apache.kafka.streams.TopologyDescription.Processor
-
The names of all connected stores.
- storeSupplier - Variable in class org.apache.kafka.streams.kstream.Materialized
-
- StoreSupplier<T extends StateStore> - Interface in org.apache.kafka.streams.state
-
A state store supplier which can create one or more
StateStore
instances.
- stream(String) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KStream
from the specified topic.
- stream(String, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KStream
from the specified topic.
- stream(Collection<String>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KStream
from the specified topics.
- stream(Collection<String>, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KStream
from the specified topics.
- stream(Pattern) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KStream
from the specified topic pattern.
- stream(Pattern, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KStream
from the specified topic pattern.
- StreamJoined<K,V1,V2> - Class in org.apache.kafka.streams.kstream
-
Class used to configure the name of the join processor, the repartition topic name,
state stores or state store names in Stream-Stream join.
- StreamJoined(StreamJoined<K, V1, V2>) - Constructor for class org.apache.kafka.streams.kstream.StreamJoined
-
- streamPartitioner(StreamPartitioner<? super K, ? super V>) - Static method in class org.apache.kafka.streams.kstream.Produced
-
Create a Produced instance with provided partitioner.
- StreamPartitioner<K,V> - Interface in org.apache.kafka.streams.processor
-
Determine how records are distributed among the partitions in a Kafka topic.
- StreamsBuilder - Class in org.apache.kafka.streams
-
StreamsBuilder
provide the high-level Kafka Streams DSL to specify a Kafka Streams topology.
- StreamsBuilder() - Constructor for class org.apache.kafka.streams.StreamsBuilder
-
- StreamsConfig - Class in org.apache.kafka.streams
-
- StreamsConfig(Map<?, ?>) - Constructor for class org.apache.kafka.streams.StreamsConfig
-
Create a new StreamsConfig
using the given properties.
- StreamsConfig(Map<?, ?>, boolean) - Constructor for class org.apache.kafka.streams.StreamsConfig
-
- StreamsConfig.InternalConfig - Class in org.apache.kafka.streams
-
- StreamsException - Exception in org.apache.kafka.streams.errors
-
- StreamsException(String) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
-
- StreamsException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
-
- StreamsException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
-
- StreamsMetadata - Class in org.apache.kafka.streams.state
-
Represents the state of an instance (process) in a
KafkaStreams
application.
- StreamsMetadata(HostInfo, Set<String>, Set<TopicPartition>) - Constructor for class org.apache.kafka.streams.state.StreamsMetadata
-
- StreamsMetrics - Interface in org.apache.kafka.streams
-
The Kafka Streams metrics interface for adding metric sensors and collecting metric values.
- String() - Static method in class org.apache.kafka.common.serialization.Serdes
-
- string() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
-
- STRING_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
-
- StringConverter - Class in org.apache.kafka.connect.storage
-
- StringConverter() - Constructor for class org.apache.kafka.connect.storage.StringConverter
-
- StringConverterConfig - Class in org.apache.kafka.connect.storage
-
- StringConverterConfig(Map<String, ?>) - Constructor for class org.apache.kafka.connect.storage.StringConverterConfig
-
- StringDeserializer - Class in org.apache.kafka.common.serialization
-
String encoding defaults to UTF8 and can be customized by setting the property key.deserializer.encoding,
value.deserializer.encoding or deserializer.encoding.
- StringDeserializer() - Constructor for class org.apache.kafka.common.serialization.StringDeserializer
-
- StringSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.StringSerde
-
- StringSerializer - Class in org.apache.kafka.common.serialization
-
String encoding defaults to UTF8 and can be customized by setting the property key.serializer.encoding,
value.serializer.encoding or serializer.encoding.
- StringSerializer() - Constructor for class org.apache.kafka.common.serialization.StringSerializer
-
- struct() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
-
- Struct - Class in org.apache.kafka.connect.data
-
A structured record containing a set of named fields with values, each field using an independent
Schema
.
- Struct(Schema) - Constructor for class org.apache.kafka.connect.data.Struct
-
Create a new Struct for this
Schema
- subject() - Method in interface org.apache.kafka.common.security.auth.Login
-
Returns the authenticated subject of this login context.
- subscribe(Collection<String>) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- subscribe(Collection<String>, ConsumerRebalanceListener) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- subscribe(Pattern, ConsumerRebalanceListener) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- subscribe(Pattern) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- subscribe(Collection<String>, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Subscribe to the given list of topics to get dynamically
assigned partitions.
- subscribe(Collection<String>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Subscribe to the given list of topics to get dynamically assigned partitions.
- subscribe(Pattern, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Subscribe to all topics matching specified pattern to get dynamically assigned partitions.
- subscribe(Pattern) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Subscribe to all topics matching specified pattern to get dynamically assigned partitions.
- subscribe(Collection<String>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- subscribe(Pattern, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- subscribe(Pattern) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- subscribe(Collection<String>, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- subscribe(String, Set<String>, ConfigChangeCallback) - Method in interface org.apache.kafka.common.config.provider.ConfigProvider
-
Subscribes to changes for the given keys at the given path (optional operation).
- subscription() - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- Subscription(List<String>, ByteBuffer, List<TopicPartition>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
-
- Subscription(List<String>, ByteBuffer) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
-
- Subscription(List<String>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
-
- subscription() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Get the current subscription.
- subscription() - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- subscriptionUserData(Set<String>) - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
-
- subscriptionUserData(Set<String>) - Method in class org.apache.kafka.clients.consumer.StickyAssignor
-
- subtopologies() - Method in interface org.apache.kafka.streams.TopologyDescription
-
All sub-topologies of the represented topology.
- SUCCESS - Static variable in class org.apache.kafka.server.authorizer.AclCreateResult
-
- successors() - Method in interface org.apache.kafka.streams.TopologyDescription.Node
-
The successor of this node within a sub-topology.
- supportedProtocols() - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
-
- supportedProtocols() - Method in class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
-
- suppress(Suppressed<? super K>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Suppress some updates from this changelog stream, determined by the supplied
Suppressed
configuration.
- Suppressed<K> - Interface in org.apache.kafka.streams.kstream
-
- Suppressed.BufferConfig<BC extends Suppressed.BufferConfig<BC>> - Interface in org.apache.kafka.streams.kstream
-
- Suppressed.EagerBufferConfig - Interface in org.apache.kafka.streams.kstream
-
Marker interface for a buffer configuration that will strictly enforce size constraints
(bytes and/or number of records) on the buffer, so it is suitable for reducing duplicate
results downstream, but does not promise to eliminate them entirely.
- Suppressed.StrictBufferConfig - Interface in org.apache.kafka.streams.kstream
-
Marker interface for a buffer configuration that is "strict" in the sense that it will strictly
enforce the time bound and never emit early.
- synonyms() - Method in class org.apache.kafka.clients.admin.ConfigEntry
-
Returns all config values that may be used as the value of this config along with their source,
in the order of precedence.
- table(String, Consumed<K, V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KTable
for the specified topic.
- table(String) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KTable
for the specified topic.
- table(String, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KTable
for the specified topic.
- table(String, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
-
Create a
KTable
for the specified topic.
- tags() - Method in class org.apache.kafka.common.MetricName
-
- tags() - Method in class org.apache.kafka.common.MetricNameTemplate
-
Get the set of tag names for the metric.
- target() - Method in class org.apache.kafka.connect.mirror.SourceAndTarget
-
- TARGET_CLUSTER_ALIAS_KEY - Static variable in class org.apache.kafka.connect.mirror.Heartbeat
-
- targetClusterAlias() - Method in class org.apache.kafka.connect.mirror.Heartbeat
-
- targetReplicas() - Method in class org.apache.kafka.clients.admin.NewPartitionReassignment
-
- Task - Interface in org.apache.kafka.connect.connector
-
Tasks contain the code that actually copies data to/from another system.
- TASK_MANAGER_FOR_PARTITION_ASSIGNOR - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
-
- TaskAssignmentException - Exception in org.apache.kafka.streams.errors
-
Indicates a run time error incurred while trying to assign
stream tasks
to
threads
.
- TaskAssignmentException(String) - Constructor for exception org.apache.kafka.streams.errors.TaskAssignmentException
-
- TaskAssignmentException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskAssignmentException
-
- TaskAssignmentException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskAssignmentException
-
- taskClass() - Method in class org.apache.kafka.connect.connector.Connector
-
Returns the Task implementation for this Connector.
- taskConfigs(int) - Method in class org.apache.kafka.connect.connector.Connector
-
Returns a set of configurations for Tasks based on the current configuration,
producing at most count configurations.
- taskId() - Method in class org.apache.kafka.connect.health.TaskState
-
Provides the ID of the task.
- taskId() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- taskId() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Returns the task id
- TaskId - Class in org.apache.kafka.streams.processor
-
The task ID representation composed as topic group ID plus the assigned partition ID.
- TaskId(int, int) - Constructor for class org.apache.kafka.streams.processor.TaskId
-
- taskId() - Method in class org.apache.kafka.streams.processor.TaskMetadata
-
- TaskIdFormatException - Exception in org.apache.kafka.streams.errors
-
Indicates a run time error incurred while trying parse the
task id
from the read string.
- TaskIdFormatException(String) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
-
- TaskIdFormatException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
-
- TaskIdFormatException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
-
- TaskMetadata - Class in org.apache.kafka.streams.processor
-
Represents the state of a single task running within a
KafkaStreams
application.
- TaskMetadata(String, Set<TopicPartition>) - Constructor for class org.apache.kafka.streams.processor.TaskMetadata
-
- TaskMigratedException - Exception in org.apache.kafka.streams.errors
-
Indicates that a task got migrated to another thread.
- TaskMigratedException() - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
-
- TaskMigratedException(Task, TopicPartition, long, long) - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
-
- TaskMigratedException(Task) - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
-
- TaskMigratedException(Task, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
-
- tasksState() - Method in class org.apache.kafka.connect.health.ConnectorHealth
-
Provides the current state of the connector tasks.
- TaskState - Class in org.apache.kafka.connect.health
-
Describes the state, IDs, and any errors of a connector task.
- TaskState(int, String, String, String) - Constructor for class org.apache.kafka.connect.health.TaskState
-
- test(K, V) - Method in interface org.apache.kafka.streams.kstream.Predicate
-
Test if the record with the given key and value satisfies the predicate.
- TestInputTopic<K,V> - Class in org.apache.kafka.streams
-
- TestOutputTopic<K,V> - Class in org.apache.kafka.streams
-
- TestRecord<K,V> - Class in org.apache.kafka.streams.test
-
A key/value pair, including timestamp and record headers, to be sent to or received from
TopologyTestDriver
.
- TestRecord(K, V, Headers, Instant) - Constructor for class org.apache.kafka.streams.test.TestRecord
-
Creates a record.
- TestRecord(K, V, Headers, Long) - Constructor for class org.apache.kafka.streams.test.TestRecord
-
Creates a record.
- TestRecord(K, V, Instant) - Constructor for class org.apache.kafka.streams.test.TestRecord
-
Creates a record.
- TestRecord(K, V, Headers) - Constructor for class org.apache.kafka.streams.test.TestRecord
-
Creates a record.
- TestRecord(K, V) - Constructor for class org.apache.kafka.streams.test.TestRecord
-
Creates a record.
- TestRecord(V) - Constructor for class org.apache.kafka.streams.test.TestRecord
-
Create a record with null
key.
- TestRecord(ConsumerRecord<K, V>) - Constructor for class org.apache.kafka.streams.test.TestRecord
-
- TestRecord(ProducerRecord<K, V>) - Constructor for class org.apache.kafka.streams.test.TestRecord
-
- thenApply(KafkaFuture.BaseFunction<T, R>) - Method in class org.apache.kafka.common.KafkaFuture
-
Returns a new KafkaFuture that, when this future completes normally, is executed with this
futures's result as the argument to the supplied function.
- thenApply(KafkaFuture.Function<T, R>) - Method in class org.apache.kafka.common.KafkaFuture
-
- thisStoreSupplier - Variable in class org.apache.kafka.streams.kstream.StreamJoined
-
- ThreadMetadata - Class in org.apache.kafka.streams.processor
-
Represents the state of a single thread running within a
KafkaStreams
application.
- ThreadMetadata(String, String, String, String, Set<String>, String, Set<TaskMetadata>, Set<TaskMetadata>) - Constructor for class org.apache.kafka.streams.processor.ThreadMetadata
-
- threadName() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
- threads - Variable in class org.apache.kafka.streams.KafkaStreams
-
- threadState() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
- through(String) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Materialize this stream to a topic and creates a new KStream
from the topic using default serializers,
deserializers, and producer's DefaultPartitioner
.
- through(String, Produced<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
- Time - Class in org.apache.kafka.connect.data
-
A time representing a specific point in a day, not tied to any specific date.
- Time() - Constructor for class org.apache.kafka.connect.data.Time
-
- timeout(long) - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Set the timeout in milliseconds.
- TimeoutException - Exception in org.apache.kafka.common.errors
-
Indicates that a request timed out.
- TimeoutException() - Constructor for exception org.apache.kafka.common.errors.TimeoutException
-
- TimeoutException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.TimeoutException
-
- TimeoutException(String) - Constructor for exception org.apache.kafka.common.errors.TimeoutException
-
- TimeoutException(Throwable) - Constructor for exception org.apache.kafka.common.errors.TimeoutException
-
- timeoutMs - Variable in class org.apache.kafka.clients.admin.AbstractOptions
-
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.AbstractOptions
-
Set the request timeout in milliseconds for this operation or null
if the default request timeout for the
AdminClient should be used.
- timeoutMs() - Method in class org.apache.kafka.clients.admin.AbstractOptions
-
The request timeout in milliseconds for this operation or null
if the default request timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.AlterConfigsOptions
-
Set the request timeout in milliseconds for this operation or null
if the default request timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.CreateAclsOptions
-
Set the request timeout in milliseconds for this operation or null
if the default request timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.CreateTopicsOptions
-
Set the request timeout in milliseconds for this operation or null
if the default request timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DeleteAclsOptions
-
Set the request timeout in milliseconds for this operation or null
if the default request timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DeleteTopicsOptions
-
Set the request timeout in milliseconds for this operation or null
if the default request timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DescribeAclsOptions
-
Set the request timeout in milliseconds for this operation or null
if the default request timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DescribeClusterOptions
-
Set the request timeout in milliseconds for this operation or null
if the default request timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DescribeConfigsOptions
-
Set the request timeout in milliseconds for this operation or null
if the default request timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DescribeTopicsOptions
-
Set the request timeout in milliseconds for this operation or null
if the default request timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
-
Set the request timeout in milliseconds for this operation or null
if the default request timeout for the
AdminClient should be used.
- timestamp() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The timestamp of this record
- timestamp() - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
-
- timestamp() - Method in class org.apache.kafka.clients.producer.ProducerRecord
-
- timestamp() - Method in class org.apache.kafka.clients.producer.RecordMetadata
-
The timestamp of the record in the topic/partition.
- timestamp() - Method in class org.apache.kafka.connect.connector.ConnectRecord
-
- Timestamp - Class in org.apache.kafka.connect.data
-
A timestamp representing an absolute time, without timezone information.
- Timestamp() - Constructor for class org.apache.kafka.connect.data.Timestamp
-
- timestamp() - Method in class org.apache.kafka.connect.mirror.Heartbeat
-
- timestamp() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedForward
-
The timestamp attached to the forwarded record.
- timestamp() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- timestamp() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Returns the current timestamp.
- timestamp() - Method in interface org.apache.kafka.streams.processor.RecordContext
-
- timestamp - Variable in class org.apache.kafka.streams.processor.To
-
- timestamp() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
-
- timestamp() - Method in class org.apache.kafka.streams.test.TestRecord
-
- TIMESTAMP_KEY - Static variable in class org.apache.kafka.connect.mirror.Heartbeat
-
- TimestampedBytesStore - Interface in org.apache.kafka.streams.state
-
- timestampedKeyValueStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
-
- TimestampedKeyValueStore<K,V> - Interface in org.apache.kafka.streams.state
-
A key-(value/timestamp) store that supports put/get/delete and range queries.
- timestampedKeyValueStoreBuilder(KeyValueBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
-
- timestampedWindowStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
-
- TimestampedWindowStore<K,V> - Interface in org.apache.kafka.streams.state
-
Interface for storing the aggregated values of fixed-size time windows.
- timestampedWindowStoreBuilder(WindowBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
-
- timestampExtractor - Variable in class org.apache.kafka.streams.kstream.Consumed
-
- TimestampExtractor - Interface in org.apache.kafka.streams.processor
-
An interface that allows the Kafka Streams framework to extract a timestamp from an instance of
ConsumerRecord
.
- timestampType() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The timestamp type of this record
- timestampType() - Method in class org.apache.kafka.connect.sink.SinkRecord
-
- TimeWindowedDeserializer<T> - Class in org.apache.kafka.streams.kstream
-
- TimeWindowedDeserializer() - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
-
- TimeWindowedDeserializer(Deserializer<T>) - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
-
- TimeWindowedDeserializer(Deserializer<T>, long) - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
-
- TimeWindowedKStream<K,V> - Interface in org.apache.kafka.streams.kstream
-
TimeWindowedKStream
is an abstraction of a
windowed record stream of
KeyValue
pairs.
- TimeWindowedSerde() - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
-
- TimeWindowedSerde(Serde<T>) - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
-
- TimeWindowedSerde(Serde<T>, long) - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
-
- timeWindowedSerdeFrom(Class<T>) - Static method in class org.apache.kafka.streams.kstream.WindowedSerdes
-
Construct a TimeWindowedSerde
object for the specified inner class type.
- timeWindowedSerdeFrom(Class<T>, long) - Static method in class org.apache.kafka.streams.kstream.WindowedSerdes
-
Construct a TimeWindowedSerde
object to deserialize changelog topic
for the specified inner class type and window size.
- TimeWindowedSerializer<T> - Class in org.apache.kafka.streams.kstream
-
- TimeWindowedSerializer() - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedSerializer
-
- TimeWindowedSerializer(Serializer<T>) - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedSerializer
-
- TimeWindows - Class in org.apache.kafka.streams.kstream
-
The fixed-size time-based window specifications used for aggregations.
- to(String) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Materialize this stream to a topic using default serializers specified in the config and producer's
DefaultPartitioner
.
- to(String, Produced<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Materialize this stream to a topic using the provided
Produced
instance.
- to(TopicNameExtractor<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Dynamically materialize this stream to topics using default serializers specified in the config and producer's
DefaultPartitioner
.
- to(TopicNameExtractor<K, V>, Produced<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Dynamically materialize this stream to topics using the provided
Produced
instance.
- To - Class in org.apache.kafka.streams.processor
-
- To(To) - Constructor for class org.apache.kafka.streams.processor.To
-
- toArray() - Method in interface org.apache.kafka.common.header.Headers
-
Returns all headers as an array, in the order they were added in.
- toConnectData(String, byte[]) - Method in interface org.apache.kafka.connect.storage.Converter
-
Convert a native object to a Kafka Connect data object.
- toConnectData(String, Headers, byte[]) - Method in interface org.apache.kafka.connect.storage.Converter
-
Convert a native object to a Kafka Connect data object,
potentially using the supplied topic and headers in the record as necessary.
- toConnectData(String, byte[]) - Method in class org.apache.kafka.connect.storage.StringConverter
-
- toConnectHeader(String, String, byte[]) - Method in interface org.apache.kafka.connect.storage.HeaderConverter
-
Convert the header name and byte array value into a
Header
object.
- toConnectHeader(String, String, byte[]) - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
-
- toConnectHeader(String, String, byte[]) - Method in class org.apache.kafka.connect.storage.StringConverter
-
- toEnrichedRst() - Method in class org.apache.kafka.common.config.ConfigDef
-
Configs with new metadata (group, orderInGroup, dependents) formatted with reStructuredText, suitable for embedding in Sphinx
documentation.
- toFile(String) - Static method in class org.apache.kafka.streams.kstream.Printed
-
Print the records of a
KStream
to a file.
- toFilter() - Method in class org.apache.kafka.common.acl.AccessControlEntry
-
Create a filter which matches only this AccessControlEntry.
- toFilter() - Method in class org.apache.kafka.common.acl.AclBinding
-
Create a filter which matches only this AclBinding.
- toFilter() - Method in class org.apache.kafka.common.resource.Resource
-
Create a filter which matches only this Resource.
- toFilter() - Method in class org.apache.kafka.common.resource.ResourcePattern
-
- toHtml() - Method in class org.apache.kafka.common.config.ConfigDef
-
- toHtml(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
-
Converts this config into an HTML list that can be embedded into docs.
- toHtmlTable() - Method in class org.apache.kafka.common.config.ConfigDef
-
- toHtmlTable(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
-
Converts this config into an HTML table that can be embedded into docs.
- token() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
-
- token() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback
-
Return the (potentially null) token
- token(OAuthBearerToken) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback
-
Set the token.
- token() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
-
Return the (potentially null) token
- token(OAuthBearerToken) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
-
Set the token.
- TOKEN_AUTH_CONFIG - Static variable in class org.apache.kafka.common.security.scram.ScramLoginModule
-
- tokenAuthenticated(boolean) - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
-
- tokenAuthenticated() - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
-
- tokenId() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- tokenInfo() - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
-
- TokenInformation - Class in org.apache.kafka.common.security.token.delegation
-
A class representing a delegation token details.
- TokenInformation(String, KafkaPrincipal, Collection<KafkaPrincipal>, long, long, long) - Constructor for class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- tokenValue() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
-
Return the (always non-null) token value
- toLogical(Schema, int) - Static method in class org.apache.kafka.connect.data.Date
-
- toLogical(Schema, byte[]) - Static method in class org.apache.kafka.connect.data.Decimal
-
- toLogical(Schema, int) - Static method in class org.apache.kafka.connect.data.Time
-
- toLogical(Schema, long) - Static method in class org.apache.kafka.connect.data.Timestamp
-
- topic() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The topic this record is received from (never null)
- topic() - Method in class org.apache.kafka.clients.producer.ProducerRecord
-
- topic() - Method in class org.apache.kafka.clients.producer.RecordMetadata
-
The topic the record was appended to
- topic() - Method in class org.apache.kafka.common.PartitionInfo
-
The topic name
- topic() - Method in class org.apache.kafka.common.TopicPartition
-
- topic() - Method in class org.apache.kafka.common.TopicPartitionReplica
-
- topic() - Method in class org.apache.kafka.connect.connector.ConnectRecord
-
- topic() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
-
Return the name of the topic to create.
- topic() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- topic() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Returns the topic name of the current input record; could be null if it is not
available (for example, if this method is invoked from the punctuate call)
- topic() - Method in interface org.apache.kafka.streams.processor.RecordContext
-
- topic() - Method in class org.apache.kafka.streams.state.StateSerdes
-
Return the topic.
- topic() - Method in interface org.apache.kafka.streams.TopologyDescription.Sink
-
The topic name this sink node is writing to.
- TOPIC_KEY - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
-
- TOPIC_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
-
Prefix used to provide default topic configs to be applied when creating internal topics.
- TopicAuthorizationException - Exception in org.apache.kafka.common.errors
-
- TopicAuthorizationException(String, Set<String>) - Constructor for exception org.apache.kafka.common.errors.TopicAuthorizationException
-
- TopicAuthorizationException(Set<String>) - Constructor for exception org.apache.kafka.common.errors.TopicAuthorizationException
-
- TopicAuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.TopicAuthorizationException
-
- TopicConfig - Class in org.apache.kafka.common.config
-
Keys that can be used to configure a topic.
- TopicConfig() - Constructor for class org.apache.kafka.common.config.TopicConfig
-
- topicConfig - Variable in class org.apache.kafka.streams.kstream.Materialized
-
- TopicDeletionDisabledException - Exception in org.apache.kafka.common.errors
-
- TopicDeletionDisabledException() - Constructor for exception org.apache.kafka.common.errors.TopicDeletionDisabledException
-
- TopicDeletionDisabledException(String) - Constructor for exception org.apache.kafka.common.errors.TopicDeletionDisabledException
-
- TopicDescription - Class in org.apache.kafka.clients.admin
-
A detailed description of a single topic in the cluster.
- TopicDescription(String, boolean, List<TopicPartitionInfo>) - Constructor for class org.apache.kafka.clients.admin.TopicDescription
-
Create an instance with the specified parameters.
- TopicDescription(String, boolean, List<TopicPartitionInfo>, Set<AclOperation>) - Constructor for class org.apache.kafka.clients.admin.TopicDescription
-
Create an instance with the specified parameters.
- TopicExistsException - Exception in org.apache.kafka.common.errors
-
- TopicExistsException(String) - Constructor for exception org.apache.kafka.common.errors.TopicExistsException
-
- TopicExistsException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.TopicExistsException
-
- topicGroupId - Variable in class org.apache.kafka.streams.processor.TaskId
-
The ID of the topic group.
- TopicListing - Class in org.apache.kafka.clients.admin
-
A listing of a topic in the cluster.
- TopicListing(String, boolean) - Constructor for class org.apache.kafka.clients.admin.TopicListing
-
Create an instance with the specified parameters.
- TopicNameExtractor<K,V> - Interface in org.apache.kafka.streams.processor
-
An interface that allows to dynamically determine the name of the Kafka topic to send at the sink node of the topology.
- topicNameExtractor() - Method in interface org.apache.kafka.streams.TopologyDescription.Sink
-
The
TopicNameExtractor
class that this sink node uses to dynamically extract the topic name to write to.
- TopicPartition - Class in org.apache.kafka.common
-
A topic name and partition number
- TopicPartition(String, int) - Constructor for class org.apache.kafka.common.TopicPartition
-
- topicPartition() - Method in class org.apache.kafka.connect.mirror.Checkpoint
-
- TopicPartitionInfo - Class in org.apache.kafka.common
-
A class containing leadership, replicas and ISR information for a topic partition.
- TopicPartitionInfo(int, Node, List<Node>, List<Node>) - Constructor for class org.apache.kafka.common.TopicPartitionInfo
-
Create an instance of this class with the provided parameters.
- TopicPartitionReplica - Class in org.apache.kafka.common
-
The topic name, partition number and the brokerId of the replica
- TopicPartitionReplica(String, int, int) - Constructor for class org.apache.kafka.common.TopicPartitionReplica
-
- topicPartitions(List<TopicPartition>) - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsOptions
-
Set the topic partitions to list as part of the result.
- topicPartitions() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsOptions
-
Returns a list of topic partitions to add as part of the result.
- topicPartitions() - Method in class org.apache.kafka.clients.admin.MemberAssignment
-
The topic partitions assigned to a group member.
- topicPartitions() - Method in class org.apache.kafka.streams.processor.TaskMetadata
-
- topicPartitions() - Method in class org.apache.kafka.streams.state.StreamsMetadata
-
- topicPattern() - Method in interface org.apache.kafka.streams.TopologyDescription.Source
-
The pattern used to match topic names that is reading from.
- topicPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
-
Prefix a property with
StreamsConfig.TOPIC_PREFIX
used to provide default topic configs to be applied when creating internal topics.
- topics() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
-
- topics() - Method in class org.apache.kafka.common.Cluster
-
Get all topics.
- topics() - Method in interface org.apache.kafka.streams.TopologyDescription.Source
-
- TOPICS_CONFIG - Static variable in class org.apache.kafka.connect.sink.SinkConnector
-
Configuration key for the list of input topics for this connector.
- TOPICS_CONFIG - Static variable in class org.apache.kafka.connect.sink.SinkTask
-
The configuration key that provides the list of topics that are inputs for this
SinkTask.
- TOPICS_REGEX_CONFIG - Static variable in class org.apache.kafka.connect.sink.SinkTask
-
The configuration key that provides a regex specifying which topics to include as inputs
for this SinkTask.
- topicSet() - Method in interface org.apache.kafka.streams.TopologyDescription.Source
-
The topic names this source node is reading from.
- topicSource(String) - Method in class org.apache.kafka.connect.mirror.DefaultReplicationPolicy
-
- topicSource(String) - Method in interface org.apache.kafka.connect.mirror.ReplicationPolicy
-
Source cluster alias of given remote topic, e.g.
- Topology - Class in org.apache.kafka.streams
-
A logical representation of a ProcessorTopology
.
- Topology() - Constructor for class org.apache.kafka.streams.Topology
-
- Topology.AutoOffsetReset - Enum in org.apache.kafka.streams
-
- TOPOLOGY_OPTIMIZATION - Static variable in class org.apache.kafka.streams.StreamsConfig
-
topology.optimization
- TopologyDescription - Interface in org.apache.kafka.streams
-
- TopologyDescription.GlobalStore - Interface in org.apache.kafka.streams
-
- TopologyDescription.Node - Interface in org.apache.kafka.streams
-
A node of a topology.
- TopologyDescription.Processor - Interface in org.apache.kafka.streams
-
A processor node of a topology.
- TopologyDescription.Sink - Interface in org.apache.kafka.streams
-
A sink node of a topology.
- TopologyDescription.Source - Interface in org.apache.kafka.streams
-
A source node of a topology.
- TopologyDescription.Subtopology - Interface in org.apache.kafka.streams
-
- TopologyException - Exception in org.apache.kafka.streams.errors
-
Indicates a pre run time error occurred while parsing the
logical topology
to construct the
physical processor topology
.
- TopologyException(String) - Constructor for exception org.apache.kafka.streams.errors.TopologyException
-
- TopologyException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TopologyException
-
- TopologyException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TopologyException
-
- TopologyTestDriver - Class in org.apache.kafka.streams
-
This class makes it easier to write tests to verify the behavior of topologies created with
Topology
or
StreamsBuilder
.
- TopologyTestDriver(Topology, Properties) - Constructor for class org.apache.kafka.streams.TopologyTestDriver
-
Create a new test diver instance.
- TopologyTestDriver(Topology, Properties, long) - Constructor for class org.apache.kafka.streams.TopologyTestDriver
-
- TopologyTestDriver(Topology, Properties, Instant) - Constructor for class org.apache.kafka.streams.TopologyTestDriver
-
Create a new test diver instance.
- toRst() - Method in class org.apache.kafka.common.config.ConfigDef
-
Get the configs formatted with reStructuredText, suitable for embedding in Sphinx
documentation.
- toStream() - Method in interface org.apache.kafka.streams.kstream.KTable
-
Convert this changelog stream to a
KStream
.
- toStream(Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Convert this changelog stream to a
KStream
.
- toStream(KeyValueMapper<? super K, ? super V, ? extends KR>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- toStream(KeyValueMapper<? super K, ? super V, ? extends KR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- toString() - Method in class org.apache.kafka.clients.admin.AlterConfigOp
-
- toString() - Method in class org.apache.kafka.clients.admin.Config
-
- toString() - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
-
- toString() - Method in class org.apache.kafka.clients.admin.ConfigEntry
-
- toString() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
-
- toString() - Method in class org.apache.kafka.clients.admin.ConsumerGroupListing
-
- toString() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
-
- toString() - Method in class org.apache.kafka.clients.admin.MemberAssignment
-
- toString() - Method in class org.apache.kafka.clients.admin.MemberDescription
-
- toString() - Method in class org.apache.kafka.clients.admin.NewPartitions
-
- toString() - Method in class org.apache.kafka.clients.admin.NewTopic
-
- toString() - Method in class org.apache.kafka.clients.admin.PartitionReassignment
-
- toString() - Method in class org.apache.kafka.clients.admin.RecordsToDelete
-
- toString() - Method in class org.apache.kafka.clients.admin.TopicDescription
-
- toString() - Method in class org.apache.kafka.clients.admin.TopicListing
-
- toString() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Assignment
-
- toString() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
- toString() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
-
- toString() - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
-
- toString() - Method in class org.apache.kafka.clients.producer.ProducerRecord
-
- toString() - Method in class org.apache.kafka.clients.producer.RecordMetadata
-
- toString() - Method in class org.apache.kafka.common.acl.AccessControlEntry
-
- toString() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
-
- toString() - Method in class org.apache.kafka.common.acl.AclBinding
-
- toString() - Method in class org.apache.kafka.common.acl.AclBindingFilter
-
- toString() - Method in class org.apache.kafka.common.Cluster
-
- toString() - Method in class org.apache.kafka.common.ClusterResource
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.CaseInsensitiveValidString
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.CompositeValidator
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.LambdaValidator
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.NonEmptyString
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.NonEmptyStringWithoutControlChars
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.NonNullValidator
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.Range
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.ValidList
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.ValidString
-
- toString() - Method in class org.apache.kafka.common.config.ConfigResource
-
- toString() - Method in class org.apache.kafka.common.config.ConfigValue
-
- toString() - Method in enum org.apache.kafka.common.ConsumerGroupState
-
- toString() - Method in class org.apache.kafka.common.Endpoint
-
- toString() - Method in class org.apache.kafka.common.MetricName
-
- toString() - Method in class org.apache.kafka.common.MetricNameTemplate
-
- toString() - Method in class org.apache.kafka.common.Node
-
- toString() - Method in class org.apache.kafka.common.PartitionInfo
-
- toString() - Method in class org.apache.kafka.common.resource.Resource
-
- toString() - Method in class org.apache.kafka.common.resource.ResourceFilter
-
- toString() - Method in class org.apache.kafka.common.resource.ResourcePattern
-
- toString() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
-
- toString() - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
-
- toString() - Method in class org.apache.kafka.common.security.auth.SaslExtensions
-
- toString() - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
-
- toString() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- toString() - Method in class org.apache.kafka.common.TopicPartition
-
- toString() - Method in class org.apache.kafka.common.TopicPartitionInfo
-
- toString() - Method in class org.apache.kafka.common.TopicPartitionReplica
-
- toString() - Method in class org.apache.kafka.connect.connector.ConnectRecord
-
- toString() - Method in class org.apache.kafka.connect.data.ConnectSchema
-
- toString() - Method in class org.apache.kafka.connect.data.Field
-
- toString() - Method in class org.apache.kafka.connect.data.SchemaAndValue
-
- toString() - Method in class org.apache.kafka.connect.data.Struct
-
- toString() - Method in class org.apache.kafka.connect.header.ConnectHeaders
-
- toString() - Method in class org.apache.kafka.connect.health.ConnectorHealth
-
- toString() - Method in class org.apache.kafka.connect.health.ConnectorState
-
- toString() - Method in enum org.apache.kafka.connect.health.ConnectorType
-
- toString() - Method in class org.apache.kafka.connect.health.TaskState
-
- toString() - Method in class org.apache.kafka.connect.mirror.Checkpoint
-
- toString() - Method in class org.apache.kafka.connect.mirror.Heartbeat
-
- toString() - Method in class org.apache.kafka.connect.mirror.SourceAndTarget
-
- toString() - Method in class org.apache.kafka.connect.sink.SinkRecord
-
- toString() - Method in class org.apache.kafka.connect.source.SourceRecord
-
- toString() - Method in class org.apache.kafka.server.authorizer.Action
-
- toString() - Method in class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
-
- toString() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
-
- toString() - Method in class org.apache.kafka.streams.KeyValue
-
- toString() - Method in class org.apache.kafka.streams.kstream.JoinWindows
-
- toString() - Method in class org.apache.kafka.streams.kstream.SessionWindows
-
- toString() - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
- toString() - Method in class org.apache.kafka.streams.kstream.TimeWindows
-
- toString() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
- toString() - Method in class org.apache.kafka.streams.kstream.Window
-
- toString() - Method in class org.apache.kafka.streams.kstream.Windowed
-
- toString() - Method in class org.apache.kafka.streams.processor.MockProcessorContext.CapturedForward
-
- toString() - Method in class org.apache.kafka.streams.processor.TaskId
-
- toString() - Method in class org.apache.kafka.streams.processor.TaskMetadata
-
- toString() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
-
- toString() - Method in class org.apache.kafka.streams.state.HostInfo
-
- toString() - Method in class org.apache.kafka.streams.state.StreamsMetadata
-
- toString() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
-
- toString() - Method in class org.apache.kafka.streams.test.TestRecord
-
- toString() - Method in class org.apache.kafka.streams.TestInputTopic
-
- toString() - Method in class org.apache.kafka.streams.TestOutputTopic
-
- toSysOut() - Static method in class org.apache.kafka.streams.kstream.Printed
-
Print the records of a
KStream
to system out.
- totalCount() - Method in class org.apache.kafka.clients.admin.NewPartitions
-
The total number of partitions after the operation succeeds.
- TRACE_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
-
The TRACE
level designates finer-grained
informational events than the DEBUG
level.
- traceMessage() - Method in class org.apache.kafka.connect.health.AbstractState
-
The error message associated with the connector or task.
- TRANSACTION_TIMEOUT_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
transaction.timeout.ms
- TRANSACTION_TIMEOUT_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
- transactionAborted() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- TRANSACTIONAL_ID_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
transactional.id
- TRANSACTIONAL_ID_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
- TransactionalIdAuthorizationException - Exception in org.apache.kafka.common.errors
-
- TransactionalIdAuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.TransactionalIdAuthorizationException
-
- transactionCommitted() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- TransactionCoordinatorFencedException - Exception in org.apache.kafka.common.errors
-
- TransactionCoordinatorFencedException(String) - Constructor for exception org.apache.kafka.common.errors.TransactionCoordinatorFencedException
-
- TransactionCoordinatorFencedException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.TransactionCoordinatorFencedException
-
- transactionInFlight() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- transactionInitialized() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- transform(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigTransformer
-
Transforms the given configuration data by using the
ConfigProvider
instances to
look up values to replace the variables in the pattern.
- transform(TransformerSupplier<? super K, ? super V, KeyValue<K1, V1>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into zero or one record in the output stream (both key and value type
can be altered arbitrarily).
- transform(TransformerSupplier<? super K, ? super V, KeyValue<K1, V1>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform each record of the input stream into zero or one record in the output stream (both key and value type
can be altered arbitrarily).
- transform(K, V) - Method in interface org.apache.kafka.streams.kstream.Transformer
-
Transform the record with the given key and value.
- transform(V) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
-
Transform the given value to a new value.
- transform(K, V) - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKey
-
Transform the given [key and ]value to a new value.
- Transformation<R extends ConnectRecord<R>> - Interface in org.apache.kafka.connect.transforms
-
Single message transformation for Kafka Connect record types.
- Transformer<K,V,R> - Interface in org.apache.kafka.streams.kstream
-
The Transformer
interface is for stateful mapping of an input record to zero, one, or multiple new output
records (both key and value type can be altered arbitrarily).
- TransformerSupplier<K,V,R> - Interface in org.apache.kafka.streams.kstream
-
A
TransformerSupplier
interface which can create one or more
Transformer
instances.
- transformValues(ValueTransformerSupplier<? super V, ? extends VR>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into a new value (with possibly a new type) of the output record.
- transformValues(ValueTransformerSupplier<? super V, ? extends VR>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into a new value (with possibly a new type) of the output record.
- transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into a new value (with possibly a new type) of the output record.
- transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Transform the value of each input record into a new value (with possibly a new type) of the output record.
- transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
by transforming the value of each record in this KTable
into a new value
(with possibly a new type), with default serializers, deserializers, and state store.
- transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Create a new KTable
by transforming the value of each record in this KTable
into a new value
(with possibly a new type), with default serializers, deserializers, and state store.
- transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
-
- translateOffsets(Map<String, Object>, String, String, Duration) - Static method in class org.apache.kafka.connect.mirror.RemoteClusterUtils
-
Translate a remote consumer group's offsets into corresponding local offsets.
- ttl() - Method in class org.apache.kafka.common.config.ConfigData
-
Returns the TTL (in milliseconds).
- ttls() - Method in class org.apache.kafka.common.config.ConfigTransformerResult
-
Returns the TTL values (in milliseconds) returned from the ConfigProvider instances for a given set of paths.
- type - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- type() - Method in class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- type() - Method in class org.apache.kafka.common.config.ConfigResource
-
Return the resource type.
- type() - Method in class org.apache.kafka.connect.data.ConnectSchema
-
- type() - Method in interface org.apache.kafka.connect.data.Schema
-
- type() - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
- type(Schema.Type) - Static method in class org.apache.kafka.connect.data.SchemaBuilder
-
Create a SchemaBuilder for the specified type.
- type() - Method in class org.apache.kafka.connect.health.ConnectorHealth
-
Provides the type of the connector.
- type() - Method in class org.apache.kafka.connect.storage.ConverterConfig
-
- TYPE_CONFIG - Static variable in class org.apache.kafka.connect.storage.ConverterConfig
-
- typeOf(String) - Method in class org.apache.kafka.common.config.AbstractConfig
-
- valid() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsResult
-
Returns a future which yields just the valid listings.
- valid(String) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
-
Validates a specific extension in the original inputExtensions
map
- VALID_LOG_LEVELS - Static variable in class org.apache.kafka.common.config.LogLevelConfig
-
- validate(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
-
Validate the current configuration values with the configuration definition.
- validate(Map<String, String>) - Method in class org.apache.kafka.connect.connector.Connector
-
Validate the connector configuration values against configuration definitions.
- validate(ConnectorClientConfigRequest) - Method in interface org.apache.kafka.connect.connector.policy.ConnectorClientConfigOverridePolicy
-
Worker will invoke this while constructing the producer for the SourceConnectors, DLQ for SinkConnectors and the consumer for the
SinkConnectors to validate if all of the overridden client configurations are allowed per the
policy implementation.
- validate() - Method in class org.apache.kafka.connect.data.Struct
-
Validates that this struct has filled in all the necessary data with valid values.
- validate(AlterConfigPolicy.RequestMetadata) - Method in interface org.apache.kafka.server.policy.AlterConfigPolicy
-
Validate the request parameters and throw a PolicyViolationException
with a suitable error
message if the alter configs request parameters for the provided resource do not satisfy this policy.
- validate(CreateTopicPolicy.RequestMetadata) - Method in interface org.apache.kafka.server.policy.CreateTopicPolicy
-
Validate the request parameters and throw a PolicyViolationException
with a suitable error
message if the create topics request parameters for the provided topic do not satisfy this policy.
- validate(String) - Static method in class org.apache.kafka.streams.kstream.Named
-
- validateAll(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
-
- validatedExtensions() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
-
- validateOnly(boolean) - Method in class org.apache.kafka.clients.admin.AlterConfigsOptions
-
Set to true if the request should be validated without altering the configs.
- validateOnly() - Method in class org.apache.kafka.clients.admin.CreatePartitionsOptions
-
Return true if the request should be validated without creating new partitions.
- validateOnly(boolean) - Method in class org.apache.kafka.clients.admin.CreatePartitionsOptions
-
Set to true if the request should be validated without creating new partitions.
- validateOnly(boolean) - Method in class org.apache.kafka.clients.admin.CreateTopicsOptions
-
Set to true if the request should be validated without creating the topic.
- validateReconfiguration(Map<String, ?>) - Method in interface org.apache.kafka.common.Reconfigurable
-
Validates the provided configuration.
- validateValue(Schema, Object) - Static method in class org.apache.kafka.connect.data.ConnectSchema
-
Validate that the value can be used with the schema, i.e.
- validateValue(String, Schema, Object) - Static method in class org.apache.kafka.connect.data.ConnectSchema
-
- validateValue(Object) - Method in class org.apache.kafka.connect.data.ConnectSchema
-
Validate that the value can be used for this schema, i.e.
- validator - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- validValues(String, Map<String, Object>) - Method in interface org.apache.kafka.common.config.ConfigDef.Recommender
-
The valid values for the configuration given the current configuration values.
- value() - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
-
Returns the value of this configuration, which may be null if the configuration is sensitive.
- value() - Method in class org.apache.kafka.clients.admin.ConfigEntry
-
Return the value or null.
- value() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The value
- value() - Method in class org.apache.kafka.clients.producer.ProducerRecord
-
- value() - Method in class org.apache.kafka.common.config.ConfigValue
-
- value(Object) - Method in class org.apache.kafka.common.config.ConfigValue
-
- value - Variable in enum org.apache.kafka.common.ElectionType
-
- value() - Method in interface org.apache.kafka.common.header.Header
-
- value() - Method in interface org.apache.kafka.common.Metric
-
- value() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
-
- value() - Method in class org.apache.kafka.connect.connector.ConnectRecord
-
- value() - Method in class org.apache.kafka.connect.data.SchemaAndValue
-
- value() - Method in interface org.apache.kafka.connect.header.Header
-
Get the header's value as deserialized by Connect's header converter.
- value - Variable in class org.apache.kafka.streams.KeyValue
-
The value of the key-value pair.
- value() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
-
- value() - Method in class org.apache.kafka.streams.test.TestRecord
-
- VALUE_DESERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
value.deserializer
- VALUE_DESERIALIZER_CLASS_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- VALUE_SCHEMA_V0 - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
-
- VALUE_SCHEMA_V0 - Static variable in class org.apache.kafka.connect.mirror.Heartbeat
-
- VALUE_SERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
value.serializer
- VALUE_SERIALIZER_CLASS_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
- ValueAndTimestamp<V> - Class in org.apache.kafka.streams.state
-
Combines a value from a
KeyValue
with a timestamp.
- valueDeserializer() - Method in class org.apache.kafka.streams.state.StateSerdes
-
Return the value deserializer.
- valueFrom(byte[]) - Method in class org.apache.kafka.streams.state.StateSerdes
-
Deserialize the value from raw bytes.
- ValueJoiner<V1,V2,VR> - Interface in org.apache.kafka.streams.kstream
-
The ValueJoiner
interface for joining two values into a new value of arbitrary type.
- ValueMapper<V,VR> - Interface in org.apache.kafka.streams.kstream
-
The ValueMapper
interface for mapping a value to a new value of arbitrary type.
- ValueMapperWithKey<K,V,VR> - Interface in org.apache.kafka.streams.kstream
-
The ValueMapperWithKey
interface for mapping a value to a new value of arbitrary type.
- valueOf(String) - Static method in enum org.apache.kafka.clients.admin.AlterConfigOp.OpType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.consumer.OffsetResetStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.acl.AclOperation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.acl.AclPermissionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.config.ConfigDef.Importance
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.config.ConfigDef.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.config.ConfigDef.Width
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.config.ConfigResource.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.config.SslClientAuth
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.ConsumerGroupState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.ElectionType
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum org.apache.kafka.common.ElectionType
-
- valueOf(String) - Static method in enum org.apache.kafka.common.resource.PatternType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.resource.ResourceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.connect.data.Schema.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.connect.health.ConnectorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.connect.storage.ConverterType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.server.authorizer.AuthorizationResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.server.quota.ClientQuotaType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.streams.KafkaStreams.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.streams.processor.PunctuationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.streams.Topology.AutoOffsetReset
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.kafka.clients.admin.AlterConfigOp.OpType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.kafka.clients.admin.AlterConfigsResult
-
Return a map from resources to futures which can be used to check the status of the operation on each resource.
- values() - Method in class org.apache.kafka.clients.admin.AlterPartitionReassignmentsResult
-
Return a map from partitions to futures which can be used to check the status of the reassignment.
- values() - Method in class org.apache.kafka.clients.admin.AlterReplicaLogDirsResult
-
Return a map from replica to future which can be used to check the status of individual replica movement.
- values() - Static method in enum org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.kafka.clients.admin.CreateAclsResult
-
Return a map from ACL bindings to futures which can be used to check the status of the creation of each ACL
binding.
- values() - Method in class org.apache.kafka.clients.admin.CreatePartitionsResult
-
Return a map from topic names to futures, which can be used to check the status of individual
partition creations.
- values() - Method in class org.apache.kafka.clients.admin.CreateTopicsResult
-
Return a map from topic names to futures, which can be used to check the status of individual
topic creations.
- values() - Method in class org.apache.kafka.clients.admin.DeleteAclsResult.FilterResults
-
Return a list of delete ACLs results for a given filter.
- values() - Method in class org.apache.kafka.clients.admin.DeleteAclsResult
-
Return a map from acl filters to futures which can be used to check the status of the deletions by each
filter.
- values() - Method in class org.apache.kafka.clients.admin.DeleteTopicsResult
-
Return a map from topic names to futures which can be used to check the status of
individual deletions.
- values() - Method in class org.apache.kafka.clients.admin.DescribeAclsResult
-
Return a future containing the ACLs requested.
- values() - Method in class org.apache.kafka.clients.admin.DescribeConfigsResult
-
Return a map from resources to futures which can be used to check the status of the configuration for each
resource.
- values() - Method in class org.apache.kafka.clients.admin.DescribeLogDirsResult
-
Return a map from brokerId to future which can be used to check the information of partitions on each individual broker
- values() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult
-
Return a map from replica to future which can be used to check the log directory information of individual replicas
- values() - Method in class org.apache.kafka.clients.admin.DescribeTopicsResult
-
Return a map from topic names to futures which can be used to check the status of
individual topics.
- values() - Static method in enum org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.clients.consumer.OffsetResetStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.acl.AclOperation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.acl.AclPermissionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.kafka.common.config.AbstractConfig
-
- values() - Static method in enum org.apache.kafka.common.config.ConfigDef.Importance
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.config.ConfigDef.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.config.ConfigDef.Width
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.config.ConfigResource.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- VALUES - Static variable in enum org.apache.kafka.common.config.SslClientAuth
-
- values() - Static method in enum org.apache.kafka.common.config.SslClientAuth
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.ConsumerGroupState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.ElectionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.resource.PatternType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.resource.ResourceType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.connect.data.Schema.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- Values - Class in org.apache.kafka.connect.data
-
Utility for converting from one Connect value to a different form.
- Values() - Constructor for class org.apache.kafka.connect.data.Values
-
- values() - Static method in enum org.apache.kafka.connect.health.ConnectorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.connect.storage.ConverterType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.server.authorizer.AuthorizationResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.server.quota.ClientQuotaType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.streams.KafkaStreams.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.streams.processor.PunctuationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.streams.Topology.AutoOffsetReset
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- Values.Parser - Class in org.apache.kafka.connect.data
-
- Values.SchemaDetector - Class in org.apache.kafka.connect.data
-
- valueSchema() - Method in class org.apache.kafka.connect.connector.ConnectRecord
-
- valueSchema() - Method in class org.apache.kafka.connect.data.ConnectSchema
-
- valueSchema() - Method in interface org.apache.kafka.connect.data.Schema
-
Get the value schema for this map or array schema.
- valueSchema() - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
- valueSerde - Variable in class org.apache.kafka.streams.kstream.Consumed
-
- valueSerde - Variable in class org.apache.kafka.streams.kstream.Grouped
-
- valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Grouped
-
Create a
Grouped
instance with the provided valueSerde.
- valueSerde - Variable in class org.apache.kafka.streams.kstream.Joined
-
- valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Joined
-
Create an instance of
Joined
with a value
Serde
.
- valueSerde() - Method in class org.apache.kafka.streams.kstream.Joined
-
- valueSerde - Variable in class org.apache.kafka.streams.kstream.Materialized
-
- valueSerde - Variable in class org.apache.kafka.streams.kstream.Produced
-
- valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Produced
-
Create a Produced instance with provided valueSerde.
- valueSerde - Variable in class org.apache.kafka.streams.kstream.Serialized
-
Deprecated.
- valueSerde - Variable in class org.apache.kafka.streams.kstream.StreamJoined
-
- valueSerde() - Method in class org.apache.kafka.streams.processor.MockProcessorContext
-
- valueSerde() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Returns the default value serde
- valueSerde() - Method in class org.apache.kafka.streams.state.StateSerdes
-
Return the value serde.
- valueSerializer() - Method in class org.apache.kafka.streams.state.StateSerdes
-
Return the value serializer.
- valuesWithPrefixAllOrNothing(String) - Method in class org.apache.kafka.common.config.AbstractConfig
-
If at least one key with prefix
exists, all prefixed values will be parsed and put into map.
- valuesWithPrefixOverride(String) - Method in class org.apache.kafka.common.config.AbstractConfig
-
Put all keys that do not start with prefix
and their parsed values in the result map and then
put all the remaining keys with the prefix stripped and their parsed values in the result map.
- ValueTransformer<V,VR> - Interface in org.apache.kafka.streams.kstream
-
The ValueTransformer
interface for stateful mapping of a value to a new value (with possible new type).
- ValueTransformerSupplier<V,VR> - Interface in org.apache.kafka.streams.kstream
-
A
ValueTransformerSupplier
interface which can create one or more
ValueTransformer
instances.
- ValueTransformerWithKey<K,V,VR> - Interface in org.apache.kafka.streams.kstream
-
The ValueTransformerWithKey
interface for stateful mapping of a value to a new value (with possible new type).
- ValueTransformerWithKeySupplier<K,V,VR> - Interface in org.apache.kafka.streams.kstream
-
- version() - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
-
Return the version of the assignor which indicates how the user metadata encodings
and the assignment algorithm gets evolved.
- version() - Method in interface org.apache.kafka.connect.components.Versioned
-
Get the version of this component.
- version() - Method in interface org.apache.kafka.connect.connector.Task
-
Get the version of this task.
- version() - Method in class org.apache.kafka.connect.data.ConnectSchema
-
- version() - Method in interface org.apache.kafka.connect.data.Schema
-
Get the optional version of the schema.
- version() - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
- version(Integer) - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Set the version of this schema.
- VERSION - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
-
- VERSION - Static variable in class org.apache.kafka.connect.mirror.Heartbeat
-
- VERSION_KEY - Static variable in class org.apache.kafka.connect.mirror.Checkpoint
-
- VERSION_KEY - Static variable in class org.apache.kafka.connect.mirror.Heartbeat
-
- Versioned - Interface in org.apache.kafka.connect.components
-
Connect requires some components implement this interface to define a version string.
- visible(String, Map<String, Object>) - Method in interface org.apache.kafka.common.config.ConfigDef.Recommender
-
Set the visibility of the configuration given the current configuration values.
- visible() - Method in class org.apache.kafka.common.config.ConfigValue
-
- visible(boolean) - Method in class org.apache.kafka.common.config.ConfigValue
-
- wakeup() - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- wakeup() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Wakeup the consumer.
- wakeup() - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- WakeupException - Exception in org.apache.kafka.common.errors
-
Exception used to indicate preemption of a blocking operation by an external thread.
- WakeupException() - Constructor for exception org.apache.kafka.common.errors.WakeupException
-
- WallclockTimestampExtractor - Class in org.apache.kafka.streams.processor
-
- WallclockTimestampExtractor() - Constructor for class org.apache.kafka.streams.processor.WallclockTimestampExtractor
-
- WARN_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
-
The WARN
level designates potentially harmful situations.
- whenComplete(KafkaFuture.BiConsumer<? super T, ? super Throwable>) - Method in class org.apache.kafka.common.KafkaFuture
-
Returns a new KafkaFuture with the same result or exception as this future, that executes the given action
when this future completes.
- width - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- WILDCARD_RESOURCE - Static variable in class org.apache.kafka.common.resource.ResourcePattern
-
A special literal resource name that corresponds to 'all resources of a certain type'.
- Window - Class in org.apache.kafka.streams.kstream
-
A single window instance, defined by its start and end timestamp.
- Window(long, long) - Constructor for class org.apache.kafka.streams.kstream.Window
-
Create a new window for the given start and end time.
- window() - Method in class org.apache.kafka.streams.kstream.Windowed
-
Return the window containing the values associated with this key.
- WINDOW_STORE_CHANGE_LOG_ADDITIONAL_RETENTION_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
windowstore.changelog.additional.retention.ms
- WindowBytesStoreSupplier - Interface in org.apache.kafka.streams.state
-
- Windowed<K> - Class in org.apache.kafka.streams.kstream
-
The result key type of a windowed stream aggregation.
- Windowed(K, Window) - Constructor for class org.apache.kafka.streams.kstream.Windowed
-
- windowedBy(Windows<W>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
- windowedBy(SessionWindows) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
-
- WindowedSerdes - Class in org.apache.kafka.streams.kstream
-
- WindowedSerdes() - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes
-
- WindowedSerdes.SessionWindowedSerde<T> - Class in org.apache.kafka.streams.kstream
-
- WindowedSerdes.TimeWindowedSerde<T> - Class in org.apache.kafka.streams.kstream
-
- Windows<W extends Window> - Class in org.apache.kafka.streams.kstream
-
The window specification for fixed size windows that is used to define window boundaries and grace period.
- Windows() - Constructor for class org.apache.kafka.streams.kstream.Windows
-
- windowsFor(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
-
Not supported by JoinWindows
.
- windowsFor(long) - Method in class org.apache.kafka.streams.kstream.TimeWindows
-
- windowsFor(long) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
- windowsFor(long) - Method in class org.apache.kafka.streams.kstream.Windows
-
Create all windows that contain the provided timestamp, indexed by non-negative window start timestamps.
- windowSize() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
-
The size of the windows (in milliseconds) any store created from this supplier is creating.
- windowStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
-
- WindowStore<K,V> - Interface in org.apache.kafka.streams.state
-
Interface for storing the aggregated values of fixed-size time windows.
- windowStoreBuilder(WindowBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
-
- WindowStoreIterator<V> - Interface in org.apache.kafka.streams.state
-
- with(BiConsumer<String, Object>, Supplier<String>) - Static method in class org.apache.kafka.common.config.ConfigDef.LambdaValidator
-
- with(Schema, Object) - Method in interface org.apache.kafka.connect.header.Header
-
Return a new
Header
object that has the same key but with the supplied value.
- with(Serde<K>, Serde<V>, TimestampExtractor, Topology.AutoOffsetReset) - Static method in class org.apache.kafka.streams.kstream.Consumed
-
Create an instance of
Consumed
with the supplied arguments.
- with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Consumed
-
- with(TimestampExtractor) - Static method in class org.apache.kafka.streams.kstream.Consumed
-
- with(Topology.AutoOffsetReset) - Static method in class org.apache.kafka.streams.kstream.Consumed
-
- with(String, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Grouped
-
Create a
Grouped
instance with the provided name, keySerde, and valueSerde.
- with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Grouped
-
Create a
Grouped
instance with the provided keySerde and valueSerde.
- with(Serde<K>, Serde<V>, Serde<VO>) - Static method in class org.apache.kafka.streams.kstream.Joined
-
Create an instance of
Joined
with key, value, and otherValue
Serde
instances.
- with(Serde<K>, Serde<V>, Serde<VO>, String) - Static method in class org.apache.kafka.streams.kstream.Joined
-
Create an instance of
Joined
with key, value, and otherValue
Serde
instances.
- with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Materialized
-
- with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Produced
-
Create a Produced instance with provided keySerde and valueSerde.
- with(Serde<K>, Serde<V>, StreamPartitioner<? super K, ? super V>) - Static method in class org.apache.kafka.streams.kstream.Produced
-
Create a Produced instance with provided keySerde, valueSerde, and partitioner.
- with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Serialized
-
Deprecated.
Construct a
Serialized
instance with the provided key and value
Serde
s.
- with(long) - Static method in class org.apache.kafka.streams.kstream.SessionWindows
-
- with(Duration) - Static method in class org.apache.kafka.streams.kstream.SessionWindows
-
Create a new window specification with the specified inactivity gap.
- with(WindowBytesStoreSupplier, WindowBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.StreamJoined
-
Creates a StreamJoined instance with the provided store suppliers.
- with(Serde<K>, Serde<V1>, Serde<V2>) - Static method in class org.apache.kafka.streams.kstream.StreamJoined
-
Creates a
StreamJoined
instance with the provided serdes to configure the stores
for the join.
- withBuiltinTypes(String, Class<K>, Class<V>) - Static method in class org.apache.kafka.streams.state.StateSerdes
-
Create a new instance of
StateSerdes
for the given state name and key-/value-type classes.
- withCachingDisabled() - Method in class org.apache.kafka.streams.kstream.Materialized
-
- withCachingDisabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
-
Disable caching on the store.
- withCachingEnabled() - Method in class org.apache.kafka.streams.kstream.Materialized
-
- withCachingEnabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
-
Enable caching on the store.
- withClientSaslSupport() - Method in class org.apache.kafka.common.config.ConfigDef
-
Add standard SASL client configuration options.
- withClientSslSupport() - Method in class org.apache.kafka.common.config.ConfigDef
-
Add standard SSL client configuration options.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Consumed
-
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Grouped
-
Perform the grouping operation using the provided keySerde for serializing the key.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Joined
-
Set the key
Serde
to be used.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Materialized
-
Set the keySerde the materialize
StateStore
will use.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Produced
-
Produce records using the provided keySerde.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Serialized
-
Deprecated.
Construct a
Serialized
instance with the provided key
Serde
.
- withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
Configure with the provided
Serde
for the key
- withKeyValueMapper(KeyValueMapper<? super K, ? super V, String>) - Method in class org.apache.kafka.streams.kstream.Printed
-
Print the records of a
KStream
with the provided
KeyValueMapper
The provided KeyValueMapper's mapped value type must be
String
.
- withLabel(String) - Method in class org.apache.kafka.streams.kstream.Printed
-
Print the records of a
KStream
with the provided label.
- withLoggingDisabled() - Method in class org.apache.kafka.streams.kstream.Materialized
-
Disable change logging for the materialized
StateStore
.
- withLoggingDisabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
-
- withLoggingEnabled(Map<String, String>) - Method in class org.apache.kafka.streams.kstream.Materialized
-
Indicates that a changelog should be created for the store.
- withLoggingEnabled(Map<String, String>) - Method in interface org.apache.kafka.streams.state.StoreBuilder
-
Maintain a changelog for any changes made to the store.
- withMaxBytes(long) - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Set a size constraint on the buffer, the maximum number of bytes it will use.
- withMaxRecords(long) - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Set a size constraint on the buffer in terms of the maximum number of keys it will store.
- withName(String) - Static method in enum org.apache.kafka.connect.storage.ConverterType
-
Find the ConverterType with the given name, using a case-insensitive match.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Consumed
-
Configure the instance of
Consumed
with a processor name.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Grouped
-
Perform the grouping operation with the name for a repartition topic if required.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Joined
-
Set the base name used for all components of the join, this may include any repartition topics
created to complete the join.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Named
-
- withName(String) - Method in class org.apache.kafka.streams.kstream.Printed
-
Print the records of a
KStream
with provided processor name.
- withName(String) - Method in class org.apache.kafka.streams.kstream.Produced
-
- withName(String) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
Set the name to use for the join processor and the repartition topic(s) if required.
- withName(String) - Method in interface org.apache.kafka.streams.kstream.Suppressed
-
Use the specified name for the suppression node in the topology.
- withNoBound() - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
-
Set the buffer to be unconstrained by size (either keys or bytes).
- withOffsetResetPolicy(Topology.AutoOffsetReset) - Method in class org.apache.kafka.streams.kstream.Consumed
-
- withOtherStoreSupplier(WindowBytesStoreSupplier) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
- withOtherValueSerde(Serde<VO>) - Method in class org.apache.kafka.streams.kstream.Joined
-
Set the otherValue
Serde
to be used.
- withOtherValueSerde(Serde<V2>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
Configure with the provided
Serde
for the other value
- withPartitions(Map<TopicPartition, PartitionInfo>) - Method in class org.apache.kafka.common.Cluster
-
Return a copy of this cluster combined with `partitions`.
- withRetention(Duration) - Method in class org.apache.kafka.streams.kstream.Materialized
-
Configure retention period for window and session stores.
- withStoreName(String) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
Sets the base store name to use for both sides of the join.
- withStreamPartitioner(StreamPartitioner<? super K, ? super V>) - Method in class org.apache.kafka.streams.kstream.Produced
-
Produce records using the provided partitioner.
- withThisStoreSupplier(WindowBytesStoreSupplier) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
- withTimestamp(long) - Method in class org.apache.kafka.streams.processor.To
-
Set the timestamp of the output record.
- withTimestampExtractor(TimestampExtractor) - Method in class org.apache.kafka.streams.kstream.Consumed
-
- withUnderlyingMessage(String) - Static method in exception org.apache.kafka.clients.consumer.RetriableCommitFailedException
-
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Consumed
-
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Grouped
-
Perform the grouping operation using the provided valueSerde for serializing the value.
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Joined
-
Set the value
Serde
to be used.
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Materialized
-
Set the valueSerde the materialized
StateStore
will use.
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Produced
-
Produce records using the provided valueSerde.
- withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Serialized
-
Deprecated.
Construct a
Serialized
instance with the provided value
Serde
.
- withValueSerde(Serde<V1>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
-
Configure with the provided
Serde
for this value
- workerId() - Method in class org.apache.kafka.connect.health.AbstractState
-
The identifier of the worker associated with the connector or the task.
- Wrapper(Deserializer<T>) - Constructor for class org.apache.kafka.common.serialization.ExtendedDeserializer.Wrapper
-
Deprecated.
- Wrapper(Serializer<T>) - Constructor for class org.apache.kafka.common.serialization.ExtendedSerializer.Wrapper
-
Deprecated.
- WrapperSerde(Serializer<T>, Deserializer<T>) - Constructor for class org.apache.kafka.common.serialization.Serdes.WrapperSerde
-
- writeTo(DataOutputStream) - Method in class org.apache.kafka.streams.processor.TaskId
-
- writeTo(ByteBuffer) - Method in class org.apache.kafka.streams.processor.TaskId
-