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

A

AbstractProcessor<K,​V> - Class in org.apache.kafka.streams.processor
An abstract implementation of Processor that manages the ProcessorContext instance and provides default no-op implementation of AbstractProcessor.close().
AbstractProcessor() - Constructor for class org.apache.kafka.streams.processor.AbstractProcessor
 
AbstractProcessorContext - Class in org.apache.kafka.streams.processor.internals
 
AbstractProcessorContext(TaskId, StreamsConfig, StreamsMetricsImpl, StateManager, ThreadCache) - Constructor for class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
AbstractRocksDBSegmentedBytesStore<S extends Segment> - Class in org.apache.kafka.streams.state.internals
 
AbstractStoreBuilder<K,​V,​T extends StateStore> - Class in org.apache.kafka.streams.state.internals
 
AbstractStoreBuilder(String, Serde<K>, Serde<V>, Time) - Constructor for class org.apache.kafka.streams.state.internals.AbstractStoreBuilder
 
AbstractStream<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
AbstractStream(AbstractStream<K, V>) - Constructor for class org.apache.kafka.streams.kstream.internals.AbstractStream
 
AbstractTask - Class in org.apache.kafka.streams.processor.internals
 
ACCEPTABLE_RECOVERY_LAG_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
acceptable.recovery.lag
acceptableRecoveryLag - Variable in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration.AssignmentConfigs
 
accepts(StateStore) - Method in interface org.apache.kafka.streams.state.QueryableStoreType
Called when searching for StateStores to see if they match the type expected by implementors of this interface.
accessHintOnCompactionStart() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
ACTIVE - org.apache.kafka.streams.processor.internals.Task.TaskType
 
activeBufferedRecordsSensor(String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.TaskMetrics
 
activeProcessRatioSensor(String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.TaskMetrics
 
activeTaskCount() - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
activeTaskMap() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
 
activeTasks() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
activeTasks() - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
activeTasks() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
 
activeTasks() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
adapt(StateRestoreCallback) - Static method in class org.apache.kafka.streams.processor.internals.StateRestoreCallbackAdapter
 
add(byte[], int, int) - Method in class org.apache.kafka.streams.state.internals.Murmur3.IncrementalHash32
 
add(T) - Method in class org.apache.kafka.streams.processor.internals.QuickUnion
 
addApplicationIdMetric(StreamsMetricsImpl, String) - Static method in class org.apache.kafka.streams.internals.metrics.ClientMetrics
 
addAvgAndMaxLatencyToSensor(Sensor, String, Map<String, String>, String) - Static method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addAvgAndMaxToSensor(Sensor, String, Map<String, String>, String, String, String) - Static method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addAvgAndMinAndMaxToSensor(Sensor, String, Map<String, String>, String, String, String, String) - Static method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addAvgAndSumMetricsToSensor(Sensor, String, Map<String, String>, String, String, String) - Static method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addChild(StreamsGraphNode) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
addChild(ProcessorNode<?, ?>) - Method in class org.apache.kafka.streams.processor.internals.ProcessorNode
 
addChild(ProcessorNode<?, ?>) - Method in class org.apache.kafka.streams.processor.internals.SinkNode
 
addClientLevelImmutableMetric(String, String, Sensor.RecordingLevel, T) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addClientLevelMutableMetric(String, String, Sensor.RecordingLevel, Gauge<T>) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addCommitIdMetric(StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.internals.metrics.ClientMetrics
 
addDirtyEntryFlushListener(String, ThreadCache.DirtyEntryFlushListener) - Method in class org.apache.kafka.streams.state.internals.ThreadCache
Add a listener that is called each time an entry is evicted from the cache or an explicit flush is called
addGlobalStore(StoreBuilder<?>, String, String, Consumed<K, V>, String, ProcessorSupplier<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
addGlobalStore(StoreBuilder<?>, String, String, ConsumedInternal<K, V>, String, ProcessorSupplier<K, V>) - Method in class org.apache.kafka.streams.kstream.internals.InternalStreamsBuilder
 
addGlobalStore(StoreBuilder<?>, String, Deserializer<K>, Deserializer<V>, String, String, ProcessorSupplier<K, V>) - Method in class org.apache.kafka.streams.Topology
Adds a global StateStore to the topology.
addGlobalStore(StoreBuilder<?>, String, Consumed<K, V>, ProcessorSupplier<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
Adds a global StateStore to the topology.
addGlobalStore(StoreBuilder<?>, String, ConsumedInternal<K, V>, ProcessorSupplier<K, V>) - Method in class org.apache.kafka.streams.kstream.internals.InternalStreamsBuilder
 
addGlobalStore(StoreBuilder<?>, String, TimestampExtractor, Deserializer<K>, Deserializer<V>, String, String, ProcessorSupplier<K, V>) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
addGlobalStore(StoreBuilder<?>, String, TimestampExtractor, Deserializer<K>, Deserializer<V>, String, String, ProcessorSupplier<K, V>) - Method in class org.apache.kafka.streams.Topology
Adds a global StateStore to the topology.
addGlobalStore(TopologyDescription.GlobalStore) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopologyDescription
 
addInternalTopic(String, InternalTopicProperties) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
addInvocationRateAndCountToSensor(Sensor, String, Map<String, String>, String) - Static method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addInvocationRateAndCountToSensor(Sensor, String, Map<String, String>, String, String, String) - Static method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addInvocationRateToSensor(Sensor, String, Map<String, String>, String, String) - Static method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addLatencyAndThroughputSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
Deprecated.
addLatencyAndThroughputSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
Deprecated.
since 2.5. Use addLatencyRateTotalSensor() instead.
addLatencyRateTotalSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addLatencyRateTotalSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
Add a latency, rate and total sensor for a specific operation, which will include the following metrics: average latency max latency invocation rate (num.operations / seconds) total invocation count Whenever a user records this sensor via Sensor.record(double) etc, it will be counted as one invocation of the operation, and hence the rate / count metrics will be updated accordingly; and the recorded latency value will be used to update the average / max latency as well.
addMetricsRecorder(RocksDBMetricsRecorder) - Method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetricsRecordingTrigger
 
addMinAndMaxToSensor(Sensor, String, Map<String, String>, String, String, String) - Static method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addNumAliveStreamThreadMetric(StreamsMetricsImpl, Gauge<Integer>) - Static method in class org.apache.kafka.streams.internals.metrics.ClientMetrics
 
addOwnedPartitions(Collection<TopicPartition>, String) - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
addPredecessor(TopologyDescription.Node) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.AbstractNode
 
addPredecessor(TopologyDescription.Node) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Source
 
addPreviousTasksAndOffsetSums(String, Map<TaskId, Long>) - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
addProcessor(String, ProcessorSupplier<?, ?>, String...) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
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.
addRateOfSumAndSumMetricsToSensor(Sensor, String, Map<String, String>, String, String, String) - Static method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addRateOfSumMetricToSensor(Sensor, String, Map<String, String>, String, String) - Static method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addRateTotalSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addRateTotalSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
Add a rate and a total sensor for a specific operation, which will include the following metrics: invocation rate (num.operations / time unit) total invocation count Whenever a user records this sensor via Sensor.record(double) etc, it will be counted as one invocation of the operation, and hence the rate / count metrics will be updated accordingly.
addRecords(TopicPartition, Iterable<ConsumerRecord<byte[], byte[]>>) - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
 
addRecords(TopicPartition, Iterable<ConsumerRecord<byte[], byte[]>>) - Method in class org.apache.kafka.streams.processor.internals.StreamTask
Adds records to queues.
addRecords(TopicPartition, Iterable<ConsumerRecord<byte[], byte[]>>) - Method in interface org.apache.kafka.streams.processor.internals.Task
 
addSensor(String, Sensor.RecordingLevel) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
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 class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addSensor(String, Sensor.RecordingLevel, Sensor...) - Method in interface org.apache.kafka.streams.StreamsMetrics
Generic method to create a sensor with parent sensors.
addSink(String, String, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to the named Kafka topic.
addSink(String, String, Serializer<K>, Serializer<V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to the named Kafka topic.
addSink(String, String, Serializer<K>, Serializer<V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
addSink(String, String, Serializer<K>, Serializer<V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to the named Kafka topic.
addSink(String, String, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to the named Kafka topic, using the supplied partitioner.
addSink(String, TopicNameExtractor<K, V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to Kafka topics based on topicExtractor.
addSink(String, TopicNameExtractor<K, V>, Serializer<K>, Serializer<V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to Kafka topics based on topicExtractor.
addSink(String, TopicNameExtractor<K, V>, Serializer<K>, Serializer<V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
addSink(String, TopicNameExtractor<K, V>, Serializer<K>, Serializer<V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to Kafka topics based on topicExtractor.
addSink(String, TopicNameExtractor<K, V>, StreamPartitioner<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new sink that forwards records from upstream parent processor and/or source nodes to Kafka topics based on topicExtractor, using the supplied partitioner.
addSource(String, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
addSource(String, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forward the records to child processor and/or sink nodes.
addSource(String, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forwards the records to child processor and/or sink nodes.
addSource(String, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor and/or sink nodes.
addSource(TimestampExtractor, String, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
addSource(TimestampExtractor, String, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forward the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forward the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, String, TimestampExtractor, Deserializer<?>, Deserializer<?>, String...) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
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.processor.internals.InternalTopologyBuilder
 
addSource(Topology.AutoOffsetReset, String, TimestampExtractor, Deserializer<?>, Deserializer<?>, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forwards the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, TimestampExtractor, String, String...) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes the named topics and forward the records to child processor and/or sink nodes.
addSource(Topology.AutoOffsetReset, TimestampExtractor, String, Pattern) - Method in class org.apache.kafka.streams.Topology
Add a new source that consumes from topics matching the given pattern and forward the records to child processor and/or sink nodes.
addStateMetric(StreamsMetricsImpl, Gauge<KafkaStreams.State>) - Static method in class org.apache.kafka.streams.internals.metrics.ClientMetrics
 
addStateStore(StoreBuilder<?>) - Method in class org.apache.kafka.streams.kstream.internals.InternalStreamsBuilder
 
addStateStore(StoreBuilder<?>) - Method in class org.apache.kafka.streams.StreamsBuilder
Adds a state store to the underlying Topology.
addStateStore(StoreBuilder<?>, boolean, String...) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
addStateStore(StoreBuilder<?>, String...) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
addStateStore(StoreBuilder<?>, String...) - Method in class org.apache.kafka.streams.Topology
Adds a state store.
addStatistics(String, Statistics) - Method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetricsRecorder
 
addSubtopology(TopologyDescription.Subtopology) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopologyDescription
 
addSuccessor(TopologyDescription.Node) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.AbstractNode
 
addSuccessor(TopologyDescription.Node) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Sink
 
addSumMetricToSensor(Sensor, String, Map<String, String>, String, boolean, String) - Static method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addSumMetricToSensor(Sensor, String, Map<String, String>, String, String) - Static method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addThroughputSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
Deprecated.
addThroughputSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
Deprecated.
since 2.5. Use addRateTotalSensor() instead.
addToBatch(KeyValue<byte[], byte[]>, WriteBatch) - Method in interface org.apache.kafka.streams.state.internals.BatchWritingStore
 
addToBatch(KeyValue<byte[], byte[]>, WriteBatch) - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
addTopologyDescriptionMetric(StreamsMetricsImpl, String) - Static method in class org.apache.kafka.streams.internals.metrics.ClientMetrics
 
addValueMetricToSensor(Sensor, String, Map<String, String>, String, String) - Static method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addVersionMetric(StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.internals.metrics.ClientMetrics
 
ADMIN_CLIENT_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
Prefix used to isolate admin configs from other client configs.
adminClient() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
adminClientId() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
adminClientMetrics() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
 
adminClientMetrics(Admin) - Static method in class org.apache.kafka.streams.processor.internals.ClientUtils
 
adminClientPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
Prefix a property with StreamsConfig.ADMIN_CLIENT_PREFIX.
advanceBy(long) - Method in class org.apache.kafka.streams.kstream.TimeWindows
Deprecated.
advanceBy(Duration) - Method in class org.apache.kafka.streams.kstream.TimeWindows
Return a window definition with the original size, but advance ("hop") the window by the given interval, which specifies by how much a window moves forward relative to the previous one.
advanceMs - Variable in class org.apache.kafka.streams.kstream.TimeWindows
The size of the window's advance interval in milliseconds, i.e., by how much a window moves forward relative to the previous one.
adviseRandomOnOpen() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
after(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Deprecated.
after(Duration) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Changes the end window boundary to timeDifference but keep the start window boundary as is.
afterMs - Variable in class org.apache.kafka.streams.kstream.JoinWindows
Maximum time difference for tuples that are after the join tuple.
aggregate(Initializer<T>, Aggregator<? super K, ? super V, T>, Aggregator<? super K, ? super V, T>) - Method in class org.apache.kafka.streams.kstream.internals.KGroupedTableImpl
 
aggregate(Initializer<T>, Aggregator<? super K, ? super V, T>, Aggregator<? super K, ? super V, T>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KGroupedTableImpl
 
aggregate(Initializer<T>, Aggregator<? super K, ? super V, T>, Merger<? super K, T>) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImpl
 
aggregate(Initializer<T>, Aggregator<? super K, ? super V, T>, Merger<? super K, T>, Named) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImpl
 
aggregate(Initializer<V>) - Method in class org.apache.kafka.streams.kstream.internals.TimeWindowedCogroupedKStreamImpl
 
aggregate(Initializer<V>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedCogroupedKStream
Aggregate the values of records in this stream by the grouped key and defined windows.
aggregate(Initializer<V>, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.TimeWindowedCogroupedKStreamImpl
 
aggregate(Initializer<V>, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedCogroupedKStream
Aggregate the values of records in this stream by the grouped key and defined windows.
aggregate(Initializer<V>, Merger<? super K, V>) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedCogroupedKStreamImpl
 
aggregate(Initializer<V>, Merger<? super K, V>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedCogroupedKStream
Aggregate the values of records in these streams by the grouped key and defined sessions.
aggregate(Initializer<V>, Merger<? super K, V>, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedCogroupedKStreamImpl
 
aggregate(Initializer<V>, Merger<? super K, V>, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedCogroupedKStream
Aggregate the values of records in these streams by the grouped key and defined sessions.
aggregate(Initializer<V>, Merger<? super K, V>, Named) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedCogroupedKStreamImpl
 
aggregate(Initializer<V>, Merger<? super K, V>, Named) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedCogroupedKStream
Aggregate the values of records in these streams by the grouped key and defined sessions.
aggregate(Initializer<V>, Merger<? super K, V>, Named, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedCogroupedKStreamImpl
 
aggregate(Initializer<V>, Merger<? super K, V>, Named, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedCogroupedKStream
Aggregate the values of records in these streams by the grouped key and defined sessions.
aggregate(Initializer<V>, Named) - Method in class org.apache.kafka.streams.kstream.internals.TimeWindowedCogroupedKStreamImpl
 
aggregate(Initializer<V>, Named) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedCogroupedKStream
Aggregate the values of records in this stream by the grouped key and defined windows.
aggregate(Initializer<V>, Named, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.TimeWindowedCogroupedKStreamImpl
 
aggregate(Initializer<V>, Named, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedCogroupedKStream
Aggregate the values of records in this stream by the grouped key and defined windows.
aggregate(Initializer<VOut>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
Aggregate the values of records in these streams by the grouped key.
aggregate(Initializer<VOut>) - Method in class org.apache.kafka.streams.kstream.internals.CogroupedKStreamImpl
 
aggregate(Initializer<VOut>, Materialized<K, VOut, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
Aggregate the values of records in these streams by the grouped key.
aggregate(Initializer<VOut>, Materialized<K, VOut, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.CogroupedKStreamImpl
 
aggregate(Initializer<VOut>, Named) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
Aggregate the values of records in these streams by the grouped key.
aggregate(Initializer<VOut>, Named) - Method in class org.apache.kafka.streams.kstream.internals.CogroupedKStreamImpl
 
aggregate(Initializer<VOut>, Named, Materialized<K, VOut, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
Aggregate the values of records in these streams by the grouped key.
aggregate(Initializer<VOut>, Named, Materialized<K, VOut, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.CogroupedKStreamImpl
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>) - Method in class org.apache.kafka.streams.kstream.internals.TimeWindowedKStreamImpl
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Aggregate the values of records in this stream by the grouped key.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Aggregate the values of records in this stream by the grouped key and defined windows.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
Aggregate the value of records of the original KTable that got mapped to the same key into a new instance of KTable using default serializers and deserializers.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KGroupedTableImpl
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
Aggregate the value of records of the original KTable that got mapped to the same key into a new instance of KTable.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
Aggregate the value of records of the original KTable that got mapped to the same key into a new instance of KTable using default serializers and deserializers.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KGroupedTableImpl
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
Aggregate the value of records of the original KTable that got mapped to the same key into a new instance of KTable.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Aggregate the values of records in this stream by the grouped key.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, WindowStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.TimeWindowedKStreamImpl
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Aggregate the values of records in this stream by the grouped key and defined windows.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
Aggregate the values of records in this stream by the grouped key and defined sessions.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Materialized<K, VR, SessionStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImpl
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Materialized<K, VR, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
Aggregate the values of records in this stream by the grouped key and defined sessions.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
Aggregate the values of records in this stream by the grouped key and defined sessions.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Named, Materialized<K, VR, SessionStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImpl
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Named, Materialized<K, VR, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
Aggregate the values of records in this stream by the grouped key and defined sessions.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named) - Method in class org.apache.kafka.streams.kstream.internals.TimeWindowedKStreamImpl
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Aggregate the values of records in this stream by the grouped key and defined windows.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Aggregate the values of records in this stream by the grouped key.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, WindowStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.TimeWindowedKStreamImpl
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Aggregate the values of records in this stream by the grouped key and defined windows.
Aggregator<K,​V,​VA> - Interface in org.apache.kafka.streams.kstream
The Aggregator interface for aggregating values of the given key.
all() - Static method in class org.apache.kafka.streams.processor.To
Forward the key/value pair to all downstream processors
all() - Method in class org.apache.kafka.streams.state.internals.AbstractRocksDBSegmentedBytesStore
 
all() - Method in class org.apache.kafka.streams.state.internals.CachingKeyValueStore
 
all() - Method in class org.apache.kafka.streams.state.internals.ChangeLoggingKeyValueBytesStore
 
all() - Method in class org.apache.kafka.streams.state.internals.CompositeReadOnlyKeyValueStore
 
all() - Method in class org.apache.kafka.streams.state.internals.CompositeReadOnlyWindowStore
 
all() - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
all() - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowStore
 
all() - Method in class org.apache.kafka.streams.state.internals.KeyValueToTimestampedKeyValueByteStoreAdapter
 
all() - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
all() - Method in class org.apache.kafka.streams.state.internals.MemoryNavigableLRUCache
 
all() - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
all() - Method in class org.apache.kafka.streams.state.internals.MeteredWindowStore
 
all() - Method in class org.apache.kafka.streams.state.internals.ReadOnlyKeyValueStoreFacade
 
all() - Method in class org.apache.kafka.streams.state.internals.ReadOnlyWindowStoreFacade
 
all() - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
all() - Method in class org.apache.kafka.streams.state.internals.RocksDBWindowStore
 
all() - Method in interface org.apache.kafka.streams.state.internals.Segment
 
all() - Method in interface org.apache.kafka.streams.state.internals.SegmentedBytesStore
Gets all the key-value pairs in the existing windows.
all() - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
Return an iterator over all keys in this store.
all() - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
Gets all the key-value pairs in the existing windows.
all(String) - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 
allLocalStorePartitionLags() - Method in class org.apache.kafka.streams.KafkaStreams
Returns LagInfo, for all store partitions (active or standby) local to this Streams instance.
allMetadata() - Method in class org.apache.kafka.streams.KafkaStreams
Find all currently running KafkaStreams instances (potentially remotely) that use the same application ID as this instance (i.e., all instances that belong to the same Kafka Streams application) and return StreamsMetadata for each discovered instance.
allMetadataForStore(String) - Method in class org.apache.kafka.streams.KafkaStreams
Find all currently running KafkaStreams instances (potentially remotely) that use the same application ID as this instance (i.e., all instances that belong to the same Kafka Streams application) and that contain a StateStore with the given storeName and return StreamsMetadata for each discovered instance.
allow2pc() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
allowConcurrentMemtableWrite() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
allowFAllocate() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
allowMmapReads() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
allowMmapWrites() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
allParentsWrittenToTopology() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
allSensor(String, String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.state.internals.metrics.StateStoreMetrics
 
allStateStoreName() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
allTasks() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
 
apiKey() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
ApiUtils - Class in org.apache.kafka.streams.internals
 
appConfigs() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
appConfigs() - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
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.internals.AbstractProcessorContext
 
appConfigsWithPrefix(String) - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
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.
APPLICATION_DIR_ACES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
streams.appdir.permissions}
APPLICATION_ID_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
application.id
APPLICATION_SERVER_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
application.server
applicationId() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
applicationId() - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
applicationId() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the application id.
applicationInternalStream() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
applicationInternalStream() - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
applicationInternalStream() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the application internal stream name
apply() - Method in interface org.apache.kafka.streams.kstream.Initializer
Return the initial value for an aggregation.
apply(List<ThreadCache.DirtyEntry>) - Method in interface org.apache.kafka.streams.state.internals.ThreadCache.DirtyEntryFlushListener
 
apply(K, V) - Method in interface org.apache.kafka.streams.kstream.ForeachAction
Perform an action for each record of a stream.
apply(K, V) - Method in class org.apache.kafka.streams.kstream.internals.PrintForeachAction
 
apply(K, V) - Method in interface org.apache.kafka.streams.kstream.KeyValueMapper
Map a record with the given key and value to a new value.
apply(K, V) - Method in interface org.apache.kafka.streams.kstream.ValueMapperWithKey
Map the given [key and ]value to a new value.
apply(K, V, V) - Method in interface org.apache.kafka.streams.kstream.Merger
Compute a new aggregate from the key and two aggregates.
apply(K, V, VA) - Method in interface org.apache.kafka.streams.kstream.Aggregator
Compute a new aggregate from the key and value of a record and the current aggregate of the same key.
apply(K, V, V, long) - Method in interface org.apache.kafka.streams.state.internals.CacheFlushListener
Called when records are flushed from the ThreadCache
apply(Bytes, byte[]) - Method in interface org.apache.kafka.streams.state.internals.MemoryLRUCache.EldestEntryRemovalListener
 
apply(V) - Method in interface org.apache.kafka.streams.kstream.ValueMapper
Map the given value to a new value.
apply(V1, V2) - Method in interface org.apache.kafka.streams.kstream.ValueJoiner
Return a joined value consisting of value1 and value2.
apply(V, V) - Method in interface org.apache.kafka.streams.kstream.Reducer
Aggregate the two given values into a single one.
approximateNumEntries() - Method in class org.apache.kafka.streams.state.internals.CachingKeyValueStore
 
approximateNumEntries() - Method in class org.apache.kafka.streams.state.internals.ChangeLoggingKeyValueBytesStore
 
approximateNumEntries() - Method in class org.apache.kafka.streams.state.internals.CompositeReadOnlyKeyValueStore
 
approximateNumEntries() - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
approximateNumEntries() - Method in class org.apache.kafka.streams.state.internals.KeyValueToTimestampedKeyValueByteStoreAdapter
 
approximateNumEntries() - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
approximateNumEntries() - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
approximateNumEntries() - Method in class org.apache.kafka.streams.state.internals.ReadOnlyKeyValueStoreFacade
 
approximateNumEntries() - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
Return an approximate count of key-value mappings in this store.
approximateNumEntries() - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
Return an approximate count of key-value mappings in this store.
arenaBlockSize() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
as(String) - Static method in class org.apache.kafka.streams.kstream.Consumed
Create an instance of Consumed with provided processor name.
as(String) - Static method in class org.apache.kafka.streams.kstream.Grouped
Create a Grouped instance with the provided name used as part of the repartition topic if required.
as(String) - Static method in class org.apache.kafka.streams.kstream.Joined
Create an instance of Joined with base name for all components of the join, this may include any repartition topics created to complete the join.
as(String) - Static method in class org.apache.kafka.streams.kstream.Materialized
Materialize a StateStore with the given name.
as(String) - Static method in class org.apache.kafka.streams.kstream.Named
Create a Named instance with provided name.
as(String) - Static method in class org.apache.kafka.streams.kstream.Produced
Create an instance of Produced with provided processor name.
as(String) - Static method in class org.apache.kafka.streams.kstream.Repartitioned
Create a Repartitioned instance with the provided name used as part of the repartition topic.
as(String) - Static method in class org.apache.kafka.streams.kstream.StreamJoined
Creates a StreamJoined instance using the provided name for the state stores and hence the changelog topics for the join stores.
as(KeyValueBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
Materialize a KeyValueStore using the provided KeyValueBytesStoreSupplier.
as(SessionBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
Materialize a SessionStore using the provided SessionBytesStoreSupplier.
as(WindowBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.Materialized
Materialize a WindowStore using the provided WindowBytesStoreSupplier.
assign(Map<UUID, ClientState>, Set<TaskId>, Set<TaskId>, AssignorConfiguration.AssignmentConfigs) - Method in class org.apache.kafka.streams.processor.internals.assignment.FallbackPriorTaskAssignor
 
assign(Map<UUID, ClientState>, Set<TaskId>, Set<TaskId>, AssignorConfiguration.AssignmentConfigs) - Method in class org.apache.kafka.streams.processor.internals.assignment.HighAvailabilityTaskAssignor
 
assign(Map<UUID, ClientState>, Set<TaskId>, Set<TaskId>, AssignorConfiguration.AssignmentConfigs) - Method in class org.apache.kafka.streams.processor.internals.assignment.StickyTaskAssignor
 
assign(Map<UUID, ClientState>, Set<TaskId>, Set<TaskId>, AssignorConfiguration.AssignmentConfigs) - Method in interface org.apache.kafka.streams.processor.internals.assignment.TaskAssignor
 
assign(Cluster, ConsumerPartitionAssignor.GroupSubscription) - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
assignActive(TaskId) - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
assignActiveTasks(Collection<TaskId>) - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
assignedTaskCount() - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
ASSIGNMENT_ERROR_CODE - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
 
ASSIGNMENT_LISTENER - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
 
assignmentConfigs() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
assignmentErrorCode() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
AssignmentInfo - Class in org.apache.kafka.streams.processor.internals.assignment
 
AssignmentInfo(int, int) - Constructor for class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
AssignmentInfo(int, int, List<TaskId>, Map<TaskId, Set<TopicPartition>>, Map<HostInfo, Set<TopicPartition>>, Map<HostInfo, Set<TopicPartition>>, int) - Constructor for class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
AssignmentInfo(int, List<TaskId>, Map<TaskId, Set<TopicPartition>>, Map<HostInfo, Set<TopicPartition>>, Map<HostInfo, Set<TopicPartition>>, int) - Constructor for class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
assignmentListener() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
AssignorConfiguration - Class in org.apache.kafka.streams.processor.internals.assignment
 
AssignorConfiguration(Map<String, ?>) - Constructor for class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
AssignorConfiguration.AssignmentConfigs - Class in org.apache.kafka.streams.processor.internals.assignment
 
AssignorConfiguration.AssignmentListener - Interface in org.apache.kafka.streams.processor.internals.assignment
 
AssignorError - Enum in org.apache.kafka.streams.processor.internals.assignment
 
assignStandby(TaskId) - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
AT_LEAST_ONCE - org.apache.kafka.streams.processor.internals.StreamThread.ProcessingMode
 
AT_LEAST_ONCE - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "processing.guarantee" for at-least-once processing guarantees.
AVG_LATENCY_DESCRIPTION - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
AVG_SUFFIX - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
avoidFlushDuringRecovery() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
avoidFlushDuringShutdown() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 

B

baseBackgroundCompactions() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
baseDir() - Method in class org.apache.kafka.streams.processor.internals.GlobalStateManagerImpl
 
baseDir() - Method in class org.apache.kafka.streams.processor.internals.ProcessorStateManager
 
BaseRepartitionNode<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
 
BaseRepartitionNode.BaseRepartitionNodeBuilder<K,​V,​T extends BaseRepartitionNode<K,​V>> - Class in org.apache.kafka.streams.kstream.internals.graph
 
BaseRepartitionNodeBuilder() - Constructor for class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
BatchingStateRestoreCallback - Interface in org.apache.kafka.streams.processor
Interface for batching restoration of a StateStore It is expected that implementations of this class will not call the StateRestoreCallback.restore(byte[], byte[]) method.
BatchWritingStore - Interface in org.apache.kafka.streams.state.internals
 
before(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Deprecated.
before(Duration) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Changes the start window boundary to timeDifference but keep the end window boundary as is.
beforeMs - Variable in class org.apache.kafka.streams.kstream.JoinWindows
Maximum time difference for tuples that are before the join tuple.
blockCacheDataHitRatioSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
blockCacheFilterHitRatioSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
blockCacheIndexHitRatioSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
bloomLocality() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
bottommostCompressionType() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
branch(Named, Predicate<? super K, ? super V>...) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
branch(Named, Predicate<? super K, ? super V>...) - Method in interface org.apache.kafka.streams.kstream.KStream
Creates an array of KStream from this stream by branching the records in the original stream based on the supplied predicates.
branch(Predicate<? super K, ? super V>...) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
branch(Predicate<? super K, ? super V>...) - Method in interface org.apache.kafka.streams.kstream.KStream
Creates an array of KStream from this stream by branching the records in the original stream based on the supplied predicates.
BrokerNotFoundException - Exception in org.apache.kafka.streams.errors
Indicates that none of the specified brokers could be found.
BrokerNotFoundException(String) - Constructor for exception org.apache.kafka.streams.errors.BrokerNotFoundException
 
BrokerNotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.BrokerNotFoundException
 
BrokerNotFoundException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.BrokerNotFoundException
 
BUFFER_ID_TAG - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
BUFFER_LEVEL_GROUP_0100_TO_24 - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
bufferConfig() - Method in class org.apache.kafka.streams.kstream.internals.suppress.SuppressedInternal
 
BufferConfigInternal<BC extends Suppressed.BufferConfig<BC>> - Class in org.apache.kafka.streams.kstream.internals.suppress
 
BufferConfigInternal() - Constructor for class org.apache.kafka.streams.kstream.internals.suppress.BufferConfigInternal
 
BUFFERED_RECORDS_PER_PARTITION_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
buffered.records.per.partition
bufferFullStrategy() - Method in class org.apache.kafka.streams.kstream.internals.suppress.BufferConfigInternal
 
bufferFullStrategy() - Method in class org.apache.kafka.streams.kstream.internals.suppress.EagerBufferConfigImpl
 
bufferFullStrategy() - Method in class org.apache.kafka.streams.kstream.internals.suppress.StrictBufferConfigImpl
 
BufferFullStrategy - Enum in org.apache.kafka.streams.kstream.internals.suppress
 
BufferKey - Class in org.apache.kafka.streams.state.internals
 
bufferLevelTagMap(String, String, String) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
bufferSize() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
bufferSize() - Method in interface org.apache.kafka.streams.state.internals.TimeOrderedKeyValueBuffer
 
BufferValue - Class in org.apache.kafka.streams.state.internals
 
build() - Method in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
build() - Method in class org.apache.kafka.streams.kstream.internals.graph.GroupedTableOperationRepartitionNode.GroupedTableOperationRepartitionNodeBuilder
 
build() - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode.KTableKTableJoinNodeBuilder
 
build() - Method in class org.apache.kafka.streams.kstream.internals.graph.OptimizableRepartitionNode.OptimizableRepartitionNodeBuilder
 
build() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamStreamJoinNode.StreamStreamJoinNodeBuilder
 
build() - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode.TableSourceNodeBuilder
 
build() - Method in class org.apache.kafka.streams.kstream.internals.graph.UnoptimizableRepartitionNode.UnoptimizableRepartitionNodeBuilder
 
build() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.StateStoreFactory
 
build() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer.Builder
 
build() - Method in class org.apache.kafka.streams.state.internals.KeyValueStoreBuilder
 
build() - Method in class org.apache.kafka.streams.state.internals.SessionStoreBuilder
 
build() - Method in class org.apache.kafka.streams.state.internals.TimestampedKeyValueStoreBuilder
 
build() - Method in class org.apache.kafka.streams.state.internals.TimestampedWindowStoreBuilder
 
build() - Method in class org.apache.kafka.streams.state.internals.WindowStoreBuilder
 
build() - Method in interface org.apache.kafka.streams.state.StoreBuilder
Build the store as defined by the builder.
build() - Method in class org.apache.kafka.streams.StreamsBuilder
Returns the Topology that represents the specified processing logic.
build(String) - Method in class org.apache.kafka.streams.kstream.internals.PrintedInternal
 
build(Properties) - Method in class org.apache.kafka.streams.StreamsBuilder
Returns the Topology that represents the specified processing logic and accepts a Properties instance used to indicate whether to optimize topology or not.
buildAndOptimizeTopology() - Method in class org.apache.kafka.streams.kstream.internals.InternalStreamsBuilder
 
buildAndOptimizeTopology(Properties) - Method in class org.apache.kafka.streams.kstream.internals.InternalStreamsBuilder
 
builder - Variable in class org.apache.kafka.streams.kstream.internals.AbstractStream
 
Builder(String, Serde<K>, Serde<V>) - Constructor for class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer.Builder
 
buildFinalResultsSuppression(Duration) - Method in class org.apache.kafka.streams.kstream.internals.suppress.FinalResultsSuppressionBuilder
 
buildFromEndpoint(String) - Static method in class org.apache.kafka.streams.state.HostInfo
 
buildGlobalStateTopology() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
Builds the topology for any global state stores
buildPriority() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
buildSubtopology(int) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
buildTopology() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
BUILT_IN_METRICS_VERSION_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
built.in.metrics.version
BYTEARRAY_VALUE_SERIALIZER - Static variable in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
 
BYTES_KEY_SERIALIZER - Static variable in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
 
bytesPerSync() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
bytesReadDuringCompactionSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
bytesReadFromDatabaseSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
bytesWrittenDuringCompactionSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
bytesWrittenToDatabaseSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 

C

cache - Variable in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
cache() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
cache() - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
Get the thread-global cache
CACHE_LEVEL_GROUP - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
CACHE_MAX_BYTES_BUFFERING_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
cache.max.bytes.buffering
CachedStateStore<K,​V> - Interface in org.apache.kafka.streams.state.internals
 
CacheFlushListener<K,​V> - Interface in org.apache.kafka.streams.state.internals
Listen to cache flush events
cacheLevelSensor(String, String, String, String, Sensor.RecordingLevel, Sensor...) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
cacheLevelTagMap(String, String, String) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
cachingEnabled - Variable in class org.apache.kafka.streams.kstream.Materialized
 
cachingEnabled() - Method in class org.apache.kafka.streams.kstream.internals.MaterializedInternal
 
CachingKeyValueStore - Class in org.apache.kafka.streams.state.internals
 
cancel() - Method in interface org.apache.kafka.streams.processor.Cancellable
Cancel the scheduled operation to avoid future calls.
cancellable() - Method in class org.apache.kafka.streams.processor.internals.PunctuationSchedule
 
Cancellable - Interface in org.apache.kafka.streams.processor
Change<T> - Class in org.apache.kafka.streams.kstream.internals
 
Change(T, T) - Constructor for class org.apache.kafka.streams.kstream.internals.Change
 
ChangedDeserializer<T> - Class in org.apache.kafka.streams.kstream.internals
 
ChangedDeserializer(Deserializer<T>) - Constructor for class org.apache.kafka.streams.kstream.internals.ChangedDeserializer
 
ChangedSerializer<T> - Class in org.apache.kafka.streams.kstream.internals
 
ChangedSerializer(Serializer<T>) - Constructor for class org.apache.kafka.streams.kstream.internals.ChangedSerializer
 
ChangeLoggingKeyValueBytesStore - Class in org.apache.kafka.streams.state.internals
 
ChangeLoggingTimestampedKeyValueBytesStore - Class in org.apache.kafka.streams.state.internals
 
changelogOffsets() - Method in class org.apache.kafka.streams.processor.internals.GlobalStateManagerImpl
 
changelogOffsets() - Method in class org.apache.kafka.streams.processor.internals.ProcessorStateManager
 
changelogOffsets() - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
 
changelogOffsets() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
changelogOffsets() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
changelogPartitions() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
changelogPartitions() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
ChangelogReader - Interface in org.apache.kafka.streams.processor.internals
ChangelogRegister - Interface in org.apache.kafka.streams.processor.internals
checkpoint(Map<TopicPartition, Long>) - Method in class org.apache.kafka.streams.processor.internals.GlobalStateManagerImpl
 
checkpoint(Map<TopicPartition, Long>) - Method in class org.apache.kafka.streams.processor.internals.ProcessorStateManager
 
child() - Method in class org.apache.kafka.streams.processor.internals.ToInternal
 
child(String) - Static method in class org.apache.kafka.streams.processor.To
Forward the key/value pair to one of the downstream processors designated by the downstream processor name.
childName - Variable in class org.apache.kafka.streams.processor.To
 
children() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
children() - Method in class org.apache.kafka.streams.processor.internals.ProcessorNode
 
clean() - Method in class org.apache.kafka.streams.processor.internals.StateDirectory
 
cleanRemovedTasks(long) - Method in class org.apache.kafka.streams.processor.internals.StateDirectory
Remove the directories for any TaskIds that are no-longer owned by this StreamThread and aren't locked by either another process or another StreamThread
cleanUp() - Method in class org.apache.kafka.streams.KafkaStreams
Do a clean up of the local StateStore directory (StreamsConfig.STATE_DIR_CONFIG) by deleting all data with regard to the application ID.
clear() - Method in interface org.apache.kafka.streams.processor.internals.ChangelogReader
Clear all partitions
clear() - Method in class org.apache.kafka.streams.processor.internals.RecordQueue
Clear the fifo queue of its elements
clear() - Method in class org.apache.kafka.streams.processor.internals.StoreChangelogReader
 
clearChildren() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
client.id
CLIENT_ID_TAG - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
CLIENT_LEVEL_GROUP - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
clientLevelTagMap() - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
ClientMetrics - Class in org.apache.kafka.streams.internals.metrics
 
ClientState - Class in org.apache.kafka.streams.processor.internals.assignment
 
ClientState() - Constructor for class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
ClientState(Set<TaskId>, Set<TaskId>, Map<TaskId, Long>, int) - Constructor for class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
ClientUtils - Class in org.apache.kafka.streams.processor.internals
 
ClientUtils() - Constructor for class org.apache.kafka.streams.processor.internals.ClientUtils
 
ClientUtils.QuietAdminClientConfig - Class in org.apache.kafka.streams.processor.internals
 
close() - Method in class org.apache.kafka.streams.KafkaStreams
Shutdown this KafkaStreams instance by signaling all the threads to stop, and then wait for them to join.
close() - Method in class org.apache.kafka.streams.kstream.internals.ChangedDeserializer
 
close() - Method in class org.apache.kafka.streams.kstream.internals.ChangedSerializer
 
close() - Method in class org.apache.kafka.streams.kstream.internals.KStreamFlatTransform.KStreamFlatTransformProcessor
 
close() - Method in class org.apache.kafka.streams.kstream.internals.KStreamFlatTransformValues.KStreamFlatTransformValuesProcessor
 
close() - Method in class org.apache.kafka.streams.kstream.internals.KStreamTransformValues.KStreamTransformValuesProcessor
 
close() - Method in interface org.apache.kafka.streams.kstream.internals.KTableValueGetter
 
close() - Method in class org.apache.kafka.streams.kstream.internals.PrintForeachAction
 
close() - Method in class org.apache.kafka.streams.kstream.internals.WrappingNullableSerde
 
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 class org.apache.kafka.streams.processor.internals.GlobalStateManagerImpl
 
close() - Method in class org.apache.kafka.streams.processor.internals.ProcessorNode
 
close() - Method in class org.apache.kafka.streams.processor.internals.ProcessorStateManager
Close all stores (even in case of failure).
close() - Method in class org.apache.kafka.streams.processor.internals.PunctuationQueue
 
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 class org.apache.kafka.streams.state.internals.AbstractRocksDBSegmentedBytesStore
 
close() - Method in class org.apache.kafka.streams.state.internals.CachingKeyValueStore
 
close() - Method in class org.apache.kafka.streams.state.internals.DelegatingPeekingKeyValueIterator
 
close() - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
close() - Method in class org.apache.kafka.streams.state.internals.InMemorySessionStore
 
close() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
close() - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowStore
 
close() - Method in class org.apache.kafka.streams.state.internals.KeyValueIteratorFacade
 
close() - Method in class org.apache.kafka.streams.state.internals.KeyValueToTimestampedKeyValueByteStoreAdapter
 
close() - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
close() - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
close() - Method in class org.apache.kafka.streams.state.internals.MeteredSessionStore
 
close() - Method in class org.apache.kafka.streams.state.internals.MeteredWindowStore
 
close() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
close() - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
close() - Method in class org.apache.kafka.streams.state.internals.ValueAndTimestampSerializer
 
close() - Method in class org.apache.kafka.streams.state.internals.WrappedStateStore
 
close() - Method in interface org.apache.kafka.streams.state.KeyValueIterator
 
close() - Method in interface org.apache.kafka.streams.state.WindowStoreIterator
 
close(boolean) - Method in class org.apache.kafka.streams.processor.internals.GlobalStateUpdateTask
 
close(long, TimeUnit) - Method in class org.apache.kafka.streams.KafkaStreams
Deprecated.
Use KafkaStreams.close(Duration) instead; note, that KafkaStreams.close(Duration) has different semantics and does not block on zero, e.g., `Duration.ofMillis(0)`.
close(String, Options) - Method in interface org.apache.kafka.streams.state.RocksDBConfigSetter
Close any user-constructed objects that inherit from org.rocksdb.RocksObject.
close(Duration) - Method in 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.
closeClean() - Method in interface org.apache.kafka.streams.processor.internals.RecordCollector
Clean close the internal Producer.
closeClean() - Method in class org.apache.kafka.streams.processor.internals.RecordCollectorImpl
 
closeClean() - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
 
closeClean() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
closeClean() - Method in interface org.apache.kafka.streams.processor.internals.Task
Must be idempotent.
closeCleanAndRecycleState() - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
 
closeCleanAndRecycleState() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
closeCleanAndRecycleState() - Method in interface org.apache.kafka.streams.processor.internals.Task
Attempt a clean close but do not close the underlying state
CLOSED - org.apache.kafka.streams.processor.internals.Task.State
 
closeDirty() - Method in interface org.apache.kafka.streams.processor.internals.RecordCollector
Dirty close the internal Producer.
closeDirty() - Method in class org.apache.kafka.streams.processor.internals.RecordCollectorImpl
 
closeDirty() - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
 
closeDirty() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
closeDirty() - Method in interface org.apache.kafka.streams.processor.internals.Task
Must be idempotent.
closeTaskSensor(String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ThreadMetrics
 
code() - Method in enum org.apache.kafka.streams.processor.internals.assignment.AssignorError
 
cogroup(Aggregator<? super K, ? super V, Vout>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Create a new CogroupedKStream from the this grouped KStream to allow cogrouping other KGroupedStream to it.
cogroup(KGroupedStream<K, VIn>, Aggregator<? super K, ? super VIn, VOut>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
Add an already grouped KStream to this CogroupedKStream.
cogroup(KGroupedStream<K, VIn>, Aggregator<? super K, ? super VIn, VOut>) - Method in class org.apache.kafka.streams.kstream.internals.CogroupedKStreamImpl
 
CogroupedKStream<K,​VOut> - Interface in org.apache.kafka.streams.kstream
CogroupedKStream is an abstraction of multiple grouped record streams of KeyValue pairs.
CogroupedKStreamImpl<K,​VOut> - Class in org.apache.kafka.streams.kstream.internals
 
CombinedKey<KF,​KP> - Class in org.apache.kafka.streams.kstream.internals.foreignkeyjoin
 
CombinedKeySchema<KO,​K> - Class in org.apache.kafka.streams.kstream.internals.foreignkeyjoin
Factory for creating CombinedKey serializers / deserializers.
CombinedKeySchema(Supplier<String>, Serde<KO>, Supplier<String>, Serde<K>) - Constructor for class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.CombinedKeySchema
 
commit() - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
commit() - Method in class org.apache.kafka.streams.processor.internals.GlobalProcessorContextImpl
 
commit() - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
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
commitId() - Static method in class org.apache.kafka.streams.internals.metrics.ClientMetrics
 
commitNeeded() - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
 
commitNeeded() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
commitNeeded() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
commitOverTasksSensor(String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ThreadMetrics
 
commitRatioSensor(String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ThreadMetrics
 
commitRequested() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
Whether or not a request has been made to commit the current state
commitRequested() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
commitSensor(String, String, StreamsMetricsImpl, Sensor...) - Static method in class org.apache.kafka.streams.processor.internals.metrics.TaskMetrics
 
commitSensor(String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ThreadMetrics
 
commonlySupportedVersion() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
compactionOptionsFIFO() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
compactionOptionsUniversal() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
compactionPriority() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
compactionReadaheadSize() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
compactionStyle() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
compactionTimeAvgSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
compactionTimeMaxSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
compactionTimeMinSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
compareTo(Object) - Method in class org.apache.kafka.streams.processor.internals.Stamped
 
compareTo(TaskId) - Method in class org.apache.kafka.streams.processor.TaskId
 
compareTo(BufferKey) - Method in class org.apache.kafka.streams.state.internals.BufferKey
 
compareValuesAndCheckForIncreasingTimestamp(byte[], byte[]) - Static method in class org.apache.kafka.streams.state.internals.ValueAndTimestampSerializer
 
completedChangelogs() - Method in interface org.apache.kafka.streams.processor.internals.ChangelogReader
 
completedChangelogs() - Method in class org.apache.kafka.streams.processor.internals.StoreChangelogReader
 
completeRestoration() - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
 
completeRestoration() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
completeRestoration() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
CompositeReadOnlyKeyValueStore<K,​V> - Class in org.apache.kafka.streams.state.internals
A wrapper over the underlying ReadOnlyKeyValueStores found in a ProcessorTopology
CompositeReadOnlyKeyValueStore(StateStoreProvider, QueryableStoreType<ReadOnlyKeyValueStore<K, V>>, String) - Constructor for class org.apache.kafka.streams.state.internals.CompositeReadOnlyKeyValueStore
 
CompositeReadOnlySessionStore<K,​V> - Class in org.apache.kafka.streams.state.internals
Wrapper over the underlying ReadOnlySessionStores found in a ProcessorTopology
CompositeReadOnlySessionStore(StateStoreProvider, QueryableStoreType<ReadOnlySessionStore<K, V>>, String) - Constructor for class org.apache.kafka.streams.state.internals.CompositeReadOnlySessionStore
 
CompositeReadOnlyWindowStore<K,​V> - Class in org.apache.kafka.streams.state.internals
Wrapper over the underlying ReadOnlyWindowStores found in a ProcessorTopology
CompositeReadOnlyWindowStore(StateStoreProvider, QueryableStoreType<ReadOnlyWindowStore<K, V>>, String) - Constructor for class org.apache.kafka.streams.state.internals.CompositeReadOnlyWindowStore
 
compressionOptions() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
compressionPerLevel() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
compressionType() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
computeTaskLags(UUID, Map<TaskId, Long>) - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
Compute the lag for each stateful task, including tasks this client did not previously have.
configDef() - Static method in class org.apache.kafka.streams.StreamsConfig
Return a copy of the config definition.
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, ?>) - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
We need to have the PartitionAssignor and its StreamThread to be mutually accessible since the former needs later's cached metadata while sending subscriptions, and the latter needs former's returned assignment when adding tasks.
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.internals.WrappingNullableSerde
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.SessionWindowedSerializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.TimeWindowedSerializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.state.internals.ValueAndTimestampSerializer
 
configuredMetadataVersion(int) - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
ConnectedStoreProvider - Interface in org.apache.kafka.streams.processor
Provides a set of StoreBuilders that will be automatically added to the topology and connected to the associated processor.
CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
connections.max.idle.ms
connectProcessorAndStateStores(String, String...) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
connectProcessorAndStateStores(String, String...) - Method in class org.apache.kafka.streams.Topology
Connects the processor and the state stores.
connectSourceStoreAndTopic(String, String) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
Consumed<K,​V> - Class in org.apache.kafka.streams.kstream
The Consumed class is used to define the optional parameters when using StreamsBuilder to build instances of KStream, KTable, and GlobalKTable.
Consumed(Consumed<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Consumed
Create an instance of Consumed from an existing instance.
consumedInternal() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamSourceNode
 
ConsumedInternal<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
ConsumedInternal() - Constructor for class org.apache.kafka.streams.kstream.internals.ConsumedInternal
 
ConsumedInternal(Serde<K>, Serde<V>, TimestampExtractor, Topology.AutoOffsetReset) - Constructor for class org.apache.kafka.streams.kstream.internals.ConsumedInternal
 
ConsumedInternal(Consumed<K, V>) - Constructor for class org.apache.kafka.streams.kstream.internals.ConsumedInternal
 
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
 
consumerMetrics() - Method in class org.apache.kafka.streams.processor.internals.GlobalStreamThread
 
consumerMetrics() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
 
consumerMetrics(Consumer<byte[], byte[]>, Consumer<byte[], byte[]>) - Static method in class org.apache.kafka.streams.processor.internals.ClientUtils
 
consumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
Prefix a property with StreamsConfig.CONSUMER_PREFIX.
context() - Method in class org.apache.kafka.streams.processor.AbstractProcessor
Get the processor's context set during initialization.
ContextualRecord - Class in org.apache.kafka.streams.state.internals
 
ContextualRecord(byte[], ProcessorRecordContext) - Constructor for class org.apache.kafka.streams.state.internals.ContextualRecord
 
CONTINUE - org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
 
CONTINUE - org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
 
convert(ConsumerRecord<byte[], byte[]>) - Method in interface org.apache.kafka.streams.state.internals.RecordConverter
 
convertToTimestampedFormat(byte[]) - Static method in interface org.apache.kafka.streams.state.TimestampedBytesStore
 
copartitionedTopicsEnforcer() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
CopartitionedTopicsEnforcer - Class in org.apache.kafka.streams.processor.internals.assignment
 
CopartitionedTopicsEnforcer(String) - Constructor for class org.apache.kafka.streams.processor.internals.assignment.CopartitionedTopicsEnforcer
 
copartitionGroups() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
copartitionSources(Collection<String>) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
copy() - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
corruptedTaskWithChangelogs() - Method in exception org.apache.kafka.streams.errors.TaskCorruptedException
 
count() - Method in class org.apache.kafka.streams.kstream.internals.KGroupedTableImpl
 
count() - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImpl
 
count() - Method in class org.apache.kafka.streams.kstream.internals.TimeWindowedKStreamImpl
 
count() - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Count the number of records in this stream by the grouped key.
count() - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
Count number of records of the original KTable that got mapped to the same key into a new instance of KTable.
count() - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
Count the number of records in this stream by the grouped key and defined sessions.
count() - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Count the number of records in this stream by the grouped key and defined windows.
count(Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KGroupedTableImpl
 
count(Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Count the number of records in this stream by the grouped key.
count(Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
Count number of records of the original KTable that got mapped to the same key into a new instance of KTable.
count(Materialized<K, Long, SessionStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImpl
 
count(Materialized<K, Long, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
Count the number of records in this stream by the grouped key and defined sessions.
count(Materialized<K, Long, WindowStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.TimeWindowedKStreamImpl
 
count(Materialized<K, Long, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Count the number of records in this stream by the grouped key and defined windows.
count(Named) - Method in class org.apache.kafka.streams.kstream.internals.KGroupedTableImpl
 
count(Named) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImpl
 
count(Named) - Method in class org.apache.kafka.streams.kstream.internals.TimeWindowedKStreamImpl
 
count(Named) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Count the number of records in this stream by the grouped key.
count(Named) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
Count number of records of the original KTable that got mapped to the same key into a new instance of KTable.
count(Named) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
Count the number of records in this stream by the grouped key and defined sessions.
count(Named) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Count the number of records in this stream by the grouped key and defined windows.
count(Named, Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KGroupedTableImpl
 
count(Named, Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Count the number of records in this stream by the grouped key.
count(Named, Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
Count number of records of the original KTable that got mapped to the same key into a new instance of KTable.
count(Named, Materialized<K, Long, SessionStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImpl
 
count(Named, Materialized<K, Long, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
Count the number of records in this stream by the grouped key and defined sessions.
count(Named, Materialized<K, Long, WindowStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.TimeWindowedKStreamImpl
 
count(Named, Materialized<K, Long, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Count the number of records in this stream by the grouped key and defined windows.
create(InternalTopologyBuilder, StreamsConfig, KafkaClientSupplier, Admin, UUID, String, StreamsMetricsImpl, Time, StreamsMetadataState, long, StateDirectory, StateRestoreListener, int) - Static method in class org.apache.kafka.streams.processor.internals.StreamThread
 
create(StateStoreProvider, String) - Method in interface org.apache.kafka.streams.state.QueryableStoreType
Create an instance of T (usually a facade) that developers can use to query the underlying StateStores.
create(StateStoreProvider, String) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.KeyValueStoreType
 
create(StateStoreProvider, String) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.SessionStoreType
 
create(StateStoreProvider, String) - Method in class org.apache.kafka.streams.state.QueryableStoreTypes.WindowStoreType
 
createAppDirAndInternalStreams(StreamsConfig) - Static method in class org.apache.kafka.streams.mapr.KafkaStreamsInternalStorageInitializer
 
CREATED - org.apache.kafka.streams.KafkaStreams.State
 
CREATED - org.apache.kafka.streams.processor.internals.GlobalStreamThread.State
 
CREATED - org.apache.kafka.streams.processor.internals.StreamThread.State
 
CREATED - org.apache.kafka.streams.processor.internals.Task.State
 
createIfMissing() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
createMissingColumnFamilies() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
createSensor(String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ProcessorNodeMetrics
 
createTaskSensor(String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ThreadMetrics
 
currentNode - Variable in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
currentNode() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
currentNode() - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
Get the current ProcessorNode
currentNode() - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
currentOffsetPosition() - Method in class org.apache.kafka.streams.LagInfo
Get the current maximum offset on the store partition's changelog topic, that has been successfully written into the store partition's state store.
currentSystemTimeMs() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
currentSystemTimeMs() - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
 

D

dbLogDir() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
dbPaths() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
dbWriteBufferSize() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
DEAD - org.apache.kafka.streams.processor.internals.GlobalStreamThread.State
 
DEAD - org.apache.kafka.streams.processor.internals.StreamThread.State
 
decode(ByteBuffer) - Static method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
decode(ByteBuffer) - Static method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
decomposeLegacyFormattedArrayIntoChangeArrays(byte[]) - Static method in class org.apache.kafka.streams.kstream.internals.FullChangeSerde
We used to serialize a Change into a single byte[].
decoratePseudoTopic(String) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
DEFAULT_DESERIALIZATION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
default.deserialization.exception.handler
DEFAULT_KEY_SERDE_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
default key.serde
DEFAULT_PRODUCTION_EXCEPTION_HANDLER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
default.production.exception.handler
DEFAULT_RETENTION_MS - Static variable in class org.apache.kafka.streams.kstream.internals.WindowingDefaults
 
DEFAULT_SEED - Static variable in class org.apache.kafka.streams.state.internals.Murmur3
 
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
 
DefaultKafkaClientSupplier - Class in org.apache.kafka.streams.processor.internals
 
DefaultKafkaClientSupplier() - Constructor for class org.apache.kafka.streams.processor.internals.DefaultKafkaClientSupplier
 
defaultKeySerde() - Method in class org.apache.kafka.streams.StreamsConfig
Return an configured instance of key Serde class.
DefaultPartitionGrouper - Class in org.apache.kafka.streams.processor
Deprecated.
since 2.4 release; will be removed in 3.0.0 via KAFKA-7785
DefaultPartitionGrouper() - Constructor for class org.apache.kafka.streams.processor.DefaultPartitionGrouper
Deprecated.
 
defaultProductionExceptionHandler() - Method in class org.apache.kafka.streams.StreamsConfig
 
DefaultProductionExceptionHandler - Class in org.apache.kafka.streams.errors
ProductionExceptionHandler that always instructs streams to fail when an exception happens while attempting to produce result records.
DefaultProductionExceptionHandler() - Constructor for class org.apache.kafka.streams.errors.DefaultProductionExceptionHandler
 
DefaultStreamPartitioner<K,​V> - Class in org.apache.kafka.streams.processor.internals
 
DefaultStreamPartitioner(Serializer<K>, Cluster) - Constructor for class org.apache.kafka.streams.processor.internals.DefaultStreamPartitioner
 
defaultTimestampExtractor() - Method in class org.apache.kafka.streams.StreamsConfig
 
defaultValueSerde() - Method in class org.apache.kafka.streams.StreamsConfig
Return an configured instance of value Serde class.
defined(T) - Static method in class org.apache.kafka.streams.state.internals.Maybe
 
delayedWriteRate() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
DelegatingPeekingKeyValueIterator<K,​V> - Class in org.apache.kafka.streams.state.internals
Optimized KeyValueIterator used when the same element could be peeked multiple times.
DelegatingPeekingKeyValueIterator(String, KeyValueIterator<K, V>) - Constructor for class org.apache.kafka.streams.state.internals.DelegatingPeekingKeyValueIterator
 
delete() - Method in class org.apache.kafka.streams.state.internals.OffsetCheckpoint
 
delete(String, Bytes) - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 
delete(K) - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
delete(K) - Method in interface org.apache.kafka.streams.state.KeyValueStore
Delete the value from the store (if there is one).
delete(Bytes) - Method in class org.apache.kafka.streams.state.internals.CachingKeyValueStore
 
delete(Bytes) - Method in class org.apache.kafka.streams.state.internals.ChangeLoggingKeyValueBytesStore
 
delete(Bytes) - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
delete(Bytes) - Method in class org.apache.kafka.streams.state.internals.KeyValueToTimestampedKeyValueByteStoreAdapter
 
delete(Bytes) - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
delete(Bytes) - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
DELETE_KEY_AND_PROPAGATE - org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionWrapper.Instruction
 
DELETE_KEY_NO_PROPAGATE - org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionWrapper.Instruction
 
deleteObsoleteFilesPeriodMicros() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
deleteSensor(String, String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.state.internals.metrics.StateStoreMetrics
 
describe() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
describe() - Method in class org.apache.kafka.streams.Topology
Returns a description of the specified Topology.
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.streams.kstream.internals.ChangedDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
 
deserialize(String, byte[]) - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
 
deserialize(String, Headers, byte[]) - Method in class org.apache.kafka.streams.kstream.internals.ChangedDeserializer
 
deserialize(ByteBuffer) - Static method in class org.apache.kafka.streams.processor.internals.ProcessorRecordContext
 
deserializeParts(String, Change<byte[]>) - Method in class org.apache.kafka.streams.kstream.internals.FullChangeSerde
 
deserializer() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionResponseWrapperSerde
 
deserializer() - Method in class org.apache.kafka.streams.kstream.internals.WrappingNullableSerde
 
destroy() - Method in interface org.apache.kafka.streams.state.internals.Segment
 
destroySensor(String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ProcessorNodeMetrics
 
directoryForTask(TaskId) - Method in class org.apache.kafka.streams.processor.internals.StateDirectory
Get or create the directory for the provided TaskId.
disableAutoCompactions() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
droppedRecordsSensor(String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.TaskMetrics
 
droppedRecordsSensorOrExpiredWindowRecordDropSensor(String, String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.TaskMetrics
 
droppedRecordsSensorOrLateRecordDropSensor(String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.TaskMetrics
 
droppedRecordsSensorOrSkippedRecordsSensor(String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.TaskMetrics
 
DUMMY_THREAD_INDEX - Static variable in class org.apache.kafka.streams.StreamsConfig
 
dumpMallocStats() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
duplicate() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
duplicate() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
duplicate() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
duplicate() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 

E

e2ELatencySensor(String, String, String, Sensor.RecordingLevel, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.TaskMetrics
 
EagerBufferConfigImpl - Class in org.apache.kafka.streams.kstream.internals.suppress
 
EagerBufferConfigImpl(long, long) - Constructor for class org.apache.kafka.streams.kstream.internals.suppress.EagerBufferConfigImpl
 
EARLIEST - org.apache.kafka.streams.Topology.AutoOffsetReset
 
EARLIEST_PROBEABLE_VERSION - Static variable in class org.apache.kafka.streams.processor.internals.assignment.StreamsAssignmentProtocolVersions
 
earliestResetTopicsPattern() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
EMIT - org.apache.kafka.streams.kstream.internals.suppress.BufferFullStrategy
 
emitEarlyWhenFull() - Method in class org.apache.kafka.streams.kstream.internals.suppress.BufferConfigInternal
 
emitEarlyWhenFull() - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
Set the buffer to just emit the oldest records when any of its constraints are violated.
empty() - Static method in class org.apache.kafka.streams.kstream.internals.NamedInternal
 
empty() - Static method in class org.apache.kafka.streams.processor.internals.InternalTopicProperties
 
enableSendingOldValues() - Method in interface org.apache.kafka.streams.kstream.internals.KStreamAggProcessorSupplier
 
enableSendingOldValues() - Method in class org.apache.kafka.streams.kstream.internals.KStreamAggregate
 
enableSendingOldValues() - Method in class org.apache.kafka.streams.kstream.internals.KStreamReduce
 
enableSendingOldValues() - Method in class org.apache.kafka.streams.kstream.internals.KStreamSessionWindowAggregate
 
enableSendingOldValues() - Method in class org.apache.kafka.streams.kstream.internals.KStreamWindowAggregate
 
enableSendingOldValues() - Method in class org.apache.kafka.streams.kstream.internals.KTableAggregate
 
enableSendingOldValues() - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
enableSendingOldValues() - Method in class org.apache.kafka.streams.kstream.internals.KTableKTableJoinMerger
 
enableSendingOldValues() - Method in interface org.apache.kafka.streams.kstream.internals.KTableProcessorSupplier
 
enableSendingOldValues() - Method in class org.apache.kafka.streams.kstream.internals.KTableReduce
 
enableSendingOldValues() - Method in class org.apache.kafka.streams.kstream.internals.KTableRepartitionMap
 
enableSendingOldValues() - Method in class org.apache.kafka.streams.kstream.internals.KTableSource
 
enableSendingOldValues() - Method in class org.apache.kafka.streams.kstream.internals.suppress.KTableSuppressProcessorSupplier
 
enableStaleStores() - Method in class org.apache.kafka.streams.StoreQueryParameters
Enable querying of stale state stores, i.e., allow to query active tasks during restore as well as standby tasks.
enableThreadTracking() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
enableWriteThreadAdaptiveYield() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
encode() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
encode() - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
end() - Method in class org.apache.kafka.streams.kstream.Window
Return the end timestamp of this window.
end() - Method in class org.apache.kafka.streams.state.internals.Murmur3.IncrementalHash32
 
endMs - Variable in class org.apache.kafka.streams.kstream.Window
 
endOffsetPosition() - Method in class org.apache.kafka.streams.LagInfo
Get the end offset position for this store partition's changelog topic on the Kafka brokers.
endTime() - Method in class org.apache.kafka.streams.kstream.Window
Return the end time of this window.
enforce(Set<String>, Map<String, InternalTopicConfig>, Cluster) - Method in class org.apache.kafka.streams.processor.internals.assignment.CopartitionedTopicsEnforcer
 
enforcedProcessingSensor(String, String, StreamsMetricsImpl, Sensor...) - Static method in class org.apache.kafka.streams.processor.internals.metrics.TaskMetrics
 
enforceRestoreActive() - Method in interface org.apache.kafka.streams.processor.internals.ChangelogReader
Transit to restore active changelogs mode
enforceRestoreActive() - Method in class org.apache.kafka.streams.processor.internals.StoreChangelogReader
 
eosEnabled(StreamsConfig) - Static method in class org.apache.kafka.streams.processor.internals.StreamThread
 
equals(Object) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
equals(Object) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
equals(Object) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
equals(Object) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
equals(Object) - Method in class org.apache.kafka.streams.KeyQueryMetadata
 
equals(Object) - Method in class org.apache.kafka.streams.KeyValue
 
equals(Object) - Method in class org.apache.kafka.streams.kstream.Consumed
 
equals(Object) - Method in class org.apache.kafka.streams.kstream.internals.Change
 
equals(Object) - Method in class org.apache.kafka.streams.kstream.internals.suppress.EagerBufferConfigImpl
 
equals(Object) - Method in class org.apache.kafka.streams.kstream.internals.suppress.FinalResultsSuppressionBuilder
 
equals(Object) - Method in class org.apache.kafka.streams.kstream.internals.suppress.StrictBufferConfigImpl
 
equals(Object) - Method in class org.apache.kafka.streams.kstream.internals.suppress.SuppressedInternal
 
equals(Object) - Method in class org.apache.kafka.streams.kstream.JoinWindows
 
equals(Object) - Method in class org.apache.kafka.streams.kstream.Produced
 
equals(Object) - Method in class org.apache.kafka.streams.kstream.SessionWindows
 
equals(Object) - Method in class org.apache.kafka.streams.kstream.TimeWindows
 
equals(Object) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
 
equals(Object) - Method in class org.apache.kafka.streams.kstream.Window
 
equals(Object) - Method in class org.apache.kafka.streams.kstream.Windowed
 
equals(Object) - Method in class org.apache.kafka.streams.LagInfo
 
equals(Object) - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
equals(Object) - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
equals(Object) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.GlobalStore
 
equals(Object) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Processor
 
equals(Object) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Sink
 
equals(Object) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Source
 
equals(Object) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Subtopology
 
equals(Object) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopicsInfo
 
equals(Object) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopologyDescription
 
equals(Object) - Method in class org.apache.kafka.streams.processor.internals.ProcessorRecordContext
 
equals(Object) - Method in class org.apache.kafka.streams.processor.internals.PunctuationSchedule
 
equals(Object) - Method in class org.apache.kafka.streams.processor.internals.RepartitionTopicConfig
 
equals(Object) - Method in class org.apache.kafka.streams.processor.internals.Stamped
 
equals(Object) - Method in class org.apache.kafka.streams.processor.internals.StaticTopicNameExtractor
 
equals(Object) - Method in class org.apache.kafka.streams.processor.internals.UnwindowedChangelogTopicConfig
 
equals(Object) - Method in class org.apache.kafka.streams.processor.internals.WindowedChangelogTopicConfig
 
equals(Object) - Method in class org.apache.kafka.streams.processor.TaskId
 
equals(Object) - Method in class org.apache.kafka.streams.processor.TaskMetadata
 
equals(Object) - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
equals(Object) - Method in class org.apache.kafka.streams.processor.To
 
equals(Object) - Method in class org.apache.kafka.streams.state.HostInfo
 
equals(Object) - Method in class org.apache.kafka.streams.state.internals.BufferKey
 
equals(Object) - Method in class org.apache.kafka.streams.state.internals.BufferValue
 
equals(Object) - Method in class org.apache.kafka.streams.state.internals.ContextualRecord
 
equals(Object) - Method in class org.apache.kafka.streams.state.internals.Maybe
 
equals(Object) - Method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics.RocksDBMetricContext
 
equals(Object) - Method in class org.apache.kafka.streams.state.internals.TimeOrderedKeyValueBuffer.Eviction
 
equals(Object) - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
equals(Object) - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
 
equals(Object) - Method in class org.apache.kafka.streams.StoreQueryParameters
 
equals(KF, KP) - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.CombinedKey
 
errCode() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
ERROR - org.apache.kafka.streams.KafkaStreams.State
 
errorIfExists() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
evicts() - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 
evictWhile(Supplier<Boolean>, Consumer<TimeOrderedKeyValueBuffer.Eviction<K, V>>) - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
evictWhile(Supplier<Boolean>, Consumer<TimeOrderedKeyValueBuffer.Eviction<K, V>>) - Method in interface org.apache.kafka.streams.state.internals.TimeOrderedKeyValueBuffer
 
EXACTLY_ONCE - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "processing.guarantee" for exactly-once processing guarantees.
EXACTLY_ONCE_ALPHA - org.apache.kafka.streams.processor.internals.StreamThread.ProcessingMode
 
EXACTLY_ONCE_BETA - org.apache.kafka.streams.processor.internals.StreamThread.ProcessingMode
 
EXACTLY_ONCE_BETA - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "processing.guarantee" for exactly-once processing guarantees.
executeAndMaybeSwallow(boolean, Runnable, String, Logger) - Static method in class org.apache.kafka.streams.processor.internals.TaskManager
 
executeAndMaybeSwallow(boolean, Runnable, Consumer<RuntimeException>, Consumer<RuntimeException>) - Static method in class org.apache.kafka.streams.processor.internals.TaskManager
 
exists(T) - Method in class org.apache.kafka.streams.processor.internals.QuickUnion
 
expiredWindowRecordDropSensor(String, String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.state.internals.metrics.StateStoreMetrics
 
extract(K, V, RecordContext) - Method in class org.apache.kafka.streams.processor.internals.StaticTopicNameExtractor
 
extract(K, V, RecordContext) - Method in interface org.apache.kafka.streams.processor.TopicNameExtractor
Extracts the topic name to send to.
extract(ConsumerRecord<Object, Object>, long) - Method in interface org.apache.kafka.streams.processor.TimestampExtractor
Extracts a timestamp from a record.
extract(ConsumerRecord<Object, Object>, long) - Method in class org.apache.kafka.streams.processor.WallclockTimestampExtractor
Return the current wall clock time as timestamp.

F

FAIL - org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
 
FAIL - org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
 
failIfOptionsFileError() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
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
 
FallbackPriorTaskAssignor - Class in org.apache.kafka.streams.processor.internals.assignment
A special task assignor implementation to be used as a fallback in case the configured assignor couldn't be invoked.
FallbackPriorTaskAssignor() - Constructor for class org.apache.kafka.streams.processor.internals.assignment.FallbackPriorTaskAssignor
 
fetch(K) - Method in class org.apache.kafka.streams.state.internals.CompositeReadOnlySessionStore
 
fetch(K) - Method in class org.apache.kafka.streams.state.internals.MeteredSessionStore
 
fetch(K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
Retrieve all aggregated sessions for the provided key.
fetch(K, long) - Method in class org.apache.kafka.streams.state.internals.CompositeReadOnlyWindowStore
 
fetch(K, long) - Method in class org.apache.kafka.streams.state.internals.MeteredWindowStore
 
fetch(K, long) - Method in class org.apache.kafka.streams.state.internals.ReadOnlyWindowStoreFacade
 
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 class org.apache.kafka.streams.state.internals.CompositeReadOnlyWindowStore
Deprecated.
fetch(K, long, long) - Method in class org.apache.kafka.streams.state.internals.MeteredWindowStore
 
fetch(K, long, long) - Method in class org.apache.kafka.streams.state.internals.ReadOnlyWindowStoreFacade
 
fetch(K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
fetch(K, long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
Get all the key-value pairs with the given key and the time range from all the existing windows.
fetch(K, Instant, Instant) - Method in class org.apache.kafka.streams.state.internals.CompositeReadOnlyWindowStore
 
fetch(K, Instant, Instant) - Method in class org.apache.kafka.streams.state.internals.ReadOnlyWindowStoreFacade
 
fetch(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
Get all the key-value pairs with the given key and the time range from all the existing windows.
fetch(K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
 
fetch(K, K) - Method in class org.apache.kafka.streams.state.internals.CompositeReadOnlySessionStore
 
fetch(K, K) - Method in class org.apache.kafka.streams.state.internals.MeteredSessionStore
 
fetch(K, K) - Method in interface org.apache.kafka.streams.state.ReadOnlySessionStore
Retrieve all aggregated sessions for the given range of keys.
fetch(K, K, long, long) - Method in class org.apache.kafka.streams.state.internals.CompositeReadOnlyWindowStore
 
fetch(K, K, long, long) - Method in class org.apache.kafka.streams.state.internals.MeteredWindowStore
 
fetch(K, K, long, long) - Method in class org.apache.kafka.streams.state.internals.ReadOnlyWindowStoreFacade
 
fetch(K, K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
fetch(K, K, long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
Get all the key-value pairs in the given key range and time range from all the existing windows.
fetch(K, K, Instant, Instant) - Method in class org.apache.kafka.streams.state.internals.CompositeReadOnlyWindowStore
 
fetch(K, K, Instant, Instant) - Method in class org.apache.kafka.streams.state.internals.ReadOnlyWindowStoreFacade
 
fetch(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
Get all the key-value pairs in the given key range and time range from all the existing windows.
fetch(K, K, Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
 
fetch(Bytes) - Method in class org.apache.kafka.streams.state.internals.InMemorySessionStore
 
fetch(Bytes) - Method in class org.apache.kafka.streams.state.internals.RocksDBSessionStore
 
fetch(Bytes, long) - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowStore
 
fetch(Bytes, long) - Method in class org.apache.kafka.streams.state.internals.RocksDBWindowStore
 
fetch(Bytes, long, long) - Method in class org.apache.kafka.streams.state.internals.AbstractRocksDBSegmentedBytesStore
 
fetch(Bytes, long, long) - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowStore
Deprecated.
fetch(Bytes, long, long) - Method in class org.apache.kafka.streams.state.internals.RocksDBWindowStore
 
fetch(Bytes, long, long) - Method in interface org.apache.kafka.streams.state.internals.SegmentedBytesStore
Fetch all records from the segmented store with the provided key and time range from all existing segments
fetch(Bytes, Bytes) - Method in class org.apache.kafka.streams.state.internals.InMemorySessionStore
 
fetch(Bytes, Bytes) - Method in class org.apache.kafka.streams.state.internals.RocksDBSessionStore
 
fetch(Bytes, Bytes, long, long) - Method in class org.apache.kafka.streams.state.internals.AbstractRocksDBSegmentedBytesStore
 
fetch(Bytes, Bytes, long, long) - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowStore
Deprecated.
fetch(Bytes, Bytes, long, long) - Method in class org.apache.kafka.streams.state.internals.RocksDBWindowStore
 
fetch(Bytes, Bytes, long, long) - Method in interface org.apache.kafka.streams.state.internals.SegmentedBytesStore
Fetch all records from the segmented store in the provided key range and time range from all existing segments
fetchAll(long, long) - Method in class org.apache.kafka.streams.state.internals.AbstractRocksDBSegmentedBytesStore
 
fetchAll(long, long) - Method in class org.apache.kafka.streams.state.internals.CompositeReadOnlyWindowStore
Deprecated.
fetchAll(long, long) - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowStore
Deprecated.
fetchAll(long, long) - Method in class org.apache.kafka.streams.state.internals.MeteredWindowStore
 
fetchAll(long, long) - Method in class org.apache.kafka.streams.state.internals.ReadOnlyWindowStoreFacade
 
fetchAll(long, long) - Method in class org.apache.kafka.streams.state.internals.RocksDBWindowStore
 
fetchAll(long, long) - Method in interface org.apache.kafka.streams.state.internals.SegmentedBytesStore
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.ReadOnlyWindowStore
fetchAll(long, long) - Method in interface org.apache.kafka.streams.state.WindowStore
Gets all the key-value pairs that belong to the windows within in the given time range.
fetchAll(Instant, Instant) - Method in class org.apache.kafka.streams.state.internals.CompositeReadOnlyWindowStore
 
fetchAll(Instant, Instant) - Method in class org.apache.kafka.streams.state.internals.ReadOnlyWindowStoreFacade
 
fetchAll(Instant, Instant) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
Gets all the key-value pairs that belong to the windows within in the given time range.
fetchAll(Instant, Instant) - Method in interface org.apache.kafka.streams.state.WindowStore
 
fetchCommittedOffsets(Set<TopicPartition>, Consumer<byte[], byte[]>) - Static method in class org.apache.kafka.streams.processor.internals.ClientUtils
 
fetchEndOffsets(Collection<TopicPartition>, Admin) - Static method in class org.apache.kafka.streams.processor.internals.ClientUtils
 
fetchEndOffsetsFuture(Collection<TopicPartition>, Admin) - Static method in class org.apache.kafka.streams.processor.internals.ClientUtils
 
fetchSensor(String, String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.state.internals.metrics.StateStoreMetrics
 
fetchSession(K, long, long) - Method in class org.apache.kafka.streams.state.internals.MeteredSessionStore
 
fetchSession(K, long, long) - Method in interface org.apache.kafka.streams.state.SessionStore
Get the value of key from a single session.
fetchSession(Bytes, long, long) - Method in class org.apache.kafka.streams.state.internals.InMemorySessionStore
 
fetchSession(Bytes, long, long) - Method in class org.apache.kafka.streams.state.internals.RocksDBSessionStore
 
filter(Predicate<? super K, ? super V>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
filter(Predicate<? super K, ? super V>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
filter(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Create a new KStream that consists of all records of this stream which satisfy the given predicate.
filter(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable that consists of all records of this KTable which satisfy the given predicate, with default serializers, deserializers, and state store.
filter(Predicate<? super K, ? super V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
filter(Predicate<? super K, ? super V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable that consists of all records of this KTable which satisfy the given predicate, with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
filter(Predicate<? super K, ? super V>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
filter(Predicate<? super K, ? super V>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
filter(Predicate<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
Create a new KStream that consists of all records of this stream which satisfy the given predicate.
filter(Predicate<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable that consists of all records of this KTable which satisfy the given predicate, with default serializers, deserializers, and state store.
filter(Predicate<? super K, ? super V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
filter(Predicate<? super K, ? super V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable that consists of all records of this KTable which satisfy the given predicate, with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
filterNot(Predicate<? super K, ? super V>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
filterNot(Predicate<? super K, ? super V>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
filterNot(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Create a new KStream that consists all records of this stream which do not satisfy the given predicate.
filterNot(Predicate<? super K, ? super V>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable that consists all records of this KTable which do not satisfy the given predicate, with default serializers, deserializers, and state store.
filterNot(Predicate<? super K, ? super V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
filterNot(Predicate<? super K, ? super V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable that consists all records of this KTable which do not satisfy the given predicate, with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
filterNot(Predicate<? super K, ? super V>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
filterNot(Predicate<? super K, ? super V>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
filterNot(Predicate<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
Create a new KStream that consists all records of this stream which do not satisfy the given predicate.
filterNot(Predicate<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable that consists all records of this KTable which do not satisfy the given predicate, with default serializers, deserializers, and state store.
filterNot(Predicate<? super K, ? super V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
filterNot(Predicate<? super K, ? super V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable that consists all records of this KTable which do not satisfy the given predicate, with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
FinalResultsSuppressionBuilder<K extends Windowed> - Class in org.apache.kafka.streams.kstream.internals.suppress
 
FinalResultsSuppressionBuilder(String, Suppressed.StrictBufferConfig) - Constructor for class org.apache.kafka.streams.kstream.internals.suppress.FinalResultsSuppressionBuilder
 
findAndVerifyWindowGrace(StreamsGraphNode) - Static method in class org.apache.kafka.streams.kstream.internals.graph.GraphGraceSearchUtil
 
findSessions(K, long, long) - Method in class org.apache.kafka.streams.state.internals.MeteredSessionStore
 
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 class org.apache.kafka.streams.state.internals.MeteredSessionStore
 
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.
findSessions(Bytes, long, long) - Method in class org.apache.kafka.streams.state.internals.InMemorySessionStore
Deprecated.
findSessions(Bytes, long, long) - Method in class org.apache.kafka.streams.state.internals.RocksDBSessionStore
 
findSessions(Bytes, Bytes, long, long) - Method in class org.apache.kafka.streams.state.internals.InMemorySessionStore
Deprecated.
findSessions(Bytes, Bytes, long, long) - Method in class org.apache.kafka.streams.state.internals.RocksDBSessionStore
 
flatMap(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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.
flush() - Method in class org.apache.kafka.streams.processor.internals.GlobalStateManagerImpl
 
flush() - Method in class org.apache.kafka.streams.processor.internals.ProcessorStateManager
 
flush() - Method in interface org.apache.kafka.streams.processor.internals.RecordCollector
Flush the internal Producer.
flush() - Method in class org.apache.kafka.streams.processor.internals.RecordCollectorImpl
 
flush() - Method in interface org.apache.kafka.streams.processor.StateStore
Flush any cached data
flush() - Method in class org.apache.kafka.streams.state.internals.AbstractRocksDBSegmentedBytesStore
 
flush() - Method in class org.apache.kafka.streams.state.internals.CachingKeyValueStore
 
flush() - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
flush() - Method in class org.apache.kafka.streams.state.internals.InMemorySessionStore
 
flush() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
flush() - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowStore
 
flush() - Method in class org.apache.kafka.streams.state.internals.KeyValueToTimestampedKeyValueByteStoreAdapter
 
flush() - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
flush() - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
flush() - Method in class org.apache.kafka.streams.state.internals.MeteredSessionStore
 
flush() - Method in class org.apache.kafka.streams.state.internals.MeteredWindowStore
 
flush() - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
flush() - Method in class org.apache.kafka.streams.state.internals.WrappedStateStore
 
flush(String) - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 
flushes() - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 
flushSensor(String, String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.state.internals.metrics.StateStoreMetrics
 
flushState() - Method in class org.apache.kafka.streams.processor.internals.GlobalStateUpdateTask
 
forceConsistencyChecks() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
forChangelog(boolean) - Method in class org.apache.kafka.streams.kstream.WindowedSerdes.TimeWindowedSerde
 
foreach(ForeachAction<? super K, ? super V>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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.
ForeignJoinSubscriptionProcessorSupplier<K,​KO,​VO> - Class in org.apache.kafka.streams.kstream.internals.foreignkeyjoin
 
ForeignJoinSubscriptionProcessorSupplier(StoreBuilder<TimestampedKeyValueStore<Bytes, SubscriptionWrapper<K>>>, CombinedKeySchema<KO, K>) - Constructor for class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.ForeignJoinSubscriptionProcessorSupplier
 
ForeignJoinSubscriptionSendProcessorSupplier<K,​KO,​V> - Class in org.apache.kafka.streams.kstream.internals.foreignkeyjoin
 
ForeignJoinSubscriptionSendProcessorSupplier(Function<V, KO>, Supplier<String>, Supplier<String>, Serde<KO>, Serializer<V>, boolean) - Constructor for class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.ForeignJoinSubscriptionSendProcessorSupplier
 
forward(K, V) - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
forward(K, V) - Method in class org.apache.kafka.streams.processor.internals.GlobalProcessorContextImpl
 
forward(K, V) - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
forward(K, V) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Forwards a key/value pair to all downstream processors.
forward(K, V, int) - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
Deprecated.
forward(K, V, int) - Method in class org.apache.kafka.streams.processor.internals.GlobalProcessorContextImpl
Deprecated.
forward(K, V, int) - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
Deprecated.
forward(K, V, int) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Deprecated.
forward(K, V, String) - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
Deprecated.
forward(K, V, String) - Method in class org.apache.kafka.streams.processor.internals.GlobalProcessorContextImpl
Deprecated.
forward(K, V, String) - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
Deprecated.
forward(K, V, String) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Deprecated.
forward(K, V, To) - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
forward(K, V, To) - Method in class org.apache.kafka.streams.processor.internals.GlobalProcessorContextImpl
No-op.
forward(K, V, To) - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
forward(K, V, To) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Forwards a key/value pair to the specified downstream processors.
ForwardingDisabledProcessorContext - Class in org.apache.kafka.streams.processor.internals
ProcessorContext implementation that will throw on any forward call.
ForwardingDisabledProcessorContext(ProcessorContext) - Constructor for class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
forwardSensor(String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ProcessorNodeMetrics
 
from(byte[], long, Deserializer<K>, String) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
from(byte[], Deserializer<K>, String) - Static method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
from(Bytes) - Static method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
from(Windowed<Bytes>, Deserializer<K>, String) - Static method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
FROM_0100_TO_24 - org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl.Version
 
fromBytes(Bytes) - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.CombinedKeySchema
 
fromNameAndType(String, QueryableStoreType<T>) - Static method in class org.apache.kafka.streams.StoreQueryParameters
 
fromStoreBytesKey(byte[], long) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
fromStoreKey(byte[], long, Deserializer<K>, String) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
fromStoreKey(Windowed<Bytes>, Deserializer<K>, String) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
fromStruct(Struct, short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
fromStruct(Struct, short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
fromStruct(Struct, short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
fromStruct(Struct, short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
fromValue(byte) - Static method in enum org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionWrapper.Instruction
 
FullChangeSerde<T> - Class in org.apache.kafka.streams.kstream.internals
 

G

get() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.ForeignJoinSubscriptionProcessorSupplier
 
get() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.ForeignJoinSubscriptionSendProcessorSupplier
 
get() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionJoinForeignProcessorSupplier
 
get() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionResolverJoinProcessorSupplier
 
get() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionStoreReceiveProcessorSupplier
 
get() - Method in class org.apache.kafka.streams.kstream.internals.KStreamAggregate
 
get() - Method in class org.apache.kafka.streams.kstream.internals.KStreamFlatTransform
 
get() - Method in class org.apache.kafka.streams.kstream.internals.KStreamFlatTransformValues
 
get() - Method in class org.apache.kafka.streams.kstream.internals.KStreamPrint
 
get() - Method in class org.apache.kafka.streams.kstream.internals.KStreamReduce
 
get() - Method in class org.apache.kafka.streams.kstream.internals.KStreamSessionWindowAggregate
 
get() - Method in class org.apache.kafka.streams.kstream.internals.KStreamTransformValues
 
get() - Method in class org.apache.kafka.streams.kstream.internals.KStreamWindowAggregate
 
get() - Method in class org.apache.kafka.streams.kstream.internals.KTableAggregate
 
get() - Method in class org.apache.kafka.streams.kstream.internals.KTableKTableJoinMerger
 
get() - Method in class org.apache.kafka.streams.kstream.internals.KTableMaterializedValueGetterSupplier
 
get() - Method in class org.apache.kafka.streams.kstream.internals.KTableReduce
 
get() - Method in class org.apache.kafka.streams.kstream.internals.KTableRepartitionMap
 
get() - Method in class org.apache.kafka.streams.kstream.internals.KTableSource
 
get() - Method in class org.apache.kafka.streams.kstream.internals.KTableSourceValueGetterSupplier
 
get() - Method in interface org.apache.kafka.streams.kstream.internals.KTableValueGetterSupplier
 
get() - Method in class org.apache.kafka.streams.kstream.internals.suppress.KTableSuppressProcessorSupplier
 
get() - Method in class org.apache.kafka.streams.kstream.internals.TransformerSupplierAdapter
 
get() - Method in interface org.apache.kafka.streams.kstream.TransformerSupplier
Return a new Transformer instance.
get() - Method in interface org.apache.kafka.streams.kstream.ValueTransformerSupplier
Return a new ValueTransformer instance.
get() - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKeySupplier
 
get() - Method in interface org.apache.kafka.streams.processor.ProcessorSupplier
Return a new Processor instance.
get() - Method in class org.apache.kafka.streams.state.internals.InMemorySessionBytesStoreSupplier
 
get() - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowBytesStoreSupplier
 
get() - Method in class org.apache.kafka.streams.state.internals.RocksDbKeyValueBytesStoreSupplier
 
get() - Method in class org.apache.kafka.streams.state.internals.RocksDbSessionBytesStoreSupplier
 
get() - Method in class org.apache.kafka.streams.state.internals.RocksDbWindowBytesStoreSupplier
 
get() - Method in interface org.apache.kafka.streams.state.StoreSupplier
Return a new StateStore instance.
get(String, Bytes) - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 
get(K) - Method in interface org.apache.kafka.streams.kstream.internals.KTableValueGetter
 
get(K) - Method in class org.apache.kafka.streams.state.internals.CompositeReadOnlyKeyValueStore
 
get(K) - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
get(K) - Method in class org.apache.kafka.streams.state.internals.ReadOnlyKeyValueStoreFacade
 
get(K) - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
Get the value corresponding to this key.
get(Bytes) - Method in class org.apache.kafka.streams.state.internals.AbstractRocksDBSegmentedBytesStore
 
get(Bytes) - Method in class org.apache.kafka.streams.state.internals.CachingKeyValueStore
 
get(Bytes) - Method in class org.apache.kafka.streams.state.internals.ChangeLoggingKeyValueBytesStore
 
get(Bytes) - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
get(Bytes) - Method in class org.apache.kafka.streams.state.internals.KeyValueToTimestampedKeyValueByteStoreAdapter
 
get(Bytes) - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
get(Bytes) - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
get(Bytes) - Method in interface org.apache.kafka.streams.state.internals.SegmentedBytesStore
Get the record from the store with the given key.
getActiveHost() - Method in class org.apache.kafka.streams.KeyQueryMetadata
Get the Active streams instance for given key
getActiveTasks(List<TopicPartition>, AssignmentInfo) - Static method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
getActiveTasksFromTaskOffsetSumMap(Map<TaskId, Long>) - Static method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
getAdmin(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
Create an Admin which is used for internal topic management.
getAdmin(Map<String, Object>) - Method in class org.apache.kafka.streams.processor.internals.DefaultKafkaClientSupplier
 
getAdminClient(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
Deprecated.
Not called by Kafka Streams, which now uses KafkaClientSupplier.getAdmin(java.util.Map<java.lang.String, java.lang.Object>) instead.
getAdminClient(Map<String, Object>) - Method in class org.apache.kafka.streams.processor.internals.DefaultKafkaClientSupplier
Deprecated.
getAdminConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
Get the configs for the admin client.
getAllMetadata() - Method in class org.apache.kafka.streams.processor.internals.StreamsMetadataState
Find all of the StreamsMetadatas in a application
getAllMetadataForStore(String) - Method in class org.apache.kafka.streams.processor.internals.StreamsMetadataState
Find all of the StreamsMetadatas for a given storeName
getChangelogTopicToStore() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
getConsumer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
Create a Consumer which is used to read records of source topics.
getConsumer(Map<String, Object>) - Method in class org.apache.kafka.streams.processor.internals.DefaultKafkaClientSupplier
 
getConsumerClientId(String) - Static method in class org.apache.kafka.streams.processor.internals.ClientUtils
 
getConsumerConfigs(String, String) - Method in class org.apache.kafka.streams.StreamsConfig
getEndOffsets(KafkaFuture<Map<TopicPartition, ListOffsetsResult.ListOffsetsResultInfo>>) - Static method in class org.apache.kafka.streams.processor.internals.ClientUtils
A helper method that wraps the Future#get call and rethrows any thrown exception as a StreamsException
getEnv() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
getForeignKey() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.CombinedKey
 
getForeignValue() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionResponseWrapper
 
getGlobalConsumer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
Create a Consumer which is used to consume records for GlobalKTable.
getGlobalConsumer(Map<String, Object>) - Method in class org.apache.kafka.streams.processor.internals.DefaultKafkaClientSupplier
 
getGlobalConsumerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
Get the configs for the global consumer.
getGlobalStore(String) - Method in class org.apache.kafka.streams.processor.internals.GlobalStateManagerImpl
 
getGlobalStore(String) - Method in class org.apache.kafka.streams.processor.internals.ProcessorStateManager
 
getHash() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionWrapper
 
getInstruction() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionWrapper
 
getKeyDeserializer(ProcessorContext) - Static method in class org.apache.kafka.streams.processor.internals.ProcessorContextUtils
 
getKeyQueryMetadataForKey(String, K, Serializer<K>) - Method in class org.apache.kafka.streams.processor.internals.StreamsMetadataState
Find the KeyQueryMetadatas for a given storeName and key.
getKeyQueryMetadataForKey(String, K, StreamPartitioner<? super K, ?>) - Method in class org.apache.kafka.streams.processor.internals.StreamsMetadataState
Find the KeyQueryMetadatas for a given storeName and key Note: the key may not exist in the StateStore,this method provides a way of finding which StreamsMetadata it would exist on.
getKeySerializer(ProcessorContext) - Static method in class org.apache.kafka.streams.processor.internals.ProcessorContextUtils
 
getLocalMetadata() - Method in class org.apache.kafka.streams.processor.internals.StreamsMetadataState
Get the StreamsMetadatas for the local instance in a application
getLogConfig() - Method in class org.apache.kafka.streams.kstream.internals.suppress.BufferConfigInternal
 
getLogConfig() - Method in class org.apache.kafka.streams.kstream.internals.suppress.EagerBufferConfigImpl
 
getLogConfig() - Method in class org.apache.kafka.streams.kstream.internals.suppress.StrictBufferConfigImpl
 
getMainConsumerConfigs(String, String, int) - Method in class org.apache.kafka.streams.StreamsConfig
Get the configs to the main consumer.
getMetadataWithKey(String, K, Serializer<K>) - Method in class org.apache.kafka.streams.processor.internals.StreamsMetadataState
getMetadataWithKey(String, K, StreamPartitioner<? super K, ?>) - Method in class org.apache.kafka.streams.processor.internals.StreamsMetadataState
getNullableValue() - Method in class org.apache.kafka.streams.state.internals.Maybe
 
getNumberOfPartitions() - Method in class org.apache.kafka.streams.processor.internals.InternalTopicProperties
 
getNumPartitions(Set<String>) - Method in class org.apache.kafka.streams.processor.internals.InternalTopicManager
Try to get the number of partitions for the given topics; return the number of partitions for topics that already exists.
getOptions() - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
getOriginalValueHash() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionResponseWrapper
 
getPartition() - Method in class org.apache.kafka.streams.KeyQueryMetadata
Get the Store partition corresponding to the key.
getPrimaryKey() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.CombinedKey
 
getPrimaryKey() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionWrapper
 
getProducer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
Create a Producer which is used to write records to sink topics.
getProducer(Map<String, Object>) - Method in class org.apache.kafka.streams.processor.internals.DefaultKafkaClientSupplier
 
getProducerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
Get the configs for the producer.
getProperties(Map<String, String>, long) - Method in class org.apache.kafka.streams.processor.internals.InternalTopicConfig
Get the configured properties for this topic.
getProperties(Map<String, String>, long) - Method in class org.apache.kafka.streams.processor.internals.RepartitionTopicConfig
Get the configured properties for this topic.
getProperties(Map<String, String>, long) - Method in class org.apache.kafka.streams.processor.internals.UnwindowedChangelogTopicConfig
Get the configured properties for this topic.
getProperties(Map<String, String>, long) - Method in class org.apache.kafka.streams.processor.internals.WindowedChangelogTopicConfig
Get the configured properties for this topic.
getQueryableName() - Method in class org.apache.kafka.streams.kstream.internals.KTableKTableJoinMerger
 
getRestoreConsumer(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
Create a Consumer which is used to read records to restore StateStores.
getRestoreConsumer(Map<String, Object>) - Method in class org.apache.kafka.streams.processor.internals.DefaultKafkaClientSupplier
 
getRestoreConsumerClientId(String) - Static method in class org.apache.kafka.streams.processor.internals.ClientUtils
 
getRestoreConsumerConfigs(String) - Method in class org.apache.kafka.streams.StreamsConfig
Get the configs for the restore-consumer.
gets() - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 
getSensor - Variable in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
getSensor(String, String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.state.internals.metrics.StateStoreMetrics
 
getSharedAdminClientId(String) - Static method in class org.apache.kafka.streams.processor.internals.ClientUtils
 
getStandbyHosts() - Method in class org.apache.kafka.streams.KeyQueryMetadata
Get the Streams instances that host the key as standbys
getStandbyTasksFromTaskOffsetSumMap(Map<TaskId, Long>) - Static method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
getStateStore(String) - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
getStateStore(String) - Method in class org.apache.kafka.streams.processor.internals.GlobalProcessorContextImpl
 
getStateStore(String) - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
getStateStore(String) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Get the state store given the store name.
getStateStore(StoreBuilder<T>) - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
Get a correctly typed state store, given a handle on the original builder.
getStore(String) - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
getStore(String) - Method in class org.apache.kafka.streams.processor.internals.GlobalStateManagerImpl
 
getStore(String) - Method in class org.apache.kafka.streams.processor.internals.ProcessorStateManager
 
getStore(String) - Method in interface org.apache.kafka.streams.processor.internals.Task
 
getStore(StoreQueryParameters<T>) - Method in class org.apache.kafka.streams.state.internals.QueryableStoreProvider
Get a composite object wrapping the instances of the StateStore with the provided storeName and QueryableStoreType
getStoreForChangelogTopic(String) - Method in class org.apache.kafka.streams.processor.internals.StreamsMetadataState
 
getStreamsCliSideAssignmentInternalStream() - Method in class org.apache.kafka.streams.StreamsConfig
 
getStreamsInternalStreamCompacted() - Method in class org.apache.kafka.streams.StreamsConfig
 
getStreamsInternalStreamFolder() - Method in class org.apache.kafka.streams.StreamsConfig
 
getStreamsInternalStreamNotcompacted() - Method in class org.apache.kafka.streams.StreamsConfig
 
getTaskOffsetSums() - Method in class org.apache.kafka.streams.processor.internals.TaskManager
Compute the offset total summed across all stores in a task.
getTaskProducerClientId(String, TaskId) - Static method in class org.apache.kafka.streams.processor.internals.ClientUtils
 
getThreadProducerClientId(String) - Static method in class org.apache.kafka.streams.processor.internals.ClientUtils
 
getTimestampExtractor() - Method in class org.apache.kafka.streams.processor.internals.SourceNode
 
getValue() - Method in enum org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionWrapper.Instruction
 
getValueDeserializer(ProcessorContext) - Static method in class org.apache.kafka.streams.processor.internals.ProcessorContextUtils
 
getValueOrNull(ValueAndTimestamp<V>) - Static method in class org.apache.kafka.streams.state.ValueAndTimestamp
Return the wrapped value of the given valueAndTimestamp parameter if the parameter is not null.
getValueSerializer(ProcessorContext) - Static method in class org.apache.kafka.streams.processor.internals.ProcessorContextUtils
 
getVersion() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionResponseWrapper
 
getVersion() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionWrapper
 
getWindowSize() - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
 
getWithBinary(K) - Method in class org.apache.kafka.streams.state.internals.MeteredTimestampedKeyValueStore
 
GLOBAL - org.apache.kafka.streams.processor.internals.Task.TaskType
 
GLOBAL_CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
Prefix used to override consumer configs for the global consumer client from the general consumer client configs.
globalConsumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
Prefix a property with StreamsConfig.GLOBAL_CONSUMER_PREFIX.
GlobalKTable<K,​V> - Interface in org.apache.kafka.streams.kstream
GlobalKTable is an abstraction of a changelog stream from a primary-keyed table.
GlobalKTableImpl<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
GlobalProcessorContextImpl - Class in org.apache.kafka.streams.processor.internals
 
GlobalProcessorContextImpl(StreamsConfig, StateManager, StreamsMetricsImpl, ThreadCache) - Constructor for class org.apache.kafka.streams.processor.internals.GlobalProcessorContextImpl
 
GlobalStateManager - Interface in org.apache.kafka.streams.processor.internals
 
GlobalStateManagerImpl - Class in org.apache.kafka.streams.processor.internals
This class is responsible for the initialization, restoration, closing, flushing etc of Global State Stores.
GlobalStateManagerImpl(LogContext, ProcessorTopology, Consumer<byte[], byte[]>, StateDirectory, StateRestoreListener, StreamsConfig) - Constructor for class org.apache.kafka.streams.processor.internals.GlobalStateManagerImpl
 
GlobalStateStoreProvider - Class in org.apache.kafka.streams.state.internals
 
GlobalStateStoreProvider(Map<String, StateStore>) - Constructor for class org.apache.kafka.streams.state.internals.GlobalStateStoreProvider
 
globalStateStores() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
Get any global StateStores that are part of the topology
globalStateStores() - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
GlobalStateUpdateTask - Class in org.apache.kafka.streams.processor.internals
Updates the state for all Global State Stores.
GlobalStateUpdateTask(LogContext, ProcessorTopology, InternalProcessorContext, GlobalStateManager, DeserializationExceptionHandler) - Constructor for class org.apache.kafka.streams.processor.internals.GlobalStateUpdateTask
 
GlobalStore(String, String, String, String, int) - Constructor for class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.GlobalStore
 
GlobalStoreNode<K,​V,​S extends StateStore> - Class in org.apache.kafka.streams.kstream.internals.graph
 
GlobalStoreNode(StoreBuilder<S>, String, String, ConsumedInternal<K, V>, String, ProcessorSupplier<K, V>) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.GlobalStoreNode
 
globalStores() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopologyDescription
 
globalStores() - Method in interface org.apache.kafka.streams.TopologyDescription
All global stores of the represented topology.
GlobalStreamThread - Class in org.apache.kafka.streams.processor.internals
This is the thread responsible for keeping all Global State Stores updated.
GlobalStreamThread(ProcessorTopology, StreamsConfig, Consumer<byte[], byte[]>, StateDirectory, long, StreamsMetricsImpl, Time, String, StateRestoreListener) - Constructor for class org.apache.kafka.streams.processor.internals.GlobalStreamThread
 
GlobalStreamThread.State - Enum in org.apache.kafka.streams.processor.internals
The states that the global stream thread can be in
globalTable(String) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a GlobalKTable for the specified topic.
globalTable(String, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a GlobalKTable for the specified topic.
globalTable(String, Consumed<K, V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a GlobalKTable for the specified topic.
globalTable(String, ConsumedInternal<K, V>, MaterializedInternal<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.InternalStreamsBuilder
 
globalTable(String, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a GlobalKTable for the specified topic.
grace(Duration) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Reject out-of-order events that are delayed more than afterWindowEnd after the end of its window.
grace(Duration) - Method in class org.apache.kafka.streams.kstream.SessionWindows
Reject out-of-order events that arrive more than afterWindowEnd after the end of its window.
grace(Duration) - Method in class org.apache.kafka.streams.kstream.TimeWindows
Reject out-of-order events that arrive more than millisAfterWindowEnd after the end of its window.
gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.JoinWindows
 
gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.SessionWindows
 
gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.TimeWindows
 
gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
 
gracePeriodMs() - Method in class org.apache.kafka.streams.kstream.Windows
Return the window grace period (the time to admit out-of-order events after the end of the window.) Delay is defined as (stream_time - record_timestamp).
GraphGraceSearchUtil - Class in org.apache.kafka.streams.kstream.internals.graph
 
GROUP_PREFIX - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
GROUP_PREFIX_WO_DELIMITER - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
GROUP_SUFFIX - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
groupBy(KeyValueMapper<? super K, ? super V, KR>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
groupBy(KeyValueMapper<? super K, ? super V, KR>) - Method in interface org.apache.kafka.streams.kstream.KStream
Group the records of this KStream on a new key that is selected using the provided KeyValueMapper and default serializers and deserializers.
groupBy(KeyValueMapper<? super K, ? super V, KR>, Grouped<KR, V>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
groupBy(KeyValueMapper<? super K, ? super V, KR>, Grouped<KR, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Group the records of this KStream on a new key that is selected using the provided KeyValueMapper and Serdes as specified by Grouped.
groupBy(KeyValueMapper<? super K, ? super V, KR>, Serialized<KR, V>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
Deprecated.
groupBy(KeyValueMapper<? super K, ? super V, KR>, Serialized<KR, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Deprecated.
groupBy(KeyValueMapper<? super K, ? super V, KeyValue<K1, V1>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
groupBy(KeyValueMapper<? super K, ? super V, KeyValue<K1, V1>>, Grouped<K1, V1>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
groupBy(KeyValueMapper<? super K, ? super V, KeyValue<K1, V1>>, Serialized<K1, V1>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
Deprecated.
groupBy(KeyValueMapper<? super K, ? super V, KeyValue<KR, VR>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Re-groups the records of this KTable using the provided KeyValueMapper and default serializers and deserializers.
groupBy(KeyValueMapper<? super K, ? super V, KeyValue<KR, VR>>, Grouped<KR, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Re-groups the records of this KTable using the provided KeyValueMapper and Serdes as specified by Grouped.
groupBy(KeyValueMapper<? super K, ? super V, KeyValue<KR, VR>>, Serialized<KR, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Deprecated.
groupByKey() - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
groupByKey() - Method in interface org.apache.kafka.streams.kstream.KStream
Group the records by their current key into a KGroupedStream while preserving the original values and default serializers and deserializers.
groupByKey(Grouped<K, V>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
groupByKey(Grouped<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Group the records by their current key into a KGroupedStream while preserving the original values and using the serializers as defined by Grouped.
groupByKey(Serialized<K, V>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
Deprecated.
groupByKey(Serialized<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Deprecated.
since 2.1. Use KStream.groupByKey(Grouped) instead
Grouped<K,​V> - Class in org.apache.kafka.streams.kstream
The class that is used to capture the key and value Serdes and set the part of name used for repartition topics when performing KStream.groupBy(KeyValueMapper, Grouped), KStream.groupByKey(Grouped), or KTable.groupBy(KeyValueMapper, Grouped) operations.
Grouped(Grouped<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Grouped
 
GroupedInternal<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
GroupedInternal(Grouped<K, V>) - Constructor for class org.apache.kafka.streams.kstream.internals.GroupedInternal
 
groupedTableOperationNodeBuilder() - Static method in class org.apache.kafka.streams.kstream.internals.graph.GroupedTableOperationRepartitionNode
 
GroupedTableOperationRepartitionNode<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
 
GroupedTableOperationRepartitionNode.GroupedTableOperationRepartitionNodeBuilder<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
 
GroupedTableOperationRepartitionNodeBuilder() - Constructor for class org.apache.kafka.streams.kstream.internals.graph.GroupedTableOperationRepartitionNode.GroupedTableOperationRepartitionNodeBuilder
 

H

handle(ProducerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.DefaultProductionExceptionHandler
 
handle(ProducerRecord<byte[], byte[]>, Exception) - Method in interface org.apache.kafka.streams.errors.ProductionExceptionHandler
Inspect a record that we attempted to produce, and the exception that resulted from attempting to produce it and determine whether or not to continue processing.
handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in interface org.apache.kafka.streams.errors.DeserializationExceptionHandler
Inspect a record and the exception received.
handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndContinueExceptionHandler
 
handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.apache.kafka.streams.errors.LogAndFailExceptionHandler
 
handleAssignment(Map<TaskId, Set<TopicPartition>>, Map<TaskId, Set<TopicPartition>>) - Method in class org.apache.kafka.streams.processor.internals.TaskManager
 
handleRebalanceStart(Set<String>) - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
hardPendingCompactionBytesLimit() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
hasEnforcedNumberOfPartitions() - Method in class org.apache.kafka.streams.processor.internals.InternalTopicConfig
 
hash128(byte[]) - Static method in class org.apache.kafka.streams.state.internals.Murmur3
Murmur3 128-bit variant.
hash128(byte[], int, int, int) - Static method in class org.apache.kafka.streams.state.internals.Murmur3
Murmur3 128-bit variant.
hash32(byte[]) - Static method in class org.apache.kafka.streams.state.internals.Murmur3
Murmur3 32-bit variant.
hash32(byte[], int) - Static method in class org.apache.kafka.streams.state.internals.Murmur3
Murmur3 32-bit variant.
hash32(byte[], int, int) - Static method in class org.apache.kafka.streams.state.internals.Murmur3
Murmur3 32-bit variant.
hash32(byte[], int, int, int) - Static method in class org.apache.kafka.streams.state.internals.Murmur3
Murmur3 32-bit variant.
hash32(long) - Static method in class org.apache.kafka.streams.state.internals.Murmur3
 
hash32(long, int) - Static method in class org.apache.kafka.streams.state.internals.Murmur3
Murmur3 32-bit variant.
hash32(long, long) - Static method in class org.apache.kafka.streams.state.internals.Murmur3
 
hash32(long, long, int) - Static method in class org.apache.kafka.streams.state.internals.Murmur3
Murmur3 32-bit variant.
hash64(byte[]) - Static method in class org.apache.kafka.streams.state.internals.Murmur3
Murmur3 64-bit variant.
hash64(byte[], int, int) - Static method in class org.apache.kafka.streams.state.internals.Murmur3
 
hash64(byte[], int, int, int) - Static method in class org.apache.kafka.streams.state.internals.Murmur3
Murmur3 64-bit variant.
hash64(int) - Static method in class org.apache.kafka.streams.state.internals.Murmur3
 
hash64(long) - Static method in class org.apache.kafka.streams.state.internals.Murmur3
 
hash64(short) - Static method in class org.apache.kafka.streams.state.internals.Murmur3
 
hashCode() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
hashCode() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
hashCode() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
hashCode() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
hashCode() - Method in class org.apache.kafka.streams.KeyQueryMetadata
 
hashCode() - Method in class org.apache.kafka.streams.KeyValue
 
hashCode() - Method in class org.apache.kafka.streams.kstream.Consumed
 
hashCode() - Method in class org.apache.kafka.streams.kstream.internals.Change
 
hashCode() - Method in class org.apache.kafka.streams.kstream.internals.suppress.EagerBufferConfigImpl
 
hashCode() - Method in class org.apache.kafka.streams.kstream.internals.suppress.FinalResultsSuppressionBuilder
 
hashCode() - Method in class org.apache.kafka.streams.kstream.internals.suppress.StrictBufferConfigImpl
 
hashCode() - Method in class org.apache.kafka.streams.kstream.internals.suppress.SuppressedInternal
 
hashCode() - Method in class org.apache.kafka.streams.kstream.JoinWindows
 
hashCode() - Method in class org.apache.kafka.streams.kstream.Produced
 
hashCode() - Method in class org.apache.kafka.streams.kstream.SessionWindows
 
hashCode() - Method in class org.apache.kafka.streams.kstream.TimeWindows
 
hashCode() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
 
hashCode() - Method in class org.apache.kafka.streams.kstream.Window
 
hashCode() - Method in class org.apache.kafka.streams.kstream.Windowed
 
hashCode() - Method in class org.apache.kafka.streams.LagInfo
 
hashCode() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
hashCode() - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
hashCode() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.GlobalStore
 
hashCode() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Processor
 
hashCode() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Sink
 
hashCode() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Source
 
hashCode() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Subtopology
 
hashCode() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopicsInfo
 
hashCode() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopologyDescription
 
hashCode() - Method in class org.apache.kafka.streams.processor.internals.ProcessorRecordContext
Deprecated.
hashCode() - Method in class org.apache.kafka.streams.processor.internals.PunctuationSchedule
 
hashCode() - Method in class org.apache.kafka.streams.processor.internals.RepartitionTopicConfig
 
hashCode() - Method in class org.apache.kafka.streams.processor.internals.Stamped
 
hashCode() - Method in class org.apache.kafka.streams.processor.internals.StaticTopicNameExtractor
 
hashCode() - Method in class org.apache.kafka.streams.processor.internals.UnwindowedChangelogTopicConfig
 
hashCode() - Method in class org.apache.kafka.streams.processor.internals.WindowedChangelogTopicConfig
 
hashCode() - Method in class org.apache.kafka.streams.processor.TaskId
 
hashCode() - Method in class org.apache.kafka.streams.processor.TaskMetadata
 
hashCode() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
hashCode() - Method in class org.apache.kafka.streams.processor.To
Equality is implemented in support of tests, *not* for use in Hash collections, since this class is mutable.
hashCode() - Method in class org.apache.kafka.streams.state.HostInfo
 
hashCode() - Method in class org.apache.kafka.streams.state.internals.BufferKey
 
hashCode() - Method in class org.apache.kafka.streams.state.internals.BufferValue
 
hashCode() - Method in class org.apache.kafka.streams.state.internals.ContextualRecord
 
hashCode() - Method in class org.apache.kafka.streams.state.internals.Maybe
 
hashCode() - Method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics.RocksDBMetricContext
 
hashCode() - Method in class org.apache.kafka.streams.state.internals.TimeOrderedKeyValueBuffer.Eviction
 
hashCode() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
hashCode() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
 
hashCode() - Method in class org.apache.kafka.streams.StoreQueryParameters
 
hasNext() - Method in class org.apache.kafka.streams.state.internals.DelegatingPeekingKeyValueIterator
 
hasNext() - Method in class org.apache.kafka.streams.state.internals.KeyValueIteratorFacade
 
hasNextCondition(Bytes, Bytes, long, long) - Method in interface org.apache.kafka.streams.state.internals.SegmentedBytesStore.KeySchema
Create an implementation of HasNextCondition that knows when to stop iterating over the KeyValueSegments.
hasNextCondition(Bytes, Bytes, long, long) - Method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
hasNextCondition(Bytes, Bytes, long, long) - Method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
hasNoNonGlobalTopology() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
hasPersistentGlobalStore() - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
hasPersistentLocalStore() - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
hasRecordsQueued() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
hasStore(String) - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
hasTimestamp() - Method in class org.apache.kafka.streams.processor.internals.ToInternal
 
hasWrittenToTopology() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
headers() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
headers() - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
headers() - Method in class org.apache.kafka.streams.processor.internals.ProcessorRecordContext
 
headers() - Method in class org.apache.kafka.streams.processor.internals.StampedRecord
 
headers() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the headers of the current input record; could be null if it is not available (for example, if this method is invoked from the punctuate call).
headers() - Method in interface org.apache.kafka.streams.processor.RecordContext
 
headRecordOffset() - Method in class org.apache.kafka.streams.processor.internals.RecordQueue
 
headRecordTimestamp() - Method in class org.apache.kafka.streams.processor.internals.RecordQueue
Returns the head record's timestamp
HighAvailabilityTaskAssignor - Class in org.apache.kafka.streams.processor.internals.assignment
 
HighAvailabilityTaskAssignor() - Constructor for class org.apache.kafka.streams.processor.internals.assignment.HighAvailabilityTaskAssignor
 
highestSupportedVersion() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
highestSupportedVersion() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
highestSupportedVersion() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
highestSupportedVersion() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
hitRatioSensor(StreamsMetricsImpl, String, String, String) - Static method in class org.apache.kafka.streams.state.internals.metrics.NamedCacheMetrics
 
host() - Method in class org.apache.kafka.streams.state.HostInfo
 
host() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
hostInfo() - Method in class org.apache.kafka.streams.state.StreamsMetadata
The value of StreamsConfig.APPLICATION_SERVER_CONFIG configured for the streams instance, which is typically host/port
HostInfo - Class in org.apache.kafka.streams.state
Represents a user defined endpoint in a KafkaStreams application.
HostInfo(String, int) - Constructor for class org.apache.kafka.streams.state.HostInfo
 

I

id - Variable in enum org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
the permanent and immutable id of an API--this can't change ever
id - Variable in enum org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
the permanent and immutable id of an API--this can't change ever
id - Variable in class org.apache.kafka.streams.processor.internals.AbstractTask
 
id() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
id() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.GlobalStore
 
id() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Subtopology
 
id() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
id() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
 
id() - Method in interface org.apache.kafka.streams.TopologyDescription.Subtopology
Internally assigned unique ID.
identity() - Static method in class org.apache.kafka.streams.state.internals.RecordConverters
 
inactivityGap() - Method in class org.apache.kafka.streams.kstream.SessionWindows
Return the specified gap for the session windows in milliseconds.
INCOMPLETE_SOURCE_TOPIC_METADATA - org.apache.kafka.streams.processor.internals.assignment.AssignorError
 
IncrementalHash32() - Constructor for class org.apache.kafka.streams.state.internals.Murmur3.IncrementalHash32
 
incrementCapacity() - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
infoLogLevel() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
init(InternalProcessorContext) - Method in class org.apache.kafka.streams.processor.internals.ProcessorNode
 
init(InternalProcessorContext) - Method in class org.apache.kafka.streams.processor.internals.SinkNode
 
init(InternalProcessorContext) - Method in class org.apache.kafka.streams.processor.internals.SourceNode
 
init(StreamsMetricsImpl, TaskId) - Method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetricsRecorder
The initialisation of the metrics recorder is idempotent.
init(ProcessorContext) - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.CombinedKeySchema
 
init(ProcessorContext) - Method in class org.apache.kafka.streams.kstream.internals.KStreamFlatTransform.KStreamFlatTransformProcessor
 
init(ProcessorContext) - Method in class org.apache.kafka.streams.kstream.internals.KStreamFlatTransformValues.KStreamFlatTransformValuesProcessor
 
init(ProcessorContext) - Method in class org.apache.kafka.streams.kstream.internals.KStreamTransformValues.KStreamTransformValuesProcessor
 
init(ProcessorContext) - Method in interface org.apache.kafka.streams.kstream.internals.KTableValueGetter
 
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.
init(ProcessorContext, StateStore) - Method in class org.apache.kafka.streams.state.internals.AbstractRocksDBSegmentedBytesStore
 
init(ProcessorContext, StateStore) - Method in class org.apache.kafka.streams.state.internals.CachingKeyValueStore
 
init(ProcessorContext, StateStore) - Method in class org.apache.kafka.streams.state.internals.ChangeLoggingKeyValueBytesStore
 
init(ProcessorContext, StateStore) - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
init(ProcessorContext, StateStore) - Method in class org.apache.kafka.streams.state.internals.InMemorySessionStore
 
init(ProcessorContext, StateStore) - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
init(ProcessorContext, StateStore) - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowStore
 
init(ProcessorContext, StateStore) - Method in class org.apache.kafka.streams.state.internals.KeyValueToTimestampedKeyValueByteStoreAdapter
 
init(ProcessorContext, StateStore) - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
init(ProcessorContext, StateStore) - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
init(ProcessorContext, StateStore) - Method in class org.apache.kafka.streams.state.internals.MeteredSessionStore
 
init(ProcessorContext, StateStore) - Method in class org.apache.kafka.streams.state.internals.MeteredWindowStore
 
init(ProcessorContext, StateStore) - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
init(ProcessorContext, StateStore) - Method in class org.apache.kafka.streams.state.internals.RocksDBWindowStore
 
init(ProcessorContext, StateStore) - Method in class org.apache.kafka.streams.state.internals.WrappedStateStore
 
initialize() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
initialize() - Method in interface org.apache.kafka.streams.processor.internals.GlobalStateManager
 
initialize() - Method in class org.apache.kafka.streams.processor.internals.GlobalStateManagerImpl
 
initialize() - Method in class org.apache.kafka.streams.processor.internals.GlobalStateUpdateTask
 
initialize() - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
Mark this context as being initialized
initialize() - Method in interface org.apache.kafka.streams.processor.internals.RecordCollector
Initialize the internal Producer; note this function should be made idempotent
initialize() - Method in class org.apache.kafka.streams.processor.internals.RecordCollectorImpl
 
initializeIfNeeded() - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
 
initializeIfNeeded() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
initializeIfNeeded() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
initializePrevTasks(Map<TopicPartition, TaskId>) - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
Initializer<VA> - Interface in org.apache.kafka.streams.kstream
The Initializer interface for creating an initial value in aggregations.
initNullableDeserializer(Deserializer<T>, Deserializer<?>, Deserializer<?>) - Static method in class org.apache.kafka.streams.kstream.internals.WrappingNullableUtils
 
initNullableSerializer(Serializer<T>, Serializer<?>, Serializer<?>) - Static method in class org.apache.kafka.streams.kstream.internals.WrappingNullableUtils
 
inMemoryKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
Create an in-memory KeyValueBytesStoreSupplier.
InMemoryKeyValueStore - Class in org.apache.kafka.streams.state.internals
 
InMemoryKeyValueStore(String) - Constructor for class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
InMemorySessionBytesStoreSupplier - Class in org.apache.kafka.streams.state.internals
 
InMemorySessionBytesStoreSupplier(String, long) - Constructor for class org.apache.kafka.streams.state.internals.InMemorySessionBytesStoreSupplier
 
inMemorySessionStore(String, Duration) - Static method in class org.apache.kafka.streams.state.Stores
Create an in-memory SessionBytesStoreSupplier.
InMemorySessionStore - Class in org.apache.kafka.streams.state.internals
 
InMemoryTimeOrderedKeyValueBuffer<K,​V> - Class in org.apache.kafka.streams.state.internals
 
InMemoryTimeOrderedKeyValueBuffer.Builder<K,​V> - Class in org.apache.kafka.streams.state.internals
 
InMemoryWindowBytesStoreSupplier - Class in org.apache.kafka.streams.state.internals
 
InMemoryWindowBytesStoreSupplier(String, long, long, boolean) - Constructor for class org.apache.kafka.streams.state.internals.InMemoryWindowBytesStoreSupplier
 
inMemoryWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
Create an in-memory WindowBytesStoreSupplier.
InMemoryWindowStore - Class in org.apache.kafka.streams.state.internals
 
inner - Variable in class org.apache.kafka.streams.state.internals.ReadOnlyKeyValueStoreFacade
 
inner - Variable in class org.apache.kafka.streams.state.internals.ReadOnlyWindowStoreFacade
 
inner() - Method in class org.apache.kafka.streams.kstream.internals.ChangedDeserializer
 
inner() - Method in class org.apache.kafka.streams.kstream.internals.ChangedSerializer
 
innerSerde() - Method in class org.apache.kafka.streams.kstream.internals.FullChangeSerde
 
inplaceUpdateNumLocks() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
inplaceUpdateSupport() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
inputPartitions - Variable in class org.apache.kafka.streams.processor.internals.AbstractTask
 
inputPartitions() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
inputPartitions() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
INTERNAL_TASK_ASSIGNOR_CLASS - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
 
InternalConfig() - Constructor for class org.apache.kafka.streams.StreamsConfig.InternalConfig
 
InternalNameProvider - Interface in org.apache.kafka.streams.kstream.internals
 
InternalProcessorContext - Interface in org.apache.kafka.streams.processor.internals
For internal use so we can update the RecordContext and current ProcessorNode when we are forwarding items that have been evicted or flushed from ThreadCache
InternalStreamNotExistException - Exception in org.apache.kafka.streams.errors.mapr
 
InternalStreamNotExistException(String) - Constructor for exception org.apache.kafka.streams.errors.mapr.InternalStreamNotExistException
 
InternalStreamNotExistException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.mapr.InternalStreamNotExistException
 
InternalStreamNotExistException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.mapr.InternalStreamNotExistException
 
InternalStreamsBuilder - Class in org.apache.kafka.streams.kstream.internals
 
InternalStreamsBuilder(InternalTopologyBuilder) - Constructor for class org.apache.kafka.streams.kstream.internals.InternalStreamsBuilder
 
InternalTopicConfig - Class in org.apache.kafka.streams.processor.internals
InternalTopicConfig captures the properties required for configuring the internal topics we create for change-logs and repartitioning etc.
internalTopicManager() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
InternalTopicManager - Class in org.apache.kafka.streams.processor.internals
 
InternalTopicManager(Admin, StreamsConfig) - Constructor for class org.apache.kafka.streams.processor.internals.InternalTopicManager
 
internalTopicProperties - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
internalTopicProperties - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode
 
InternalTopicProperties - Class in org.apache.kafka.streams.processor.internals
 
InternalTopicProperties(Integer) - Constructor for class org.apache.kafka.streams.processor.internals.InternalTopicProperties
 
internalTopologyBuilder() - Method in class org.apache.kafka.streams.kstream.internals.AbstractStream
 
InternalTopologyBuilder - Class in org.apache.kafka.streams.processor.internals
 
InternalTopologyBuilder() - Constructor for class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
InternalTopologyBuilder.AbstractNode - Class in org.apache.kafka.streams.processor.internals
 
InternalTopologyBuilder.GlobalStore - Class in org.apache.kafka.streams.processor.internals
 
InternalTopologyBuilder.Processor - Class in org.apache.kafka.streams.processor.internals
 
InternalTopologyBuilder.Sink<K,​V> - Class in org.apache.kafka.streams.processor.internals
 
InternalTopologyBuilder.Source - Class in org.apache.kafka.streams.processor.internals
 
InternalTopologyBuilder.StateStoreFactory<S extends StateStore> - Class in org.apache.kafka.streams.processor.internals
 
InternalTopologyBuilder.Subtopology - Class in org.apache.kafka.streams.processor.internals
 
InternalTopologyBuilder.TopicsInfo - Class in org.apache.kafka.streams.processor.internals
 
InternalTopologyBuilder.TopologyDescription - Class in org.apache.kafka.streams.processor.internals
 
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
 
isActive() - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
 
isActive() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
isActive() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
isAlive() - Method in enum org.apache.kafka.streams.processor.internals.StreamThread.State
 
isClosed() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
isClosed() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
isDefined() - Method in class org.apache.kafka.streams.state.internals.Maybe
 
isEmpty() - Method in interface org.apache.kafka.streams.processor.internals.ChangelogReader
 
isEmpty() - Method in class org.apache.kafka.streams.processor.internals.RecordQueue
Tests if the queue is empty
isEmpty() - Method in class org.apache.kafka.streams.processor.internals.StoreChangelogReader
 
isFdCloseOnExec() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
isGlobalKTable(boolean) - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode.TableSourceNodeBuilder
 
isKeyChangingOperation() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
isLoggingEnabled() - Method in class org.apache.kafka.streams.kstream.internals.suppress.BufferConfigInternal
 
isLoggingEnabled() - Method in class org.apache.kafka.streams.kstream.internals.suppress.EagerBufferConfigImpl
 
isLoggingEnabled() - Method in class org.apache.kafka.streams.kstream.internals.suppress.StrictBufferConfigImpl
 
isMergeNode() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
isOpen() - Method in interface org.apache.kafka.streams.processor.StateStore
Is this store open for reading and writing
isOpen() - Method in class org.apache.kafka.streams.state.internals.AbstractRocksDBSegmentedBytesStore
 
isOpen() - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
isOpen() - Method in class org.apache.kafka.streams.state.internals.InMemorySessionStore
 
isOpen() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
isOpen() - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowStore
 
isOpen() - Method in class org.apache.kafka.streams.state.internals.KeyValueToTimestampedKeyValueByteStoreAdapter
 
isOpen() - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
isOpen() - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
isOpen() - Method in class org.apache.kafka.streams.state.internals.WrappedStateStore
 
isProcessable(long) - Method in class org.apache.kafka.streams.processor.internals.StreamTask
An active task is processable if its buffer contains data for all of its input source topic partitions, or if it is enforced to be processable
isRunning() - Method in enum org.apache.kafka.streams.processor.internals.GlobalStreamThread.State
 
isRunning() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
 
isRunningOrRebalancing() - Method in enum org.apache.kafka.streams.KafkaStreams.State
 
isTerminalNode() - Method in class org.apache.kafka.streams.processor.internals.ProcessorNode
 
isTimestamped(StateStore) - Static method in class org.apache.kafka.streams.state.internals.WrappedStateStore
 
isValidTransition(KafkaStreams.State) - Method in enum org.apache.kafka.streams.KafkaStreams.State
 
isValidTransition(Task.State) - Method in enum org.apache.kafka.streams.processor.internals.Task.State
 
isValidTransition(ThreadStateTransitionValidator) - Method in enum org.apache.kafka.streams.processor.internals.GlobalStreamThread.State
 
isValidTransition(ThreadStateTransitionValidator) - Method in enum org.apache.kafka.streams.processor.internals.StreamThread.State
 
isValidTransition(ThreadStateTransitionValidator) - Method in interface org.apache.kafka.streams.processor.internals.ThreadStateTransitionValidator
 
isValueChangingOperation() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 

J

join(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoiner<? super V, ? super GV, ? extends RV>) - Method in interface org.apache.kafka.streams.kstream.KStream
Join records of this stream with GlobalKTable's records using non-windowed inner equi join.
join(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoiner<? super V, ? super GV, ? extends RV>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
Join records of this stream with GlobalKTable's records using non-windowed inner equi join.
join(GlobalKTable<KG, VG>, KeyValueMapper<? super K, ? super V, ? extends KG>, ValueJoiner<? super V, ? super VG, ? extends VR>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
join(GlobalKTable<KG, VG>, KeyValueMapper<? super K, ? super V, ? extends KG>, ValueJoiner<? super V, ? super VG, ? extends VR>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
join(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
join(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface org.apache.kafka.streams.kstream.KStream
Join records of this stream with another KStream's records using windowed inner equi join with default serializers and deserializers.
join(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, Joined<K, V, VO>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
Deprecated.
join(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, Joined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
join(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
join(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
Join records of this stream with another KStream's records using windowed inner equi join using the StreamJoined instance for configuration of the key serde, this stream's value serde, the other stream's value serde, and used state stores.
join(KTable<K, V1>, ValueJoiner<? super V, ? super V1, ? extends R>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
join(KTable<K, V1>, ValueJoiner<? super V, ? super V1, ? extends R>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable's records using non-windowed inner equi join, with default serializers, deserializers, and state store.
join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Joined<K, V, VO>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable's records using non-windowed inner equi join, with the Materialized instance for configuration of the key serde, the result table's value serde, and state store.
join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable's records using non-windowed inner equi join, with default serializers, deserializers, and state store.
join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable's records using non-windowed inner equi join, with the Materialized instance for configuration of the key serde, the result table's value serde, and state store.
join(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
Join records of this stream with KTable's records using non-windowed inner equi join with default serializers and deserializers.
join(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>, Joined<K, V, VT>) - Method in interface org.apache.kafka.streams.kstream.KStream
Join records of this stream with KTable's records using non-windowed inner equi join with default serializers and deserializers.
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable using non-windowed inner join.
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable using non-windowed inner join.
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable using non-windowed inner join.
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable using non-windowed inner join.
Joined<K,​V,​VO> - Class in org.apache.kafka.streams.kstream
The Joined class represents optional params that can be passed to KStream#join(KTable,...) and KStream#leftJoin(KTable,...) operations.
Joined(Joined<K, V, VO>) - Constructor for class org.apache.kafka.streams.kstream.Joined
 
JoinedInternal<K,​V,​VO> - Class in org.apache.kafka.streams.kstream.internals
 
joinMerger() - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode
The supplier which provides processor with KTable-KTable join merge functionality.
joinOtherStoreNames() - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode
 
joinThisStoreNames() - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode
 
JoinWindows - Class in org.apache.kafka.streams.kstream
The window specifications used for joins.

K

KafkaClientSupplier - Interface in org.apache.kafka.streams
KafkaClientSupplier can be used to provide custom Kafka clients to a KafkaStreams instance.
KafkaStreams - Class in org.apache.kafka.streams
A Kafka client that allows for performing continuous computation on input coming from one or more input topics and sends output to zero, one, or more output topics.
KafkaStreams(Topology, Properties) - Constructor for class org.apache.kafka.streams.KafkaStreams
Create a KafkaStreams instance.
KafkaStreams(Topology, Properties, Time) - Constructor for class org.apache.kafka.streams.KafkaStreams
Create a KafkaStreams instance.
KafkaStreams(Topology, Properties, KafkaClientSupplier) - Constructor for class org.apache.kafka.streams.KafkaStreams
Create a KafkaStreams instance.
KafkaStreams(Topology, Properties, KafkaClientSupplier, Time) - Constructor for class org.apache.kafka.streams.KafkaStreams
Create a KafkaStreams instance.
KafkaStreams(Topology, StreamsConfig) - Constructor for class org.apache.kafka.streams.KafkaStreams
Deprecated.
KafkaStreams(Topology, StreamsConfig, Time) - Constructor for class org.apache.kafka.streams.KafkaStreams
KafkaStreams(Topology, StreamsConfig, KafkaClientSupplier) - Constructor for class org.apache.kafka.streams.KafkaStreams
KafkaStreams.State - Enum in org.apache.kafka.streams
Kafka Streams states are the possible state that a Kafka Streams instance can be in.
KafkaStreams.StateListener - Interface in org.apache.kafka.streams
Listen to KafkaStreams.State change events.
KafkaStreamsInternalStorageInitializer - Class in org.apache.kafka.streams.mapr
 
KafkaStreamsInternalStorageInitializer() - Constructor for class org.apache.kafka.streams.mapr.KafkaStreamsInternalStorageInitializer
 
keepLogFileNum() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
key - Variable in class org.apache.kafka.streams.KeyValue
The key of the key-value pair.
key() - Method in class org.apache.kafka.streams.kstream.Windowed
Return the key of the window.
key() - Method in class org.apache.kafka.streams.processor.internals.StampedRecord
 
key() - Method in class org.apache.kafka.streams.state.internals.TimeOrderedKeyValueBuffer.Eviction
 
keyBytes(K) - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
keyChangingOperation(boolean) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
keyDeserializer() - Method in class org.apache.kafka.streams.kstream.internals.ConsumedInternal
 
keyDeserializer() - Method in class org.apache.kafka.streams.state.StateSerdes
Return the key deserializer.
keyFrom(byte[]) - Method in class org.apache.kafka.streams.state.StateSerdes
Deserialize the key from raw bytes.
KeyQueryMetadata - Class in org.apache.kafka.streams
Represents all the metadata related to a key, where a particular key resides in a KafkaStreams application.
KeyQueryMetadata(HostInfo, Set<HostInfo>, int) - Constructor for class org.apache.kafka.streams.KeyQueryMetadata
 
keySerde - Variable in class org.apache.kafka.streams.kstream.Consumed
 
keySerde - Variable in class org.apache.kafka.streams.kstream.Grouped
 
keySerde - Variable in class org.apache.kafka.streams.kstream.internals.AbstractStream
 
keySerde - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
keySerde - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode
 
keySerde - Variable in class org.apache.kafka.streams.kstream.Joined
 
keySerde - Variable in class org.apache.kafka.streams.kstream.Materialized
 
keySerde - Variable in class org.apache.kafka.streams.kstream.Produced
 
keySerde - Variable in class org.apache.kafka.streams.kstream.Repartitioned
 
keySerde - Variable in class org.apache.kafka.streams.kstream.Serialized
Deprecated.
 
keySerde - Variable in class org.apache.kafka.streams.kstream.StreamJoined
 
keySerde() - Method in class org.apache.kafka.streams.kstream.internals.AbstractStream
 
keySerde() - Method in class org.apache.kafka.streams.kstream.internals.ConsumedInternal
 
keySerde() - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode
 
keySerde() - Method in class org.apache.kafka.streams.kstream.internals.graph.OptimizableRepartitionNode
 
keySerde() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamSourceNode
 
keySerde() - Method in class org.apache.kafka.streams.kstream.internals.GroupedInternal
 
keySerde() - Method in class org.apache.kafka.streams.kstream.internals.JoinedInternal
 
keySerde() - Method in class org.apache.kafka.streams.kstream.internals.MaterializedInternal
 
keySerde() - Method in class org.apache.kafka.streams.kstream.internals.ProducedInternal
 
keySerde() - Method in class org.apache.kafka.streams.kstream.internals.RepartitionedInternal
 
keySerde() - Method in class org.apache.kafka.streams.kstream.internals.SerializedInternal
Deprecated.
 
keySerde() - Method in class org.apache.kafka.streams.kstream.internals.StreamJoinedInternal
 
keySerde() - Method in class org.apache.kafka.streams.kstream.Joined
 
keySerde() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
keySerde() - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
keySerde() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the default key serde.
keySerde() - Method in class org.apache.kafka.streams.state.StateSerdes
Return the key serde.
keySerde(Serde<K>) - Static method in class org.apache.kafka.streams.kstream.Grouped
Create a Grouped instance with the provided keySerde.
keySerde(Serde<K>) - Static method in class org.apache.kafka.streams.kstream.Joined
Create an instance of Joined with a key Serde.
keySerde(Serde<K>) - Static method in class org.apache.kafka.streams.kstream.Produced
Create a Produced instance with provided keySerde.
keySerializer() - Method in class org.apache.kafka.streams.state.StateSerdes
Return the key serializer.
KeyValue<K,​V> - Class in org.apache.kafka.streams
A key-value pair defined for a single Kafka Streams record.
KeyValue(K, V) - Constructor for class org.apache.kafka.streams.KeyValue
Create a new key-value pair.
KeyValueBytesStoreSupplier - Interface in org.apache.kafka.streams.state
A store supplier that can be used to create one or more KeyValueStore<Byte, byte[]> instances of type <Byte, byte[]>.
KeyValueIterator<K,​V> - Interface in org.apache.kafka.streams.state
Iterator interface of KeyValue.
KeyValueIteratorFacade<K,​V> - Class in org.apache.kafka.streams.state.internals
 
KeyValueIteratorFacade(KeyValueIterator<K, ValueAndTimestamp<V>>) - Constructor for class org.apache.kafka.streams.state.internals.KeyValueIteratorFacade
 
KeyValueMapper<K,​V,​VR> - Interface in org.apache.kafka.streams.kstream
The KeyValueMapper interface for mapping a key-value pair to a new value of arbitrary type.
keyValueStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
KeyValueStore<K,​V> - Interface in org.apache.kafka.streams.state
A key-value store that supports put/get/delete and range queries.
keyValueStoreBuilder(KeyValueBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
Creates a StoreBuilder that can be used to build a KeyValueStore.
KeyValueStoreBuilder<K,​V> - Class in org.apache.kafka.streams.state.internals
 
KeyValueStoreBuilder(KeyValueBytesStoreSupplier, Serde<K>, Serde<V>, Time) - Constructor for class org.apache.kafka.streams.state.internals.KeyValueStoreBuilder
 
KeyValueToTimestampedKeyValueByteStoreAdapter - Class in org.apache.kafka.streams.state.internals
This class is used to ensure backward compatibility at DSL level between TimestampedKeyValueStore and KeyValueStore.
KGroupedStream<K,​V> - Interface in org.apache.kafka.streams.kstream
KGroupedStream is an abstraction of a grouped record stream of KeyValue pairs.
KGroupedTable<K,​V> - Interface in org.apache.kafka.streams.kstream
KGroupedTable is an abstraction of a re-grouped changelog stream from a primary-keyed table, usually on a different grouping key than the original primary key.
KGroupedTableImpl<K,​V> - Class in org.apache.kafka.streams.kstream.internals
The implementation class of KGroupedTable.
KStream<K,​V> - Interface in org.apache.kafka.streams.kstream
KStream is an abstraction of a record stream of KeyValue pairs, i.e., each record is an independent entity/event in the real world.
KStreamAggProcessorSupplier<K,​RK,​V,​T> - Interface in org.apache.kafka.streams.kstream.internals
 
KStreamAggregate<K,​V,​T> - Class in org.apache.kafka.streams.kstream.internals
 
KStreamFlatTransform<KIn,​VIn,​KOut,​VOut> - Class in org.apache.kafka.streams.kstream.internals
 
KStreamFlatTransform(TransformerSupplier<? super KIn, ? super VIn, Iterable<KeyValue<KOut, VOut>>>) - Constructor for class org.apache.kafka.streams.kstream.internals.KStreamFlatTransform
 
KStreamFlatTransform.KStreamFlatTransformProcessor<KIn,​VIn,​KOut,​VOut> - Class in org.apache.kafka.streams.kstream.internals
 
KStreamFlatTransformProcessor(Transformer<? super KIn, ? super VIn, Iterable<KeyValue<KOut, VOut>>>) - Constructor for class org.apache.kafka.streams.kstream.internals.KStreamFlatTransform.KStreamFlatTransformProcessor
 
KStreamFlatTransformValues<KIn,​VIn,​VOut> - Class in org.apache.kafka.streams.kstream.internals
 
KStreamFlatTransformValues(ValueTransformerWithKeySupplier<KIn, VIn, Iterable<VOut>>) - Constructor for class org.apache.kafka.streams.kstream.internals.KStreamFlatTransformValues
 
KStreamFlatTransformValues.KStreamFlatTransformValuesProcessor<KIn,​VIn,​VOut> - Class in org.apache.kafka.streams.kstream.internals
 
KStreamImpl<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
KStreamPrint<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
KStreamPrint(ForeachAction<K, V>) - Constructor for class org.apache.kafka.streams.kstream.internals.KStreamPrint
 
KStreamReduce<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
KStreamSessionWindowAggregate<K,​V,​Agg> - Class in org.apache.kafka.streams.kstream.internals
 
KStreamSessionWindowAggregate(SessionWindows, String, Initializer<Agg>, Aggregator<? super K, ? super V, Agg>, Merger<? super K, Agg>) - Constructor for class org.apache.kafka.streams.kstream.internals.KStreamSessionWindowAggregate
 
KStreamTransformValues<K,​V,​R> - Class in org.apache.kafka.streams.kstream.internals
 
KStreamTransformValues.KStreamTransformValuesProcessor<K,​V,​R> - Class in org.apache.kafka.streams.kstream.internals
 
KStreamWindowAggregate<K,​V,​Agg,​W extends Window> - Class in org.apache.kafka.streams.kstream.internals
 
KStreamWindowAggregate(Windows<W>, String, Initializer<Agg>, Aggregator<? super K, ? super V, Agg>) - Constructor for class org.apache.kafka.streams.kstream.internals.KStreamWindowAggregate
 
KTable<K,​V> - Interface in org.apache.kafka.streams.kstream
KTable is an abstraction of a changelog stream from a primary-keyed table.
KTableAggregate<K,​V,​T> - Class in org.apache.kafka.streams.kstream.internals
 
KTableImpl<K,​S,​V> - Class in org.apache.kafka.streams.kstream.internals
The implementation class of KTable.
KTableImpl(String, Serde<K>, Serde<V>, Set<String>, String, ProcessorSupplier<?, ?>, StreamsGraphNode, InternalStreamsBuilder) - Constructor for class org.apache.kafka.streams.kstream.internals.KTableImpl
 
KTableKTableAbstractJoinValueGetterSupplier<K,​R,​V1,​V2> - Class in org.apache.kafka.streams.kstream.internals
 
KTableKTableJoinMerger<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
KTableKTableJoinNode<K,​V1,​V2,​VR> - Class in org.apache.kafka.streams.kstream.internals.graph
Too much specific information to generalize so the KTable-KTable join requires a specific node.
KTableKTableJoinNode.KTableKTableJoinNodeBuilder<K,​V1,​V2,​VR> - Class in org.apache.kafka.streams.kstream.internals.graph
 
kTableKTableJoinNodeBuilder() - Static method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode
 
KTableMaterializedValueGetterSupplier<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
KTableProcessorSupplier<K,​V,​T> - Interface in org.apache.kafka.streams.kstream.internals
 
KTableReduce<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
KTableRepartitionMap<K,​V,​K1,​V1> - Class in org.apache.kafka.streams.kstream.internals
KTable repartition map functions are not exposed to public APIs, but only used for keyed aggregations.
KTableSource<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
KTableSource(String, String) - Constructor for class org.apache.kafka.streams.kstream.internals.KTableSource
 
KTableSourceValueGetterSupplier<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
KTableSourceValueGetterSupplier(String) - Constructor for class org.apache.kafka.streams.kstream.internals.KTableSourceValueGetterSupplier
 
KTableSuppressProcessorSupplier<K,​V> - Class in org.apache.kafka.streams.kstream.internals.suppress
 
KTableSuppressProcessorSupplier(SuppressedInternal<K>, String, KTableImpl<K, ?, V>) - Constructor for class org.apache.kafka.streams.kstream.internals.suppress.KTableSuppressProcessorSupplier
 
KTableValueGetter<K,​V> - Interface in org.apache.kafka.streams.kstream.internals
 
KTableValueGetterSupplier<K,​V> - Interface in org.apache.kafka.streams.kstream.internals
 

L

label - Variable in class org.apache.kafka.streams.kstream.Printed
 
lagFor(TaskId) - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
Returns the total lag across all logged stores in the task.
LagInfo - Class in org.apache.kafka.streams
Encapsulates information about lag, at a store partition replica (active or standby).
LATENCY_SUFFIX - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
lateRecordDropSensor(String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ProcessorNodeMetrics
 
LATEST - org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl.Version
 
LATEST - org.apache.kafka.streams.Topology.AutoOffsetReset
 
LATEST_OFFSET - Static variable in interface org.apache.kafka.streams.processor.internals.Task
 
LATEST_SUPPORTED_VERSION - Static variable in class org.apache.kafka.streams.processor.internals.assignment.StreamsAssignmentProtocolVersions
 
latestResetTopicsPattern() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
latestSupportedVersion() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
latestSupportedVersion() - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
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(GlobalKTable<KG, VG>, KeyValueMapper<? super K, ? super V, ? extends KG>, ValueJoiner<? super V, ? super VG, ? extends VR>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
leftJoin(GlobalKTable<KG, VG>, KeyValueMapper<? super K, ? super V, ? extends KG>, ValueJoiner<? super V, ? super VG, ? extends VR>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
leftJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
Deprecated.
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
leftJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
Join records of this stream with another KStream's records using windowed left equi join using the StreamJoined instance for configuration of the key serde, this stream's value serde, the other stream's value serde, and used state stores.
leftJoin(KTable<K, V1>, ValueJoiner<? super V, ? super V1, ? extends R>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
leftJoin(KTable<K, V1>, ValueJoiner<? super V, ? super V1, ? extends R>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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>, Joined<K, V, VO>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable (left input) with another KTable's (right input) records using non-windowed left equi join, with the Materialized instance for configuration of the key serde, the result table's value serde, and state store.
leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable (left input) with another KTable's (right input) records using non-windowed left equi join, with default serializers, deserializers, and state store.
leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable (left input) with another KTable's (right input) records using non-windowed left equi join, with the Materialized instance for configuration of the key serde, the result table's value serde, and state store.
leftJoin(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
Join records of this stream with KTable's records using non-windowed left equi join with default serializers and deserializers.
leftJoin(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>, Joined<K, V, VT>) - Method in interface org.apache.kafka.streams.kstream.KStream
Join records of this stream with KTable's records using non-windowed left equi join with default serializers and deserializers.
leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable using non-windowed left join.
leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable using non-windowed left join.
leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable with another KTable using non-windowed left join.
leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
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.
level0FileNumCompactionTrigger() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
level0SlowdownWritesTrigger() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
level0StopWritesTrigger() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
levelCompactionDynamicLevelBytes() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
levelZeroFileNumCompactionTrigger() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
levelZeroSlowdownWritesTrigger() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
levelZeroStopWritesTrigger() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
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
 
logChange(String, Bytes, byte[], long) - Method in class org.apache.kafka.streams.processor.internals.GlobalProcessorContextImpl
 
logChange(String, Bytes, byte[], long) - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
 
logChange(String, Bytes, byte[], long) - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
logConfig() - Method in class org.apache.kafka.streams.state.internals.AbstractStoreBuilder
 
logConfig() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer.Builder
 
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.
logFileTimeToRoll() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
loggingEnabled - Variable in class org.apache.kafka.streams.kstream.Materialized
 
loggingEnabled() - Method in class org.apache.kafka.streams.kstream.internals.MaterializedInternal
 
loggingEnabled() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.StateStoreFactory
 
loggingEnabled() - Method in class org.apache.kafka.streams.state.internals.AbstractStoreBuilder
 
loggingEnabled() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer.Builder
 
loggingEnabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
 
logPrefix() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
logWarning(Logger) - Static method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
lowerRange(Bytes, long) - Method in interface org.apache.kafka.streams.state.internals.SegmentedBytesStore.KeySchema
Given a range of record keys and a time, construct a Segmented key that represents the lower range of keys to search when performing range queries.
lowerRange(Bytes, long) - Method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
lowerRange(Bytes, long) - Method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
lowerRangeFixedSize(Bytes, long) - Method in interface org.apache.kafka.streams.state.internals.SegmentedBytesStore.KeySchema
Given a range of fixed size record keys and a time, construct a Segmented key that represents the lower range of keys to search when performing range queries.
lowerRangeFixedSize(Bytes, long) - Method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
lowerRangeFixedSize(Bytes, long) - Method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
lowestSupportedVersion() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
lowestSupportedVersion() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
lowestSupportedVersion() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
lowestSupportedVersion() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
lruMap(String, int) - Static method in class org.apache.kafka.streams.state.Stores
Create a LRU Map KeyValueBytesStoreSupplier.

M

main(String[]) - Static method in class org.apache.kafka.streams.StreamsConfig
 
MAIN_CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
Prefix used to override consumer configs for the main consumer client from the general consumer client configs.
mainConsumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
Prefix a property with StreamsConfig.MAIN_CONSUMER_PREFIX.
maintainMs() - Method in class org.apache.kafka.streams.kstream.JoinWindows
Deprecated.
since 2.1. This function should not be used anymore, since JoinWindows.until(long) is deprecated in favor of JoinWindows.grace(Duration).
maintainMs() - Method in class org.apache.kafka.streams.kstream.SessionWindows
Deprecated.
since 2.1. Use Materialized.retention instead.
maintainMs() - Method in class org.apache.kafka.streams.kstream.TimeWindows
Deprecated.
since 2.1. Use Materialized.retention instead.
maintainMs() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
Deprecated.
since 2.1. Use Materialized.retention instead.
maintainMs() - Method in class org.apache.kafka.streams.kstream.Windows
Deprecated.
since 2.1. Use Materialized.retention instead.
make(V, long) - Static method in class org.apache.kafka.streams.state.ValueAndTimestamp
Create a new ValueAndTimestamp instance if the provide value is not null.
makeReady(Map<String, InternalTopicConfig>) - Method in class org.apache.kafka.streams.processor.internals.InternalTopicManager
Prepares a set of given internal topics.
manifestPreallocationSize() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
map - Variable in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
map(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
mapValues(ValueMapper<? super V, ? extends VR>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
mapValues(ValueMapper<? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into a new value (with possible new type) of the output record.
mapValues(ValueMapper<? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type) in the new KTable, with default serializers, deserializers, and state store.
mapValues(ValueMapper<? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
mapValues(ValueMapper<? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type) in the new KTable, with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
mapValues(ValueMapper<? super V, ? extends VR>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
mapValues(ValueMapper<? super V, ? extends VR>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
mapValues(ValueMapper<? super V, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into a new value (with possible new type) of the output record.
mapValues(ValueMapper<? super V, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type) in the new KTable, with default serializers, deserializers, and state store.
mapValues(ValueMapper<? super V, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
mapValues(ValueMapper<? super V, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type) in the new KTable, with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into a new value (with possible new type) of the output record.
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type) in the new KTable, with default serializers, deserializers, and state store.
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type) in the new KTable, with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into a new value (with possible new type) of the output record.
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type) in the new KTable, with default serializers, deserializers, and state store.
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type) in the new KTable, with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
markChangelogAsCorrupted(Collection<TopicPartition>) - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
markChangelogAsCorrupted(Collection<TopicPartition>) - Method in interface org.apache.kafka.streams.processor.internals.Task
 
materialize() - Method in class org.apache.kafka.streams.kstream.internals.KTableSource
 
materialize() - Method in class org.apache.kafka.streams.kstream.internals.TimestampedKeyValueStoreMaterializer
 
materialized() - Method in class org.apache.kafka.streams.kstream.internals.KTableSource
 
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.
MaterializedInternal<K,​V,​S extends StateStore> - Class in org.apache.kafka.streams.kstream.internals
 
MaterializedInternal(Materialized<K, V, S>) - Constructor for class org.apache.kafka.streams.kstream.internals.MaterializedInternal
 
MaterializedInternal(Materialized<K, V, S>, InternalNameProvider, String) - Constructor for class org.apache.kafka.streams.kstream.internals.MaterializedInternal
 
MAX_LATENCY_DESCRIPTION - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
MAX_SUFFIX - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
MAX_TASK_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
max.task.idle.ms
MAX_WARMUP_REPLICAS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
max.warmup.replicas
maxBackgroundCompactions() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxBackgroundFlushes() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxBackgroundJobs() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxBytes() - Method in class org.apache.kafka.streams.kstream.internals.suppress.BufferConfigInternal
 
maxBytes() - Method in class org.apache.kafka.streams.kstream.internals.suppress.EagerBufferConfigImpl
 
maxBytes() - Method in class org.apache.kafka.streams.kstream.internals.suppress.StrictBufferConfigImpl
 
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.
maxBytesForLevelBase() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxBytesForLevelMultiplier() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxBytesForLevelMultiplierAdditional() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxCompactionBytes() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxFileOpeningThreads() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxLogFileSize() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxManifestFileSize() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxNumPartitions(Cluster, Set<String>) - Method in class org.apache.kafka.streams.processor.DefaultPartitionGrouper
Deprecated.
 
maxOpenFiles() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxRecords() - Method in class org.apache.kafka.streams.kstream.internals.suppress.BufferConfigInternal
 
maxRecords() - Method in class org.apache.kafka.streams.kstream.internals.suppress.EagerBufferConfigImpl
 
maxRecords() - Method in class org.apache.kafka.streams.kstream.internals.suppress.StrictBufferConfigImpl
 
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.
maxSequentialSkipInIterations() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxSubcompactions() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxSuccessiveMerges() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxTableFilesSizeFIFO() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxTotalWalSize() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxWarmupReplicas - Variable in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration.AssignmentConfigs
 
maxWriteBufferNumber() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
maxWriteBufferNumberToMaintain() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
Maybe<T> - Class in org.apache.kafka.streams.state.internals
A container that may be empty, may contain null, or may contain a value.
maybeMeasureLatency(Runnable, Time, Sensor) - Static method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
maybeMeasureLatency(Supplier<T>, Time, Sensor) - Static method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
maybePunctuateStreamTime() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
Possibly trigger registered stream-time punctuation functions if current partition group timestamp has reached the defined stamp Note, this is only called in the presence of new records
maybePunctuateStreamTime() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
maybePunctuateSystemTime() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
Possibly trigger registered system-time punctuation functions if current system timestamp has reached the defined stamp Note, this is called irrespective of the presence of new records
maybePunctuateSystemTime() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
maybeUpdateCopartitionSourceGroups(String, String) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
maybeUpdateSubscriptionVersion(int, int) - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
MemoryLRUCache - Class in org.apache.kafka.streams.state.internals
An in-memory LRU cache store based on HashSet and HashMap.
MemoryLRUCache.EldestEntryRemovalListener - Interface in org.apache.kafka.streams.state.internals
 
MemoryNavigableLRUCache - Class in org.apache.kafka.streams.state.internals
 
MemoryNavigableLRUCache(String, int) - Constructor for class org.apache.kafka.streams.state.internals.MemoryNavigableLRUCache
 
memtableAvgFlushTimeSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
memtableBytesFlushedSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
memTableConfig() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
memTableFactoryName() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
memtableHitRatioSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
memtableHugePageSize() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
memtableMaxFlushTimeSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
memtableMinFlushTimeSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
memtablePrefixBloomSizeRatio() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
merge(KStream<K, V>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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.
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
metadataForKey(String, K, StreamPartitioner<? super K, ?>) - Method in class org.apache.kafka.streams.KafkaStreams
MeteredKeyValueStore<K,​V> - Class in org.apache.kafka.streams.state.internals
A Metered KeyValueStore wrapper that is used for recording operation metrics, and hence its inner KeyValueStore implementation do not need to provide its own metrics collecting functionality.
MeteredSessionStore<K,​V> - Class in org.apache.kafka.streams.state.internals
 
MeteredTimestampedKeyValueStore<K,​V> - Class in org.apache.kafka.streams.state.internals
A Metered TimestampedKeyValueStore wrapper that is used for recording operation metrics, and hence its inner KeyValueStore implementation do not need to provide its own metrics collecting functionality.
MeteredTimestampedKeyValueStore.RawAndDeserializedValue<ValueType> - Class in org.apache.kafka.streams.state.internals
 
MeteredWindowStore<K,​V> - Class in org.apache.kafka.streams.state.internals
 
METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
metric.reporters
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.internals.AbstractProcessorContext
 
metrics() - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
metrics() - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
 
metrics() - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
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_0100_TO_24 - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "built.in.metrics.version" for built-in metrics from version 0.10.0.
METRICS_LATEST - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "built.in.metrics.version" for the latest built-in metrics version.
METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
metrics.num.samples
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.streams.StreamsConfig
metrics.sample.window.ms
metricsScope() - Method in class org.apache.kafka.streams.state.internals.InMemorySessionBytesStoreSupplier
 
metricsScope() - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowBytesStoreSupplier
 
metricsScope() - Method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics.RocksDBMetricContext
 
metricsScope() - Method in class org.apache.kafka.streams.state.internals.RocksDbKeyValueBytesStoreSupplier
 
metricsScope() - Method in class org.apache.kafka.streams.state.internals.RocksDbSessionBytesStoreSupplier
 
metricsScope() - Method in class org.apache.kafka.streams.state.internals.RocksDbWindowBytesStoreSupplier
 
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.
MIN_SUFFIX - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
minTimestamp() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
minTimestamp() - Method in interface org.apache.kafka.streams.state.internals.TimeOrderedKeyValueBuffer
 
minWriteBufferNumberToMerge() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
Murmur3 - Class in org.apache.kafka.streams.state.internals
This class was taken from Hive org.apache.hive.common.util; https://github.com/apache/hive/blob/master/storage-api/src/java/org/apache/hive/common/util/Murmur3.java Commit: dffa3a16588bc8e95b9d0ab5af295a74e06ef702 Murmur3 is successor to Murmur2 fast non-crytographic hash algorithms.
Murmur3() - Constructor for class org.apache.kafka.streams.state.internals.Murmur3
 
Murmur3.IncrementalHash32 - Class in org.apache.kafka.streams.state.internals
 

N

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.internals.AbstractStream
 
name - Variable in class org.apache.kafka.streams.kstream.Joined
 
name - Variable in class org.apache.kafka.streams.kstream.Named
 
name - Variable in class org.apache.kafka.streams.kstream.Repartitioned
 
name - Variable in class org.apache.kafka.streams.kstream.StreamJoined
 
name - Variable in enum org.apache.kafka.streams.processor.internals.StreamThread.ProcessingMode
 
name - Variable in enum org.apache.kafka.streams.processor.internals.Task.TaskType
 
name - Variable in class org.apache.kafka.streams.state.internals.AbstractStoreBuilder
 
name() - Method in class org.apache.kafka.streams.kstream.internals.ConsumedInternal
 
name() - Method in class org.apache.kafka.streams.kstream.internals.GroupedInternal
 
name() - Method in class org.apache.kafka.streams.kstream.internals.JoinedInternal
 
name() - Method in class org.apache.kafka.streams.kstream.internals.NamedInternal
 
name() - Method in class org.apache.kafka.streams.kstream.internals.PrintedInternal
 
name() - Method in class org.apache.kafka.streams.kstream.internals.ProducedInternal
 
name() - Method in class org.apache.kafka.streams.kstream.internals.RepartitionedInternal
 
name() - Method in class org.apache.kafka.streams.kstream.internals.StreamJoinedInternal
 
name() - Method in class org.apache.kafka.streams.kstream.internals.suppress.FinalResultsSuppressionBuilder
 
name() - Method in interface org.apache.kafka.streams.kstream.internals.suppress.NamedSuppressed
 
name() - Method in class org.apache.kafka.streams.kstream.internals.suppress.SuppressedInternal
 
name() - Method in class org.apache.kafka.streams.kstream.Joined
Deprecated.
this method will be removed in a in a future release
name() - Method in class org.apache.kafka.streams.processor.internals.InternalTopicConfig
 
name() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.AbstractNode
 
name() - Method in class org.apache.kafka.streams.processor.internals.ProcessorNode
 
name() - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
name() - Method in interface org.apache.kafka.streams.processor.StateStore
The name of this store.
name() - Method in class org.apache.kafka.streams.state.internals.AbstractRocksDBSegmentedBytesStore
 
name() - Method in class org.apache.kafka.streams.state.internals.AbstractStoreBuilder
 
name() - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
name() - Method in class org.apache.kafka.streams.state.internals.InMemorySessionBytesStoreSupplier
 
name() - Method in class org.apache.kafka.streams.state.internals.InMemorySessionStore
 
name() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer.Builder
 
name() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
name() - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowBytesStoreSupplier
 
name() - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowStore
 
name() - Method in class org.apache.kafka.streams.state.internals.KeyValueToTimestampedKeyValueByteStoreAdapter
 
name() - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
name() - Method in class org.apache.kafka.streams.state.internals.RocksDbKeyValueBytesStoreSupplier
 
name() - Method in class org.apache.kafka.streams.state.internals.RocksDbSessionBytesStoreSupplier
 
name() - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
name() - Method in class org.apache.kafka.streams.state.internals.RocksDbWindowBytesStoreSupplier
 
name() - Method in class org.apache.kafka.streams.state.internals.WrappedStateStore
 
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
Deprecated.
use Joined.as(String) instead
Named - Class in org.apache.kafka.streams.kstream
 
Named(String) - Constructor for class org.apache.kafka.streams.kstream.Named
 
Named(Named) - Constructor for class org.apache.kafka.streams.kstream.Named
 
NamedCacheMetrics - Class in org.apache.kafka.streams.state.internals.metrics
 
NamedInternal - Class in org.apache.kafka.streams.kstream.internals
 
NamedSuppressed<K> - Interface in org.apache.kafka.streams.kstream.internals.suppress
Internally-facing interface to work around the fact that all Suppressed config objects are name-able, but do not present a getter (for consistency with other config objects).
nameSpaceFromTaskIdAndStore(String, String) - Static method in class org.apache.kafka.streams.state.internals.ThreadCache
The thread cache maintains a set of NamedCaches whose names are a concatenation of the task ID and the underlying store name.
needsInitializationOrRestoration() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
newProcessorName(String) - Method in interface org.apache.kafka.streams.kstream.internals.InternalNameProvider
 
newProcessorName(String) - Method in class org.apache.kafka.streams.kstream.internals.InternalStreamsBuilder
 
newStoreName(String) - Method in interface org.apache.kafka.streams.kstream.internals.InternalNameProvider
 
newStoreName(String) - Method in class org.apache.kafka.streams.kstream.internals.InternalStreamsBuilder
 
newTableReaderForCompactionInputs() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
newValue - Variable in class org.apache.kafka.streams.kstream.internals.Change
 
next() - Method in class org.apache.kafka.streams.state.internals.DelegatingPeekingKeyValueIterator
 
next() - Method in class org.apache.kafka.streams.state.internals.KeyValueIteratorFacade
 
next(long) - Method in class org.apache.kafka.streams.processor.internals.PunctuationSchedule
 
NEXT_SCHEDULED_REBALANCE_MS - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
 
nextRebalanceMs() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
nextScheduledRebalanceMs() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
NO_OPTIMIZATION - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "topology.optimization" for disabling topology optimization
node() - Method in class org.apache.kafka.streams.processor.internals.PunctuationSchedule
 
nodeGroups() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
nodeLevelSensor(String, String, String, String, Sensor.RecordingLevel, Sensor...) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
nodeLevelTagMap(String, String, String) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
nodeName - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
nodeName() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
nodes() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Subtopology
 
nodes() - Method in interface org.apache.kafka.streams.TopologyDescription.Subtopology
All nodes of this sub-topology.
nodeToSourceTopics() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
NONE - org.apache.kafka.streams.processor.internals.assignment.AssignorError
 
NONEXIST_TOPIC - Static variable in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
nonSourceChangelogTopics() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopicsInfo
Returns the config for any changelogs that must be prepared for this topic group, ie excluding any source topics that are reused as a changelog
NOT_AVAILABLE - Static variable in class org.apache.kafka.streams.KeyQueryMetadata
Sentinel to indicate that the KeyQueryMetadata is currently unavailable.
NOT_AVAILABLE - Static variable in class org.apache.kafka.streams.state.StreamsMetadata
Sentinel to indicate that the StreamsMetadata is currently unavailable.
NOT_RUNNING - org.apache.kafka.streams.KafkaStreams.State
 
NULL_HASHCODE - Static variable in class org.apache.kafka.streams.state.internals.Murmur3
 
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
numberOfFileErrorsSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
numberOfOpenFilesSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
numberOfPartitions - Variable in class org.apache.kafka.streams.kstream.Repartitioned
 
numberOfPartitions() - Method in class org.apache.kafka.streams.kstream.internals.RepartitionedInternal
 
numberOfPartitions() - Method in class org.apache.kafka.streams.processor.internals.InternalTopicConfig
 
numberOfPartitions(int) - Static method in class org.apache.kafka.streams.kstream.Repartitioned
Create a Repartitioned instance with provided number of partitions for repartition topic.
numLevels() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
numRecords() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
numRecords() - Method in interface org.apache.kafka.streams.state.internals.TimeOrderedKeyValueBuffer
 
numStandbyReplicas - Variable in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration.AssignmentConfigs
 

O

of() - Static method in class org.apache.kafka.streams.kstream.UnlimitedWindows
Return an unlimited window starting at timestamp zero.
of(long) - Static method in class org.apache.kafka.streams.kstream.JoinWindows
Deprecated.
of(long) - Static method in class org.apache.kafka.streams.kstream.TimeWindows
Deprecated.
of(Duration) - Static method in class org.apache.kafka.streams.kstream.JoinWindows
Specifies that records of the same key are joinable if their timestamps are within timeDifference, i.e., the timestamp of a record from the secondary stream is max timeDifference earlier or later than the timestamp of the record from the primary stream.
of(Duration) - Static method in class org.apache.kafka.streams.kstream.TimeWindows
Return a window definition with the given window size, and with the advance interval being equal to the window size.
of(KTableProcessorSupplier<K, ?, V>, KTableProcessorSupplier<K, ?, V>) - Static method in class org.apache.kafka.streams.kstream.internals.KTableKTableJoinMerger
 
of(KTableProcessorSupplier<K, ?, V>, KTableProcessorSupplier<K, ?, V>, String) - Static method in class org.apache.kafka.streams.kstream.internals.KTableKTableJoinMerger
 
offset() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
offset() - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
offset() - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
offset() - Method in class org.apache.kafka.streams.processor.internals.ProcessorRecordContext
 
offset() - Method in class org.apache.kafka.streams.processor.internals.StampedRecord
 
offset() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the offset of the current input record; could be -1 if it is not available (for example, if this method is invoked from the punctuate call).
offset() - Method in interface org.apache.kafka.streams.processor.RecordContext
 
OFFSET_UNKNOWN - Static variable in class org.apache.kafka.streams.state.internals.OffsetCheckpoint
 
OffsetCheckpoint - Class in org.apache.kafka.streams.state.internals
This class saves out a map of topic/partition=>offsets to a file.
OffsetCheckpoint(File) - Constructor for class org.apache.kafka.streams.state.internals.OffsetCheckpoint
 
offsetLag() - Method in class org.apache.kafka.streams.LagInfo
Get the measured lag between current and end offset positions, for this store partition replica
offsetResetPolicy() - Method in class org.apache.kafka.streams.kstream.internals.ConsumedInternal
 
offsets() - Method in interface org.apache.kafka.streams.processor.internals.RecordCollector
The last acked offsets from the internal Producer.
offsets() - Method in class org.apache.kafka.streams.processor.internals.RecordCollectorImpl
 
offsetSum() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
oldValue - Variable in class org.apache.kafka.streams.kstream.internals.Change
 
onAssignment(ConsumerPartitionAssignor.Assignment, ConsumerGroupMetadata) - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
onAssignmentComplete(boolean) - Method in interface org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration.AssignmentListener
 
onBatchRestored(TopicPartition, String, long, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
Method called after restoring a batch of records.
onChange(Thread, ThreadStateTransitionValidator, ThreadStateTransitionValidator) - Method in interface org.apache.kafka.streams.processor.internals.StreamThread.StateListener
Called when state changes
onChange(KafkaStreams.State, KafkaStreams.State) - Method in interface org.apache.kafka.streams.KafkaStreams.StateListener
Called when state changes.
onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.FailOnInvalidTimestamp
Raises an exception on every call.
onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.LogAndSkipOnInvalidTimestamp
Writes a log WARN message when the extracted timestamp is invalid (negative) but returns the invalid timestamp as-is, which ultimately causes the record to be skipped and not to be processed.
onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.UsePartitionTimeOnInvalidTimestamp
Returns the current stream-time as new timestamp for the record.
onInvalidTimestamp(ConsumerRecord<Object, Object>, long, long) - Method in class org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestamp
Deprecated.
Returns the current stream-time as new timestamp for the record.
onPartitionsAssigned(Collection<TopicPartition>) - Method in class org.apache.kafka.streams.processor.internals.StreamsRebalanceListener
 
onPartitionsLost(Collection<TopicPartition>) - Method in class org.apache.kafka.streams.processor.internals.StreamsRebalanceListener
 
onPartitionsRevoked(Collection<TopicPartition>) - Method in class org.apache.kafka.streams.processor.internals.StreamsRebalanceListener
 
onRestoreEnd(TopicPartition, String, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
Method called when restoring the StateStore is complete.
onRestoreStart(TopicPartition, String, long, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
Method called at the very beginning of StateStore restoration.
open - Variable in class org.apache.kafka.streams.state.internals.RocksDBStore
 
OPERATIONS - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
OptimizableRepartitionNode<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
 
OptimizableRepartitionNode.OptimizableRepartitionNodeBuilder<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
 
optimizableRepartitionNodeBuilder() - Static method in class org.apache.kafka.streams.kstream.internals.graph.OptimizableRepartitionNode
 
OptimizableRepartitionNodeBuilder() - Constructor for class org.apache.kafka.streams.kstream.internals.graph.OptimizableRepartitionNode.OptimizableRepartitionNodeBuilder
 
OPTIMIZE - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "topology.optimization" for enabling topology optimization
optimizeFiltersForHits() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
optimizeForPointLookup(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
optimizeForSmallDb() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
optimizeLevelStyleCompaction() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
optimizeLevelStyleCompaction(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
optimizeUniversalStyleCompaction() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
optimizeUniversalStyleCompaction(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
org.apache.kafka.streams - package org.apache.kafka.streams
 
org.apache.kafka.streams.errors - package org.apache.kafka.streams.errors
 
org.apache.kafka.streams.errors.mapr - package org.apache.kafka.streams.errors.mapr
 
org.apache.kafka.streams.internals - package org.apache.kafka.streams.internals
 
org.apache.kafka.streams.internals.generated - package org.apache.kafka.streams.internals.generated
 
org.apache.kafka.streams.internals.metrics - package org.apache.kafka.streams.internals.metrics
 
org.apache.kafka.streams.kstream - package org.apache.kafka.streams.kstream
 
org.apache.kafka.streams.kstream.internals - package org.apache.kafka.streams.kstream.internals
 
org.apache.kafka.streams.kstream.internals.foreignkeyjoin - package org.apache.kafka.streams.kstream.internals.foreignkeyjoin
 
org.apache.kafka.streams.kstream.internals.graph - package org.apache.kafka.streams.kstream.internals.graph
 
org.apache.kafka.streams.kstream.internals.suppress - package org.apache.kafka.streams.kstream.internals.suppress
 
org.apache.kafka.streams.mapr - package org.apache.kafka.streams.mapr
 
org.apache.kafka.streams.processor - package org.apache.kafka.streams.processor
 
org.apache.kafka.streams.processor.internals - package org.apache.kafka.streams.processor.internals
 
org.apache.kafka.streams.processor.internals.assignment - package org.apache.kafka.streams.processor.internals.assignment
 
org.apache.kafka.streams.processor.internals.metrics - package org.apache.kafka.streams.processor.internals.metrics
 
org.apache.kafka.streams.state - package org.apache.kafka.streams.state
 
org.apache.kafka.streams.state.internals - package org.apache.kafka.streams.state.internals
 
org.apache.kafka.streams.state.internals.metrics - package org.apache.kafka.streams.state.internals.metrics
 
otherStoreSupplier - Variable in class org.apache.kafka.streams.kstream.StreamJoined
 
otherStoreSupplier() - Method in class org.apache.kafka.streams.kstream.internals.StreamJoinedInternal
 
otherValueSerde - Variable in class org.apache.kafka.streams.kstream.Joined
 
otherValueSerde - Variable in class org.apache.kafka.streams.kstream.StreamJoined
 
otherValueSerde() - Method in class org.apache.kafka.streams.kstream.internals.JoinedInternal
 
otherValueSerde() - Method in class org.apache.kafka.streams.kstream.internals.StreamJoinedInternal
 
otherValueSerde() - Method in class org.apache.kafka.streams.kstream.Joined
 
otherValueSerde(Serde<VO>) - Static method in class org.apache.kafka.streams.kstream.Joined
Create an instance of Joined with an other value Serde.
outerJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
Deprecated.
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
outerJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface org.apache.kafka.streams.kstream.KStream
Join records of this stream with another KStream's records using windowed outer equi join using the StreamJoined instance for configuration of the key serde, this stream's value serde, the other stream's value serde, and used state stores.
outerJoin(KTable<K, V1>, ValueJoiner<? super V, ? super V1, ? extends R>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
outerJoin(KTable<K, V1>, ValueJoiner<? super V, ? super V1, ? extends R>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable (left input) with another KTable's (right input) records using non-windowed outer equi join, with default serializers, deserializers, and state store.
outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable (left input) with another KTable's (right input) records using non-windowed outer equi join, with the Materialized instance for configuration of the key serde, the result table's value serde, and state store.
outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable (left input) with another KTable's (right input) records using non-windowed outer equi join, with default serializers, deserializers, and state store.
outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KTable
Join records of this KTable (left input) with another KTable's (right input) records using non-windowed outer equi join, with the Materialized instance for configuration of the key serde, the result table's value serde, and state store.
outerValue(byte[]) - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
outputStream - Variable in class org.apache.kafka.streams.kstream.Printed
 
overlap(Window) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindow
Check if the given window overlaps with this window.
overlap(Window) - Method in class org.apache.kafka.streams.kstream.internals.TimeWindow
Check if the given window overlaps with this window.
overlap(Window) - Method in class org.apache.kafka.streams.kstream.internals.UnlimitedWindow
Returns true if the given window is of the same type, because all unlimited windows overlap with each other due to their infinite size.
overlap(Window) - Method in class org.apache.kafka.streams.kstream.Window
Check if the given window overlaps with this window.

P

P90_SUFFIX - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
P99_SUFFIX - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
pair(K, V) - Static method in class org.apache.kafka.streams.KeyValue
Create a new key-value pair.
paranoidChecks() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
paranoidFileChecks() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
parentNodes() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
parse(String) - Static method in class org.apache.kafka.streams.processor.TaskId
 
partition - Variable in class org.apache.kafka.streams.processor.TaskId
The ID of the partition.
partition() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
partition() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
partition() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
partition() - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
partition() - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
partition() - Method in class org.apache.kafka.streams.processor.internals.ProcessorRecordContext
 
partition() - Method in class org.apache.kafka.streams.processor.internals.RecordQueue
Returns the partition with which this queue is associated
partition() - Method in class org.apache.kafka.streams.processor.internals.StampedRecord
 
partition() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the partition id of the current input record; could be -1 if it is not available (for example, if this method is invoked from the punctuate call).
partition() - Method in interface org.apache.kafka.streams.processor.RecordContext
 
partition() - Method in class org.apache.kafka.streams.StoreQueryParameters
Get the store partition that will be queried.
partition(String, K, V, int) - Method in class org.apache.kafka.streams.processor.internals.DefaultStreamPartitioner
 
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(String, Windowed<K>, V, int) - Method in class org.apache.kafka.streams.kstream.internals.WindowedStreamPartitioner
WindowedStreamPartitioner determines the partition number for a record with the given windowed key and value and the current number of partitions.
PARTITION_COMPARATOR - Static variable in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
PARTITION_GROUPER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
Deprecated.
partitioner - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
partitioner - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode
 
partitioner - Variable in class org.apache.kafka.streams.kstream.Produced
 
partitioner - Variable in class org.apache.kafka.streams.kstream.Repartitioned
 
PartitionGroup - Class in org.apache.kafka.streams.processor.internals
PartitionGroup is used to buffer all co-partitioned records for processing.
partitionGrouper() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
PartitionGrouper - Interface in org.apache.kafka.streams.processor
Deprecated.
since 2.4 release; will be removed in 3.0.0 via KAFKA-7785
partitionGroups(Map<Integer, Set<String>>, Cluster) - Method in class org.apache.kafka.streams.processor.DefaultPartitionGrouper
Deprecated.
Generate tasks with the assigned topic partitions.
partitionGroups(Map<Integer, Set<String>>, Cluster) - Method in interface org.apache.kafka.streams.processor.PartitionGrouper
Deprecated.
Returns a map of task ids to groups of partitions.
PARTITIONS_ASSIGNED - org.apache.kafka.streams.processor.internals.StreamThread.State
 
PARTITIONS_REVOKED - org.apache.kafka.streams.processor.internals.StreamThread.State
 
partitionsByHost() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
partitionToOffsetSum() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
PartitionToOffsetSum() - Constructor for class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
PartitionToOffsetSum(Readable, short) - Constructor for class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
PartitionToOffsetSum(Struct, short) - Constructor for class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
peek(ForeachAction<? super K, ? super V>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
peek(ForeachAction<? super K, ? super V>, Named) - Method in interface org.apache.kafka.streams.kstream.KStream
Perform an action on each record of KStream.
PeekingKeyValueIterator<K,​V> - Interface in org.apache.kafka.streams.state.internals
 
peekNext() - Method in class org.apache.kafka.streams.state.internals.DelegatingPeekingKeyValueIterator
 
peekNext() - Method in interface org.apache.kafka.streams.state.internals.PeekingKeyValueIterator
 
peekNextKey() - Method in class org.apache.kafka.streams.state.internals.DelegatingPeekingKeyValueIterator
 
peekNextKey() - Method in class org.apache.kafka.streams.state.internals.KeyValueIteratorFacade
 
peekNextKey() - Method in interface org.apache.kafka.streams.state.KeyValueIterator
Peek at the next key without advancing the iterator
PENDING_SHUTDOWN - org.apache.kafka.streams.KafkaStreams.State
 
PENDING_SHUTDOWN - org.apache.kafka.streams.processor.internals.GlobalStreamThread.State
 
PENDING_SHUTDOWN - org.apache.kafka.streams.processor.internals.StreamThread.State
 
persistent() - Method in interface org.apache.kafka.streams.processor.StateStore
Return if the storage is persistent or not.
persistent() - Method in class org.apache.kafka.streams.state.internals.AbstractRocksDBSegmentedBytesStore
 
persistent() - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
persistent() - Method in class org.apache.kafka.streams.state.internals.InMemorySessionStore
 
persistent() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
persistent() - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowStore
 
persistent() - Method in class org.apache.kafka.streams.state.internals.KeyValueToTimestampedKeyValueByteStoreAdapter
 
persistent() - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
persistent() - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
persistent() - Method in class org.apache.kafka.streams.state.internals.WrappedStateStore
 
persistentKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
Create a persistent KeyValueBytesStoreSupplier.
persistentSessionStore(String, long) - Static method in class org.apache.kafka.streams.state.Stores
Deprecated.
persistentSessionStore(String, Duration) - Static method in class org.apache.kafka.streams.state.Stores
Create a persistent SessionBytesStoreSupplier.
persistentTimestampedKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
Create a persistent KeyValueBytesStoreSupplier.
persistentTimestampedWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
Create a persistent WindowBytesStoreSupplier.
persistentWindowStore(String, long, int, long, boolean) - Static method in class org.apache.kafka.streams.state.Stores
persistentWindowStore(String, Duration, Duration, boolean) - Static method in class org.apache.kafka.streams.state.Stores
Create a persistent WindowBytesStoreSupplier.
poll() - Method in class org.apache.kafka.streams.processor.internals.RecordQueue
Get the next StampedRecord from the queue
POLL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
poll.ms
pollRatioSensor(String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ThreadMetrics
 
pollRecordsSensor(String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ThreadMetrics
 
pollSensor(String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ThreadMetrics
 
port() - Method in class org.apache.kafka.streams.state.HostInfo
 
port() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
postCommit() - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
 
postCommit() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
This should only be called if the attempted commit succeeded for this task
postCommit() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.streams.StreamsConfig
 
predecessors() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.AbstractNode
 
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.
prepareCommit() - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
Flush stores before a commit
prepareCommit() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
prepareCommit() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
prepareForBulkLoad() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
prepareKeyDeserializer(Deserializer<K>, Deserializer<?>, Deserializer<?>) - Static method in class org.apache.kafka.streams.kstream.internals.WrappingNullableUtils
 
prepareKeySerde(Serde<K>, Serde<?>, Serde<?>) - Static method in class org.apache.kafka.streams.kstream.internals.WrappingNullableUtils
 
prepareKeySerializer(Serializer<K>, Serializer<?>, Serializer<?>) - Static method in class org.apache.kafka.streams.kstream.internals.WrappingNullableUtils
 
prepareMillisCheckFailMsgPrefix(Object, String) - Static method in class org.apache.kafka.streams.internals.ApiUtils
Generates the prefix message for validateMillisecondXXXXXX() utility
prepareValueDeserializer(Deserializer<V>, Deserializer<?>, Deserializer<?>) - Static method in class org.apache.kafka.streams.kstream.internals.WrappingNullableUtils
 
prepareValueSerde(Serde<V>, Serde<?>, Serde<?>) - Static method in class org.apache.kafka.streams.kstream.internals.WrappingNullableUtils
 
prepareValueSerde(Serde<V>, Serde<?>, Serde<?>) - Method in class org.apache.kafka.streams.state.internals.MeteredWindowStore
 
prepareValueSerdeForStore(Serde<ValueAndTimestamp<V>>, Serde<?>, Serde<?>) - Method in class org.apache.kafka.streams.state.internals.MeteredTimestampedKeyValueStore
 
prepareValueSerdeForStore(Serde<V>, Serde<?>, Serde<?>) - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
prepareValueSerializer(Serializer<V>, Serializer<?>, Serializer<?>) - Static method in class org.apache.kafka.streams.kstream.internals.WrappingNullableUtils
 
previousOwnerForPartition(TopicPartition) - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
previousTasksForConsumer(String) - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
prevTasks() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
prevTasks() - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
print(Printed<K, V>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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.
PrintedInternal<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
PrintedInternal(Printed<K, V>) - Constructor for class org.apache.kafka.streams.kstream.internals.PrintedInternal
 
PrintForeachAction<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
priorValueForBuffered(K) - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
priorValueForBuffered(K) - Method in interface org.apache.kafka.streams.state.internals.TimeOrderedKeyValueBuffer
 
PROBING_REBALANCE_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
probing.rebalance.interval.ms
probingRebalanceIntervalMs - Variable in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration.AssignmentConfigs
 
process(long) - Method in class org.apache.kafka.streams.processor.internals.StreamTask
Process one record.
process(long) - Method in interface org.apache.kafka.streams.processor.internals.Task
 
process(KIn, VIn) - Method in class org.apache.kafka.streams.kstream.internals.KStreamFlatTransform.KStreamFlatTransformProcessor
 
process(KIn, VIn) - Method in class org.apache.kafka.streams.kstream.internals.KStreamFlatTransformValues.KStreamFlatTransformValuesProcessor
 
process(K, V) - Method in class org.apache.kafka.streams.kstream.internals.KStreamTransformValues.KStreamTransformValuesProcessor
 
process(K, V) - Method in class org.apache.kafka.streams.processor.internals.ProcessorNode
 
process(K, V) - Method in class org.apache.kafka.streams.processor.internals.SinkNode
 
process(K, V) - Method in class org.apache.kafka.streams.processor.internals.SourceNode
 
process(K, V) - Method in interface org.apache.kafka.streams.processor.Processor
Process the record with the given key and value.
process(ProcessorSupplier<? super K, ? super V>, String...) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
process(ProcessorSupplier<? super K, ? super V>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Process all records in this stream, one record at a time, by applying a Processor (provided by the given ProcessorSupplier).
process(ProcessorSupplier<? super K, ? super V>, Named, String...) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
process(ProcessorSupplier<? super K, ? super V>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Process all records in this stream, one record at a time, by applying a Processor (provided by the given ProcessorSupplier).
processAtSourceSensor(String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ProcessorNodeMetrics
 
processId() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
processId() - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
processId() - Method in class org.apache.kafka.streams.processor.internals.TaskManager
 
PROCESSING_GUARANTEE_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
processing.guarantee
processingMode(StreamsConfig) - Static method in class org.apache.kafka.streams.processor.internals.StreamThread
 
processLatencySensor(String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.TaskMetrics
 
processLatencySensor(String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ThreadMetrics
 
processor() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.GlobalStore
 
processor() - Method in class org.apache.kafka.streams.processor.internals.ProcessorNode
 
processor() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
The processor node maintaining the global store.
Processor<K,​V> - Interface in org.apache.kafka.streams.processor
A processor of key-value pair records.
Processor(String, Set<String>) - Constructor for class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Processor
 
PROCESSOR_NODE_ID_TAG - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
PROCESSOR_NODE_LEVEL_GROUP - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
processorAtSourceSensorOrForwardSensor(String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ProcessorNodeMetrics
 
processorConnectedStateStores(String) - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
processorContext() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
ProcessorContext - Interface in org.apache.kafka.streams.processor
Processor context interface.
ProcessorContextImpl - Class in org.apache.kafka.streams.processor.internals
 
ProcessorContextImpl(TaskId, StreamsConfig, ProcessorStateManager, StreamsMetricsImpl, ThreadCache) - Constructor for class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
ProcessorContextUtils - Class in org.apache.kafka.streams.processor.internals
This class bridges the gap for components that _should_ be compatible with the public ProcessorContext interface, but have come to depend on features in InternalProcessorContext.
ProcessorGraphNode<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
Used to represent any type of stateless operation: map, mapValues, flatMap, flatMapValues, filter, filterNot, branch
ProcessorGraphNode(String, ProcessorParameters<K, V>) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.ProcessorGraphNode
 
ProcessorGraphNode(ProcessorParameters<K, V>) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.ProcessorGraphNode
 
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
 
processorName() - Method in class org.apache.kafka.streams.kstream.internals.graph.ProcessorParameters
 
ProcessorNode<K,​V> - Class in org.apache.kafka.streams.processor.internals
 
ProcessorNode(String) - Constructor for class org.apache.kafka.streams.processor.internals.ProcessorNode
 
ProcessorNode(String, Processor<K, V>, Set<String>) - Constructor for class org.apache.kafka.streams.processor.internals.ProcessorNode
 
ProcessorNodeMetrics - Class in org.apache.kafka.streams.processor.internals.metrics
 
ProcessorNodePunctuator - Interface in org.apache.kafka.streams.processor.internals
 
processorParameters - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
processorParameters - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode
 
processorParameters() - Method in class org.apache.kafka.streams.kstream.internals.graph.ProcessorGraphNode
 
ProcessorParameters<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
Class used to represent a ProcessorSupplier and the name used to register it with the InternalTopologyBuilder Used by the Join nodes as there are several parameters, this abstraction helps keep the number of arguments more reasonable.
ProcessorParameters(ProcessorSupplier<K, V>, String) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.ProcessorParameters
 
ProcessorRecordContext - Class in org.apache.kafka.streams.processor.internals
 
ProcessorRecordContext(long, long, int, String, Headers) - Constructor for class org.apache.kafka.streams.processor.internals.ProcessorRecordContext
 
processors() - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
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
 
ProcessorStateManager - Class in org.apache.kafka.streams.processor.internals
ProcessorStateManager is the source of truth for the current offset for each state store, which is either the read offset during restoring, or the written offset during normal processing.
ProcessorStateManager(TaskId, Task.TaskType, boolean, LogContext, StateDirectory, ChangelogRegister, Map<String, String>, Collection<TopicPartition>) - Constructor for class org.apache.kafka.streams.processor.internals.ProcessorStateManager
 
ProcessorStateManager.StateStoreMetadata - Class in org.apache.kafka.streams.processor.internals
 
processorSupplier() - Method in class org.apache.kafka.streams.kstream.internals.graph.ProcessorParameters
 
ProcessorSupplier<K,​V> - Interface in org.apache.kafka.streams.processor
A processor supplier that can create one or more Processor instances.
ProcessorTopology - Class in org.apache.kafka.streams.processor.internals
 
ProcessorTopology(List<ProcessorNode<?, ?>>, Map<String, SourceNode<?, ?>>, Map<String, SinkNode<?, ?>>, List<StateStore>, List<StateStore>, Map<String, String>, Set<String>) - Constructor for class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
processRateSensor(String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ThreadMetrics
 
processRatioSensor(String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ThreadMetrics
 
processRecordsSensor(String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ThreadMetrics
 
processSensor(String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ProcessorNodeMetrics
 
Produced<K,​V> - Class in org.apache.kafka.streams.kstream
This class is used to provide the optional parameters when producing to new topics using KStream.through(String, Produced) or KStream.to(String, Produced).
Produced(Produced<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Produced
 
ProducedInternal<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
ProducedInternal(Produced<K, V>) - Constructor for class org.apache.kafka.streams.kstream.internals.ProducedInternal
 
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
 
producerMetrics() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
 
producerMetrics(Collection<StreamsProducer>) - Static method in class org.apache.kafka.streams.processor.internals.ClientUtils
 
producerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
Prefix a property with StreamsConfig.PRODUCER_PREFIX.
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
 
PROPAGATE_NULL_IF_NO_FK_VAL_AVAILABLE - org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionWrapper.Instruction
 
PROPAGATE_ONLY_IF_FK_VAL_AVAILABLE - org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionWrapper.Instruction
 
punctuate(long) - Method in interface org.apache.kafka.streams.processor.Punctuator
Perform the scheduled periodic operation.
punctuate(long, Punctuator) - Method in class org.apache.kafka.streams.processor.internals.ProcessorNode
 
punctuate(ProcessorNode<?, ?>, long, PunctuationType, Punctuator) - Method in interface org.apache.kafka.streams.processor.internals.ProcessorNodePunctuator
 
punctuate(ProcessorNode<?, ?>, long, PunctuationType, Punctuator) - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
punctuateRatioSensor(String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ThreadMetrics
 
punctuateSensor(String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ProcessorNodeMetrics
 
punctuateSensor(String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.TaskMetrics
 
punctuateSensor(String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ThreadMetrics
 
PunctuationQueue - Class in org.apache.kafka.streams.processor.internals
 
PunctuationQueue() - Constructor for class org.apache.kafka.streams.processor.internals.PunctuationQueue
 
PunctuationSchedule - Class in org.apache.kafka.streams.processor.internals
 
PunctuationType - Enum in org.apache.kafka.streams.processor
Controls what notion of time is used for punctuation scheduled via ProcessorContext.schedule(Duration, PunctuationType, Punctuator) schedule}: STREAM_TIME - uses "stream time", which is advanced by the processing of messages in accordance with the timestamp as extracted by the TimestampExtractor in use.
punctuator() - Method in class org.apache.kafka.streams.processor.internals.PunctuationSchedule
 
Punctuator - Interface in org.apache.kafka.streams.processor
A functional interface used as an argument to ProcessorContext.schedule(Duration, PunctuationType, Punctuator).
purgeableOffsets() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
purgeableOffsets() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
put(long, K, Change<V>, ProcessorRecordContext) - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
put(long, K, Change<V>, ProcessorRecordContext) - Method in interface org.apache.kafka.streams.state.internals.TimeOrderedKeyValueBuffer
 
put(String, Bytes, LRUCacheEntry) - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 
put(K, V) - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
put(K, V) - Method in class org.apache.kafka.streams.state.internals.MeteredWindowStore
Deprecated.
put(K, V) - Method in interface org.apache.kafka.streams.state.KeyValueStore
Update the value associated with this key.
put(K, V) - Method in interface org.apache.kafka.streams.state.WindowStore
Deprecated.
as timestamp is not provided for the key-value pair, this causes inconsistency to identify the window frame to which the key belongs. Use WindowStore.put(Object, Object, long) instead.
put(K, V, long) - Method in class org.apache.kafka.streams.state.internals.MeteredWindowStore
 
put(K, V, long) - Method in interface org.apache.kafka.streams.state.WindowStore
Put a key-value pair into the window with given window start timestamp
put(Bytes, byte[]) - Method in class org.apache.kafka.streams.state.internals.AbstractRocksDBSegmentedBytesStore
 
put(Bytes, byte[]) - Method in class org.apache.kafka.streams.state.internals.CachingKeyValueStore
 
put(Bytes, byte[]) - Method in class org.apache.kafka.streams.state.internals.ChangeLoggingKeyValueBytesStore
 
put(Bytes, byte[]) - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
put(Bytes, byte[]) - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowStore
Deprecated.
put(Bytes, byte[]) - Method in class org.apache.kafka.streams.state.internals.KeyValueToTimestampedKeyValueByteStoreAdapter
 
put(Bytes, byte[]) - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
put(Bytes, byte[]) - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
put(Bytes, byte[]) - Method in class org.apache.kafka.streams.state.internals.RocksDBWindowStore
Deprecated.
put(Bytes, byte[]) - Method in interface org.apache.kafka.streams.state.internals.SegmentedBytesStore
Write a new value to the store with the provided key.
put(Bytes, byte[], long) - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowStore
 
put(Bytes, byte[], long) - Method in class org.apache.kafka.streams.state.internals.RocksDBWindowStore
 
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(Windowed<K>, V) - Method in class org.apache.kafka.streams.state.internals.MeteredSessionStore
 
put(Windowed<Bytes>, byte[]) - Method in class org.apache.kafka.streams.state.internals.InMemorySessionStore
 
put(Windowed<Bytes>, byte[]) - Method in class org.apache.kafka.streams.state.internals.RocksDBSessionStore
 
putAll(String, List<KeyValue<Bytes, LRUCacheEntry>>) - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 
putAll(List<KeyValue<K, V>>) - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
putAll(List<KeyValue<K, V>>) - Method in interface org.apache.kafka.streams.state.KeyValueStore
Update all the given key/value pairs.
putAll(List<KeyValue<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.state.internals.CachingKeyValueStore
 
putAll(List<KeyValue<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.state.internals.ChangeLoggingKeyValueBytesStore
 
putAll(List<KeyValue<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
putAll(List<KeyValue<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.state.internals.KeyValueToTimestampedKeyValueByteStoreAdapter
 
putAll(List<KeyValue<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
putAll(List<KeyValue<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
putAllSensor(String, String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.state.internals.metrics.StateStoreMetrics
 
putIfAbsent(String, Bytes, LRUCacheEntry) - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 
putIfAbsent(K, V) - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
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.
putIfAbsent(Bytes, byte[]) - Method in class org.apache.kafka.streams.state.internals.CachingKeyValueStore
 
putIfAbsent(Bytes, byte[]) - Method in class org.apache.kafka.streams.state.internals.ChangeLoggingKeyValueBytesStore
 
putIfAbsent(Bytes, byte[]) - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
putIfAbsent(Bytes, byte[]) - Method in class org.apache.kafka.streams.state.internals.KeyValueToTimestampedKeyValueByteStoreAdapter
 
putIfAbsent(Bytes, byte[]) - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
putIfAbsent(Bytes, byte[]) - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
putIfAbsentSensor(String, String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.state.internals.metrics.StateStoreMetrics
 
putIfDifferentValues(K, ValueAndTimestamp<V>, byte[]) - Method in class org.apache.kafka.streams.state.internals.MeteredTimestampedKeyValueStore
 
puts() - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 
putSensor - Variable in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
putSensor(String, String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.state.internals.metrics.StateStoreMetrics
 

Q

queryableName() - Method in class org.apache.kafka.streams.kstream.internals.KTableSource
 
queryableStoreName() - Method in interface org.apache.kafka.streams.kstream.GlobalKTable
Get the name of the local state store that can be used to query this GlobalKTable.
queryableStoreName() - Method in class org.apache.kafka.streams.kstream.internals.GlobalKTableImpl
 
queryableStoreName() - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode
 
queryableStoreName() - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
queryableStoreName() - Method in class org.apache.kafka.streams.kstream.internals.MaterializedInternal
 
queryableStoreName() - Method in interface org.apache.kafka.streams.kstream.KTable
Get the name of the local state store used that can be used to query this KTable.
QueryableStoreProvider - Class in org.apache.kafka.streams.state.internals
A wrapper over all of the StateStoreProviders in a Topology
QueryableStoreProvider(List<StreamThreadStateStoreProvider>, GlobalStateStoreProvider) - Constructor for class org.apache.kafka.streams.state.internals.QueryableStoreProvider
 
queryableStoreType() - Method in class org.apache.kafka.streams.StoreQueryParameters
Get the queryable store type for which key is queried by the user.
QueryableStoreType<T> - Interface in org.apache.kafka.streams.state
Used to enable querying of custom StateStore types via the KafkaStreams API.
QueryableStoreTypes - Class in org.apache.kafka.streams.state
Provides access to the QueryableStoreTypes provided with KafkaStreams.
QueryableStoreTypes() - Constructor for class org.apache.kafka.streams.state.QueryableStoreTypes
 
QueryableStoreTypes.KeyValueStoreType<K,​V> - Class in org.apache.kafka.streams.state
 
QueryableStoreTypes.SessionStoreType<K,​V> - Class in org.apache.kafka.streams.state
 
QueryableStoreTypes.WindowStoreType<K,​V> - Class in org.apache.kafka.streams.state
 
queryMetadataForKey(String, K, Serializer<K>) - Method in class org.apache.kafka.streams.KafkaStreams
Finds the metadata containing the active hosts and standby hosts where the key being queried would reside.
queryMetadataForKey(String, K, StreamPartitioner<? super K, ?>) - Method in class org.apache.kafka.streams.KafkaStreams
Finds the metadata containing the active hosts and standby hosts where the key being queried would reside.
QuickUnion<T> - Class in org.apache.kafka.streams.processor.internals
 
QuickUnion() - Constructor for class org.apache.kafka.streams.processor.internals.QuickUnion
 
QuietStreamsConfig - Class in org.apache.kafka.streams.internals
A StreamsConfig that does not log its configuration on construction.
QuietStreamsConfig(Map<?, ?>) - Constructor for class org.apache.kafka.streams.internals.QuietStreamsConfig
 

R

randomAccessMaxBufferSize() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
range(String, Bytes, Bytes) - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 
range(K, K) - Method in class org.apache.kafka.streams.state.internals.CompositeReadOnlyKeyValueStore
 
range(K, K) - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
range(K, K) - Method in class org.apache.kafka.streams.state.internals.ReadOnlyKeyValueStoreFacade
 
range(K, K) - Method in interface org.apache.kafka.streams.state.ReadOnlyKeyValueStore
Get an iterator over a given range of keys.
range(Bytes, Bytes) - Method in class org.apache.kafka.streams.state.internals.CachingKeyValueStore
 
range(Bytes, Bytes) - Method in class org.apache.kafka.streams.state.internals.ChangeLoggingKeyValueBytesStore
 
range(Bytes, Bytes) - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
range(Bytes, Bytes) - Method in class org.apache.kafka.streams.state.internals.KeyValueToTimestampedKeyValueByteStoreAdapter
 
range(Bytes, Bytes) - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
range(Bytes, Bytes) - Method in class org.apache.kafka.streams.state.internals.MemoryNavigableLRUCache
 
range(Bytes, Bytes) - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
range(Bytes, Bytes) - Method in interface org.apache.kafka.streams.state.internals.Segment
 
rangeSensor(String, String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.state.internals.metrics.StateStoreMetrics
 
RATE_DESCRIPTION - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
RATE_DESCRIPTION_PREFIX - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
RATE_DESCRIPTION_SUFFIX - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
RATE_SUFFIX - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
RATIO_SUFFIX - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
RawAndDeserializedValue(byte[], ValueAndTimestamp<ValueType>) - Constructor for class org.apache.kafka.streams.state.internals.MeteredTimestampedKeyValueStore.RawAndDeserializedValue
 
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.
rawValueToTimestampedValue() - Static method in class org.apache.kafka.streams.state.internals.RecordConverters
 
read() - Method in class org.apache.kafka.streams.state.internals.OffsetCheckpoint
Reads the offsets from the local checkpoint file, skipping any negative offsets it finds.
read(Readable, short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
read(Readable, short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
read(Readable, short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
read(Readable, short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
readFrom(DataInputStream) - Static method in class org.apache.kafka.streams.processor.TaskId
 
readFrom(ByteBuffer) - Static method in class org.apache.kafka.streams.processor.TaskId
 
ReadOnlyKeyValueStore<K,​V> - Interface in org.apache.kafka.streams.state
A key-value store that only supports read operations.
ReadOnlyKeyValueStoreFacade<K,​V> - Class in org.apache.kafka.streams.state.internals
 
ReadOnlyKeyValueStoreFacade(TimestampedKeyValueStore<K, V>) - Constructor for class org.apache.kafka.streams.state.internals.ReadOnlyKeyValueStoreFacade
 
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.
ReadOnlyWindowStoreFacade<K,​V> - Class in org.apache.kafka.streams.state.internals
 
ReadOnlyWindowStoreFacade(TimestampedWindowStore<K, V>) - Constructor for class org.apache.kafka.streams.state.internals.ReadOnlyWindowStoreFacade
 
rebalanceProtocol() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
REBALANCING - org.apache.kafka.streams.KafkaStreams.State
 
RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
receive.buffer.bytes
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.streams.StreamsConfig
reconnect.backoff.ms
record(long) - Method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetricsRecorder
 
RECORD_CACHE_ID_TAG - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
RecordBatchingStateRestoreCallback - Interface in org.apache.kafka.streams.processor.internals
 
recordCollector() - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
recordCollector() - Method in interface org.apache.kafka.streams.processor.internals.RecordCollector.Supplier
Get the record collector.
RecordCollector - Interface in org.apache.kafka.streams.processor.internals
 
RecordCollector.Supplier - Interface in org.apache.kafka.streams.processor.internals
A supplier of a RecordCollectorImpl instance.
RecordCollectorImpl - Class in org.apache.kafka.streams.processor.internals
 
RecordCollectorImpl(LogContext, TaskId, StreamsProducer, ProductionExceptionHandler, StreamsMetricsImpl) - Constructor for class org.apache.kafka.streams.processor.internals.RecordCollectorImpl
 
recordContext - Variable in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
recordContext() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
recordContext() - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
Returns the current RecordContext
recordContext() - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
recordContext() - Method in class org.apache.kafka.streams.state.internals.ContextualRecord
 
recordContext() - Method in class org.apache.kafka.streams.state.internals.TimeOrderedKeyValueBuffer.Eviction
 
RecordContext - Interface in org.apache.kafka.streams.processor
The context associated with the current record being processed by an Processor
RecordConverter - Interface in org.apache.kafka.streams.state.internals
 
RecordConverters - Class in org.apache.kafka.streams.state.internals
 
recordLatency(Sensor, long, long) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
Deprecated.
recordLatency(Sensor, long, long) - Method in interface org.apache.kafka.streams.StreamsMetrics
Deprecated.
since 2.5. Use Sensor#record() instead.
recordLatenessSensor(String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.TaskMetrics
 
recordProcessBatchTime(long) - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
recordProcessBatchTime(long) - Method in interface org.apache.kafka.streams.processor.internals.Task
 
recordProcessTimeRatioAndBufferSize(long, long) - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
recordProcessTimeRatioAndBufferSize(long, long) - Method in interface org.apache.kafka.streams.processor.internals.Task
 
RecordQueue - Class in org.apache.kafka.streams.processor.internals
RecordQueue is a FIFO queue of StampedRecord (ConsumerRecord + timestamp).
RECORDS_SUFFIX - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
recordThroughput(Sensor, long) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
Deprecated.
recordThroughput(Sensor, long) - Method in interface org.apache.kafka.streams.StreamsMetrics
Deprecated.
since 2.5. Use Sensor#record() instead.
recycleLogFileNum() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
reduce(Reducer<V>) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImpl
 
reduce(Reducer<V>) - Method in class org.apache.kafka.streams.kstream.internals.TimeWindowedKStreamImpl
 
reduce(Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Combine the values of records in this stream by the grouped key.
reduce(Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
Combine the values of records in this stream by the grouped key and defined sessions.
reduce(Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Combine the values of records in this stream by the grouped key and defined windows.
reduce(Reducer<V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Combine the value of records in this stream by the grouped key.
reduce(Reducer<V>, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImpl
 
reduce(Reducer<V>, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
Combine the values of records in this stream by the grouped key and defined sessions.
reduce(Reducer<V>, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.TimeWindowedKStreamImpl
 
reduce(Reducer<V>, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Combine the values of records in this stream by the grouped key and defined windows.
reduce(Reducer<V>, Named) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImpl
 
reduce(Reducer<V>, Named) - Method in class org.apache.kafka.streams.kstream.internals.TimeWindowedKStreamImpl
 
reduce(Reducer<V>, Named) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
Combine the values of records in this stream by the grouped key and defined sessions.
reduce(Reducer<V>, Named) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Combine the values of records in this stream by the grouped key and defined windows.
reduce(Reducer<V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Combine the value of records in this stream by the grouped key.
reduce(Reducer<V>, Named, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImpl
 
reduce(Reducer<V>, Named, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
Combine the values of records in this stream by the grouped key and defined sessions.
reduce(Reducer<V>, Named, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.TimeWindowedKStreamImpl
 
reduce(Reducer<V>, Named, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Combine the values of records in this stream by the grouped key and defined windows.
reduce(Reducer<V>, Reducer<V>) - Method in class org.apache.kafka.streams.kstream.internals.KGroupedTableImpl
 
reduce(Reducer<V>, Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
Combine the value of records of the original KTable that got mapped to the same key into a new instance of KTable.
reduce(Reducer<V>, Reducer<V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KGroupedTableImpl
 
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 class org.apache.kafka.streams.kstream.internals.KGroupedTableImpl
 
reduce(Reducer<V>, Reducer<V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KGroupedTable
Combine the value of records of the original KTable that got mapped to the same key into a new instance of KTable.
Reducer<V> - Interface in org.apache.kafka.streams.kstream
The Reducer interface for combining two values of the same type into a new value.
register(TopicPartition, ProcessorStateManager) - Method in interface org.apache.kafka.streams.processor.internals.ChangelogRegister
Register a state store for restoration.
register(TopicPartition, ProcessorStateManager) - Method in class org.apache.kafka.streams.processor.internals.StoreChangelogReader
Since it is shared for multiple tasks and hence multiple state managers, the registration would take its corresponding state manager as well for restoring.
register(StateStore, StateRestoreCallback) - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
register(StateStore, StateRestoreCallback) - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
register(StateStore, StateRestoreCallback) - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
register(StateStore, StateRestoreCallback) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Registers and possibly restores the specified storage engine.
registerCacheFlushListener(String, ThreadCache.DirtyEntryFlushListener) - Method in class org.apache.kafka.streams.processor.internals.GlobalProcessorContextImpl
 
registerCacheFlushListener(String, ThreadCache.DirtyEntryFlushListener) - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
Register a dirty entry flush listener for a particular namespace
registerCacheFlushListener(String, ThreadCache.DirtyEntryFlushListener) - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
registerStore(StateStore, StateRestoreCallback) - Method in class org.apache.kafka.streams.processor.internals.GlobalStateManagerImpl
 
registerStore(StateStore, StateRestoreCallback) - Method in class org.apache.kafka.streams.processor.internals.ProcessorStateManager
 
remove(Bytes) - Method in class org.apache.kafka.streams.state.internals.AbstractRocksDBSegmentedBytesStore
 
remove(Bytes) - Method in interface org.apache.kafka.streams.state.internals.SegmentedBytesStore
Remove the record with the provided key.
remove(Windowed<K>) - Method in class org.apache.kafka.streams.state.internals.MeteredSessionStore
 
remove(Windowed<K>) - Method in interface org.apache.kafka.streams.state.SessionStore
Remove the session aggregated with provided Windowed key from the store
remove(Windowed<Bytes>) - Method in class org.apache.kafka.streams.state.internals.InMemorySessionStore
 
remove(Windowed<Bytes>) - Method in class org.apache.kafka.streams.state.internals.RocksDBSessionStore
 
removeAllCacheLevelSensors(String, String, String) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
removeAllClientLevelMetrics() - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
removeAllNodeLevelSensors(String, String, String) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
removeAllStoreLevelSensors(String, String, String) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
removeAllTaskLevelSensors(String, String) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
removeAllThreadLevelSensors(String) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
removeChild(StreamsGraphNode) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
removeMetricsRecorder(RocksDBMetricsRecorder) - Method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetricsRecordingTrigger
 
removeSensor(String, String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.state.internals.metrics.StateStoreMetrics
 
removeSensor(Sensor) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
Deletes a sensor and its parents, if any
removeSensor(Sensor) - Method in interface org.apache.kafka.streams.StreamsMetrics
Remove a sensor.
removeStatistics(String) - Method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetricsRecorder
 
repartition() - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
repartition() - Method in interface org.apache.kafka.streams.kstream.KStream
Materialize this stream to an auto-generated repartition topic and create a new KStream from the auto-generated topic using default serializers, deserializers, and producer's DefaultPartitioner.
repartition(Repartitioned<K, V>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
repartition(Repartitioned<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Materialize this stream to an auto-generated repartition topic and create a new KStream from the auto-generated topic using key serde, value serde, StreamPartitioner, number of partitions, and topic name part as defined by Repartitioned.
Repartitioned<K,​V> - Class in org.apache.kafka.streams.kstream
This class is used to provide the optional parameters for internal repartition topics.
Repartitioned(Repartitioned<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Repartitioned
 
RepartitionedInternal<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
RepartitionedInternal(Repartitioned<K, V>) - Constructor for class org.apache.kafka.streams.kstream.internals.RepartitionedInternal
 
repartitionSourceTopics - Variable in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopicsInfo
 
repartitionTopic - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
repartitionTopic - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode
 
repartitionTopic() - Method in class org.apache.kafka.streams.kstream.internals.graph.OptimizableRepartitionNode
 
RepartitionTopicConfig - Class in org.apache.kafka.streams.processor.internals
RepartitionTopicConfig captures the properties required for configuring the repartition topics.
REPLICATION_FACTOR_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
replication.factor
reportBgIoStats() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
request.timeout.ms
resetPolicy - Variable in class org.apache.kafka.streams.kstream.Consumed
 
resetProducer() - Method in class org.apache.kafka.streams.processor.internals.StreamsProducer
 
residentMemorySizeEstimate() - Method in class org.apache.kafka.streams.processor.internals.ProcessorRecordContext
 
restore() - Method in interface org.apache.kafka.streams.processor.internals.ChangelogReader
Restore all registered state stores by reading from their changelogs
restore() - Method in class org.apache.kafka.streams.processor.internals.StoreChangelogReader
 
restore(byte[], byte[]) - Method in interface org.apache.kafka.streams.processor.BatchingStateRestoreCallback
 
restore(byte[], byte[]) - Method in interface org.apache.kafka.streams.processor.StateRestoreCallback
 
RESTORE_CONSUMER_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
Prefix used to override consumer configs for the restore consumer client from the general consumer client configs.
restoreAll(Collection<KeyValue<byte[], byte[]>>) - Method in interface org.apache.kafka.streams.processor.BatchingStateRestoreCallback
Called to restore a number of records.
restoreAll(Collection<KeyValue<byte[], byte[]>>) - Method in interface org.apache.kafka.streams.processor.internals.RecordBatchingStateRestoreCallback
 
restoreBatch(Collection<ConsumerRecord<byte[], byte[]>>) - Method in interface org.apache.kafka.streams.processor.internals.RecordBatchingStateRestoreCallback
 
restoreConsumerClientId() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
restoreConsumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
restoreSensor(String, String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.state.internals.metrics.StateStoreMetrics
 
RESTORING - org.apache.kafka.streams.processor.internals.Task.State
 
restoringTaskFor(TopicPartition) - Method in interface org.apache.kafka.streams.processor.internals.RestoringTasks
 
RestoringTasks - Interface in org.apache.kafka.streams.processor.internals
 
resume() - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
 
resume() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
- resume the task
resume() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
retainDuplicates() - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowBytesStoreSupplier
 
retainDuplicates() - Method in class org.apache.kafka.streams.state.internals.RocksDbWindowBytesStoreSupplier
 
retainDuplicates() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
Whether or not this store is retaining duplicate keys.
retention - Variable in class org.apache.kafka.streams.kstream.Materialized
 
retentionPeriod() - Method in class org.apache.kafka.streams.state.internals.InMemorySessionBytesStoreSupplier
 
retentionPeriod() - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowBytesStoreSupplier
 
retentionPeriod() - Method in class org.apache.kafka.streams.state.internals.RocksDbSessionBytesStoreSupplier
 
retentionPeriod() - Method in class org.apache.kafka.streams.state.internals.RocksDbWindowBytesStoreSupplier
 
retentionPeriod() - Method in class org.apache.kafka.streams.state.internals.SessionStoreBuilder
 
retentionPeriod() - Method in class org.apache.kafka.streams.state.internals.TimestampedWindowStoreBuilder
 
retentionPeriod() - Method in class org.apache.kafka.streams.state.internals.WindowStoreBuilder
 
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.
RETRIES_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
retries
RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
retry.backoff.ms
reuseSourceTopicForChangeLog(boolean) - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode
 
revive() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
revive() - Method in interface org.apache.kafka.streams.processor.internals.Task
Revive a closed task to a created one; should never throw an exception
rewriteTopology(StreamsConfig) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
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.
RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter - Class in org.apache.kafka.streams.state.internals
The generic Options class allows users to set all configs on one object if only default column family is used.
RocksDbKeyValueBytesStoreSupplier - Class in org.apache.kafka.streams.state.internals
 
RocksDbKeyValueBytesStoreSupplier(String, boolean) - Constructor for class org.apache.kafka.streams.state.internals.RocksDbKeyValueBytesStoreSupplier
 
RocksDBMetricContext(String, String, String, String) - Constructor for class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics.RocksDBMetricContext
 
RocksDBMetrics - Class in org.apache.kafka.streams.state.internals.metrics
 
RocksDBMetrics.RocksDBMetricContext - Class in org.apache.kafka.streams.state.internals.metrics
 
RocksDBMetricsRecorder - Class in org.apache.kafka.streams.state.internals.metrics
 
RocksDBMetricsRecorder(String, String, String) - Constructor for class org.apache.kafka.streams.state.internals.metrics.RocksDBMetricsRecorder
 
rocksDBMetricsRecordingTrigger() - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
RocksDBMetricsRecordingTrigger - Class in org.apache.kafka.streams.state.internals.metrics
 
RocksDBMetricsRecordingTrigger(Time) - Constructor for class org.apache.kafka.streams.state.internals.metrics.RocksDBMetricsRecordingTrigger
 
RocksDBSegmentedBytesStore - Class in org.apache.kafka.streams.state.internals
 
RocksDbSessionBytesStoreSupplier - Class in org.apache.kafka.streams.state.internals
 
RocksDbSessionBytesStoreSupplier(String, long) - Constructor for class org.apache.kafka.streams.state.internals.RocksDbSessionBytesStoreSupplier
 
RocksDBSessionStore - Class in org.apache.kafka.streams.state.internals
 
RocksDBStore - Class in org.apache.kafka.streams.state.internals
A persistent key-value store based on RocksDB.
RocksDBTimestampedSegmentedBytesStore - Class in org.apache.kafka.streams.state.internals
 
RocksDBTimestampedStore - Class in org.apache.kafka.streams.state.internals
A persistent key-(value-timestamp) store based on RocksDB.
RocksDbWindowBytesStoreSupplier - Class in org.apache.kafka.streams.state.internals
 
RocksDbWindowBytesStoreSupplier(String, long, long, long, boolean, boolean) - Constructor for class org.apache.kafka.streams.state.internals.RocksDbWindowBytesStoreSupplier
 
RocksDBWindowStore - Class in org.apache.kafka.streams.state.internals
 
ROLLUP_VALUE - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
root - Variable in class org.apache.kafka.streams.kstream.internals.InternalStreamsBuilder
 
root() - Method in class org.apache.kafka.streams.kstream.internals.InternalStreamsBuilder
 
root(T) - Method in class org.apache.kafka.streams.processor.internals.QuickUnion
 
rowCache() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
run() - Method in class org.apache.kafka.streams.processor.internals.GlobalStreamThread
 
run() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
Execute the stream processors
run() - Method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetricsRecordingTrigger
 
RUNNING - org.apache.kafka.streams.KafkaStreams.State
 
RUNNING - org.apache.kafka.streams.processor.internals.GlobalStreamThread.State
 
RUNNING - org.apache.kafka.streams.processor.internals.StreamThread.State
 
RUNNING - org.apache.kafka.streams.processor.internals.Task.State
 

S

schedule(long, PunctuationType, Punctuator) - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
Deprecated.
schedule(long, PunctuationType, Punctuator) - Method in class org.apache.kafka.streams.processor.internals.GlobalProcessorContextImpl
Deprecated.
schedule(long, PunctuationType, Punctuator) - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
Deprecated.
schedule(long, PunctuationType, Punctuator) - Method in class org.apache.kafka.streams.processor.internals.StreamTask
Schedules a punctuation for the processor
schedule(long, PunctuationType, Punctuator) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
schedule(Duration, PunctuationType, Punctuator) - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
schedule(Duration, PunctuationType, Punctuator) - Method in class org.apache.kafka.streams.processor.internals.GlobalProcessorContextImpl
 
schedule(Duration, PunctuationType, Punctuator) - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
schedule(Duration, PunctuationType, Punctuator) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Schedules a periodic operation for processors.
schedule(PunctuationSchedule) - Method in class org.apache.kafka.streams.processor.internals.PunctuationQueue
 
SCHEMA_1 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
SCHEMA_1 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
SCHEMA_2 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
SCHEMA_2 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
SCHEMA_3 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
SCHEMA_3 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
SCHEMA_4 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
SCHEMA_4 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
SCHEMA_5 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
SCHEMA_5 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
SCHEMA_6 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
SCHEMA_6 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
SCHEMA_7 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
SCHEMA_7 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
SCHEMA_7 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
SCHEMA_7 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
SCHEMA_8 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
SCHEMA_8 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
SCHEMA_8 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
SCHEMA_8 - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
SCHEMAS - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
SCHEMAS - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
SCHEMAS - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
SCHEMAS - Static variable in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
SECURITY_PROTOCOL_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
security.protocol
Segment - Interface in org.apache.kafka.streams.state.internals
 
SegmentedBytesStore - Interface in org.apache.kafka.streams.state.internals
The interface representing a StateStore that has 1 or more segments that are based on time.
SegmentedBytesStore.KeySchema - Interface in org.apache.kafka.streams.state.internals
 
segmentIntervalMs() - Method in class org.apache.kafka.streams.state.internals.InMemorySessionBytesStoreSupplier
 
segmentIntervalMs() - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowBytesStoreSupplier
 
segmentIntervalMs() - Method in class org.apache.kafka.streams.state.internals.RocksDbSessionBytesStoreSupplier
 
segmentIntervalMs() - Method in class org.apache.kafka.streams.state.internals.RocksDbWindowBytesStoreSupplier
 
segmentIntervalMs() - Method in interface org.apache.kafka.streams.state.SessionBytesStoreSupplier
The size of a segment, in milliseconds.
segmentIntervalMs() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
The size of the segments (in milliseconds) the store has.
segments - Variable in class org.apache.kafka.streams.kstream.Windows
Deprecated.
segments() - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowBytesStoreSupplier
Deprecated.
segments() - Method in class org.apache.kafka.streams.state.internals.RocksDbWindowBytesStoreSupplier
Deprecated.
segments() - Method in interface org.apache.kafka.streams.state.WindowBytesStoreSupplier
Deprecated.
segments(int) - Method in class org.apache.kafka.streams.kstream.Windows
Deprecated.
since 2.1 Override segmentInterval() instead.
segmentsToSearch(Segments<S>, long, long) - Method in interface org.apache.kafka.streams.state.internals.SegmentedBytesStore.KeySchema
Used during SegmentedBytesStore.fetch(Bytes, long, long) operations to determine which segments should be scanned.
segmentsToSearch(Segments<S>, long, long) - Method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
segmentsToSearch(Segments<S>, long, long) - Method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
segmentTimestamp(Bytes) - Method in interface org.apache.kafka.streams.state.internals.SegmentedBytesStore.KeySchema
Extract the timestamp of the segment from the key.
segmentTimestamp(Bytes) - Method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
segmentTimestamp(Bytes) - Method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
selectKey(KeyValueMapper<? super K, ? super V, ? extends KR>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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(String, K, V, Headers, Integer, Long, Serializer<K>, Serializer<V>) - Method in interface org.apache.kafka.streams.processor.internals.RecordCollector
 
send(String, K, V, Headers, Integer, Long, Serializer<K>, Serializer<V>) - Method in class org.apache.kafka.streams.processor.internals.RecordCollectorImpl
 
send(String, K, V, Headers, Long, Serializer<K>, Serializer<V>, StreamPartitioner<? super K, ? super V>) - Method in interface org.apache.kafka.streams.processor.internals.RecordCollector
 
send(String, K, V, Headers, Long, Serializer<K>, Serializer<V>, StreamPartitioner<? super K, ? super V>) - Method in class org.apache.kafka.streams.processor.internals.RecordCollectorImpl
 
SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
send.buffer.bytes
serialize() - Method in class org.apache.kafka.streams.processor.internals.ProcessorRecordContext
 
serialize(String, Headers, Change<T>) - Method in class org.apache.kafka.streams.kstream.internals.ChangedSerializer
 
serialize(String, Change<T>) - Method in class org.apache.kafka.streams.kstream.internals.ChangedSerializer
 
serialize(String, Windowed<T>) - Method in class org.apache.kafka.streams.kstream.SessionWindowedSerializer
 
serialize(String, Windowed<T>) - Method in class org.apache.kafka.streams.kstream.TimeWindowedSerializer
 
serialize(String, ValueAndTimestamp<V>) - Method in class org.apache.kafka.streams.state.internals.ValueAndTimestampSerializer
 
serialize(String, V, long) - Method in class org.apache.kafka.streams.state.internals.ValueAndTimestampSerializer
 
serializeBaseKey(String, Windowed<T>) - Method in interface org.apache.kafka.streams.kstream.internals.WindowedSerializer
 
serializeBaseKey(String, Windowed<T>) - Method in class org.apache.kafka.streams.kstream.SessionWindowedSerializer
 
serializeBaseKey(String, Windowed<T>) - Method in class org.apache.kafka.streams.kstream.TimeWindowedSerializer
 
Serialized<K,​V> - Class in org.apache.kafka.streams.kstream
Deprecated.
since 2.1. Use Grouped instead
Serialized(Serialized<K, V>) - Constructor for class org.apache.kafka.streams.kstream.Serialized
Deprecated.
 
SerializedInternal<K,​V> - Class in org.apache.kafka.streams.kstream.internals
Deprecated.
SerializedInternal(Serialized<K, V>) - Constructor for class org.apache.kafka.streams.kstream.internals.SerializedInternal
Deprecated.
 
serializedValue - Variable in class org.apache.kafka.streams.state.internals.MeteredTimestampedKeyValueStore.RawAndDeserializedValue
 
serializeParts(String, Change<T>) - Method in class org.apache.kafka.streams.kstream.internals.FullChangeSerde
 
serializer() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionResponseWrapperSerde
 
serializer() - Method in class org.apache.kafka.streams.kstream.internals.WrappingNullableSerde
 
SessionBytesStoreSupplier - Interface in org.apache.kafka.streams.state
A store supplier that can be used to create one or more SessionStore<Byte, byte[]> instances.
SessionKeySchema - Class in org.apache.kafka.streams.state.internals
 
SessionKeySchema() - Constructor for class org.apache.kafka.streams.state.internals.SessionKeySchema
 
sessionStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
SessionStore<K,​AGG> - Interface in org.apache.kafka.streams.state
Interface for storing the aggregated values of sessions.
sessionStoreBuilder(SessionBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
Creates a StoreBuilder that can be used to build a SessionStore.
SessionStoreBuilder<K,​V> - Class in org.apache.kafka.streams.state.internals
 
SessionStoreBuilder(SessionBytesStoreSupplier, Serde<K>, Serde<V>, Time) - Constructor for class org.apache.kafka.streams.state.internals.SessionStoreBuilder
 
SessionWindow - Class in org.apache.kafka.streams.kstream.internals
A session window covers a closed time interval with its start and end timestamp both being an inclusive boundary.
SessionWindow(long, long) - Constructor for class org.apache.kafka.streams.kstream.internals.SessionWindow
Create a new window for the given start time and end time (both inclusive).
SessionWindowedCogroupedKStream<K,​V> - Interface in org.apache.kafka.streams.kstream
SessionWindowedCogroupKStream is an abstraction of a windowed record stream of KeyValue pairs.
SessionWindowedCogroupedKStreamImpl<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
SessionWindowedDeserializer<T> - Class in org.apache.kafka.streams.kstream
The inner serde class can be specified by setting the property StreamsConfig.DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS or StreamsConfig.DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS if the no-arg constructor is called and hence it is not passed during initialization.
SessionWindowedDeserializer() - Constructor for class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
 
SessionWindowedDeserializer(Deserializer<T>) - Constructor for class org.apache.kafka.streams.kstream.SessionWindowedDeserializer
 
SessionWindowedKStream<K,​V> - Interface in org.apache.kafka.streams.kstream
SessionWindowedKStream is an abstraction of a windowed record stream of KeyValue pairs.
SessionWindowedKStreamImpl<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
SessionWindowedSerde() - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.SessionWindowedSerde
 
SessionWindowedSerde(Serde<T>) - Constructor for class org.apache.kafka.streams.kstream.WindowedSerdes.SessionWindowedSerde
 
sessionWindowedSerdeFrom(Class<T>) - Static method in class org.apache.kafka.streams.kstream.WindowedSerdes
Construct a SessionWindowedSerde object for the specified inner class type.
SessionWindowedSerializer<T> - Class in org.apache.kafka.streams.kstream
The inner serde class can be specified by setting the property StreamsConfig.DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS or StreamsConfig.DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS if the no-arg constructor is called and hence it is not passed during initialization.
SessionWindowedSerializer() - Constructor for class org.apache.kafka.streams.kstream.SessionWindowedSerializer
 
SessionWindowedSerializer(Serializer<T>) - Constructor for class org.apache.kafka.streams.kstream.SessionWindowedSerializer
 
SessionWindows - Class in org.apache.kafka.streams.kstream
A session based window specification used for aggregating events into sessions.
setAccessHintOnCompactionStart(AccessHint) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setAdviseRandomOnOpen(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setAllow2pc(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setAllowConcurrentMemtableWrite(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setAllowFAllocate(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setAllowMmapReads(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setAllowMmapWrites(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setApplicationIdAndInternalStream(String, String, String) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
setArenaBlockSize(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setAvoidFlushDuringRecovery(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setAvoidFlushDuringShutdown(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setBaseBackgroundCompactions(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setBloomLocality(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setBottommostCompressionType(CompressionType) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setBuildPriority(int) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
setBytesPerSync(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setCompactionFilter(AbstractCompactionFilter<? extends AbstractSlice<?>>) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setCompactionFilterFactory(AbstractCompactionFilterFactory<? extends AbstractCompactionFilter<?>>) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setCompactionOptionsFIFO(CompactionOptionsFIFO) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setCompactionOptionsUniversal(CompactionOptionsUniversal) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setCompactionPriority(CompactionPriority) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setCompactionReadaheadSize(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setCompactionStyle(CompactionStyle) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setComparator(AbstractComparator<? extends AbstractSlice<?>>) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setComparator(BuiltinComparator) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setCompressionOptions(CompressionOptions) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setCompressionPerLevel(List<CompressionType>) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setCompressionType(CompressionType) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setConfig(String, Options, Map<String, Object>) - Method in interface org.apache.kafka.streams.state.RocksDBConfigSetter
Set the rocks db options for the provided storeName.
setCreateIfMissing(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setCreateMissingColumnFamilies(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setCurrentNode(ProcessorNode<?, ?>) - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
setCurrentNode(ProcessorNode<?, ?>) - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
 
setDbLogDir(String) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setDbPaths(Collection<DbPath>) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setDbWriteBufferSize(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setDefaultStream(String) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
setDelayedWriteRate(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setDeleteObsoleteFilesPeriodMicros(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setDisableAutoCompactions(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setDumpMallocStats(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setEnableThreadTracking(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setEnableWriteThreadAdaptiveYield(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setEnv(Env) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setErrorIfExists(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setFailIfOptionsFileError(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setFlushListener(CacheFlushListener<byte[], byte[]>, boolean) - Method in class org.apache.kafka.streams.state.internals.CachingKeyValueStore
 
setFlushListener(CacheFlushListener<K, V>, boolean) - Method in interface org.apache.kafka.streams.state.internals.CachedStateStore
Set the CacheFlushListener to be notified when entries are flushed from the cache to the underlying StateStore
setFlushListener(CacheFlushListener<K, V>, boolean) - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
setFlushListener(CacheFlushListener<K, V>, boolean) - Method in class org.apache.kafka.streams.state.internals.WrappedStateStore
 
setFlushListener(CacheFlushListener<Windowed<K>, V>, boolean) - Method in class org.apache.kafka.streams.state.internals.MeteredSessionStore
 
setFlushListener(CacheFlushListener<Windowed<K>, V>, boolean) - Method in class org.apache.kafka.streams.state.internals.MeteredWindowStore
 
setForceConsistencyChecks(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setGlobalProcessorContext(InternalProcessorContext) - Method in interface org.apache.kafka.streams.processor.internals.GlobalStateManager
 
setGlobalProcessorContext(InternalProcessorContext) - Method in class org.apache.kafka.streams.processor.internals.GlobalStateManagerImpl
 
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.
setHardPendingCompactionBytesLimit(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setHasWrittenToTopology(boolean) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
setIfUnset(Deserializer<InnerK>, Deserializer<InnerV>) - Method in interface org.apache.kafka.streams.kstream.internals.WrappingNullableDeserializer
 
setIfUnset(Deserializer<Void>, Deserializer<T>) - Method in class org.apache.kafka.streams.kstream.internals.ChangedDeserializer
 
setIfUnset(Serde<InnerK>, Serde<InnerV>) - Method in class org.apache.kafka.streams.kstream.internals.WrappingNullableSerde
 
setIfUnset(Serializer<InnerK>, Serializer<InnerV>) - Method in interface org.apache.kafka.streams.kstream.internals.WrappingNullableSerializer
 
setIfUnset(Serializer<Void>, Serializer<T>) - Method in class org.apache.kafka.streams.kstream.internals.ChangedSerializer
 
setIfUnset(Serializer<Void>, Serializer<V>) - Method in class org.apache.kafka.streams.state.internals.ValueAndTimestampSerializer
 
setIncreaseParallelism(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setInfoLogLevel(InfoLogLevel) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setInplaceUpdateNumLocks(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setInplaceUpdateSupport(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setIsChangelogTopic(boolean) - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
 
setIsFdCloseOnExec(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setKeepLogFileNum(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setLatestSupportedVersion(int) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
setLevel0FileNumCompactionTrigger(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setLevel0SlowdownWritesTrigger(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setLevel0StopWritesTrigger(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setLevelCompactionDynamicLevelBytes(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setLevelZeroFileNumCompactionTrigger(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setLevelZeroSlowdownWritesTrigger(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setLevelZeroStopWritesTrigger(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setLogFileTimeToRoll(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setLogger(Logger) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setManifestPreallocationSize(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxBackgroundCompactions(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxBackgroundFlushes(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxBackgroundJobs(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxBytesForLevelBase(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxBytesForLevelMultiplier(double) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxBytesForLevelMultiplierAdditional(int[]) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxCompactionBytes(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxFileOpeningThreads(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxLogFileSize(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxManifestFileSize(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxOpenFiles(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxSequentialSkipInIterations(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxSubcompactions(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxSuccessiveMerges(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxTableFilesSizeFIFO(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxTotalWalSize(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxWriteBufferNumber(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMaxWriteBufferNumberToMaintain(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMemTableConfig(MemTableConfig) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMemtableHugePageSize(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMemtablePrefixBloomSizeRatio(double) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMergeNode(boolean) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
setMergeOperator(MergeOperator) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMergeOperatorName(String) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setMinWriteBufferNumberToMerge(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setNewTableReaderForCompactionInputs(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setNextRebalanceTime(long) - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
setNumberOfPartitions(int) - Method in class org.apache.kafka.streams.processor.internals.InternalTopicConfig
 
setNumLevels(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setOffsetSum(long) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
setOptimizeFiltersForHits(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setParanoidChecks(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setParanoidFileChecks(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setPartition(int) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
setPartition(int) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
setPartitionResetter(Consumer<Set<TopicPartition>>) - Method in class org.apache.kafka.streams.processor.internals.TaskManager
 
setPartitionToOffsetSum(List<SubscriptionInfoData.PartitionToOffsetSum>) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
setPrevTasks(List<SubscriptionInfoData.TaskId>) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
setProcessId(UUID) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
setRandomAccessMaxBufferSize(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setRateLimiter(RateLimiter) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setRecordContext(ProcessorRecordContext) - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
setRecordContext(ProcessorRecordContext) - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
 
setRecordContext(ProcessorRecordContext) - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
setRecycleLogFileNum(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setReportBgIoStats(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setRocksDBMetricsRecordingTrigger(RocksDBMetricsRecordingTrigger) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
setRowCache(Cache) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setSerdesIfNull(Serde<K>, Serde<V>) - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
setSerdesIfNull(Serde<K>, Serde<V>) - Method in interface org.apache.kafka.streams.state.internals.TimeOrderedKeyValueBuffer
 
setSkipStatsUpdateOnDbOpen(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setSoftPendingCompactionBytesLimit(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setSstFileManager(SstFileManager) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setStandbyTasks(List<SubscriptionInfoData.TaskId>) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
setStateListener(KafkaStreams.StateListener) - Method in class org.apache.kafka.streams.KafkaStreams
An app can set a single KafkaStreams.StateListener so that the app is notified when state changes.
setStateListener(StreamThread.StateListener) - Method in class org.apache.kafka.streams.processor.internals.GlobalStreamThread
Set the StreamThread.StateListener to be notified when state changes.
setStateListener(StreamThread.StateListener) - Method in class org.apache.kafka.streams.processor.internals.StreamThread
Set the StreamThread.StateListener to be notified when state changes.
setStatistics(Statistics) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setStatsDumpPeriodSec(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setStoreQueryParameters(StoreQueryParameters) - Method in class org.apache.kafka.streams.state.internals.WrappingStoreProvider
 
setSystemTimeMs(long) - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
setSystemTimeMs(long) - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
 
setTableCacheNumshardbits(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setTableFormatConfig(TableFormatConfig) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setTargetFileSizeBase(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setTargetFileSizeMultiplier(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setTaskOffsetSums(List<SubscriptionInfoData.TaskOffsetSum>) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
setTopicGroupId(int) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
setTopicGroupId(int) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
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.
setUniqueField(byte) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
setUseAdaptiveMutex(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setUseDirectIoForFlushAndCompaction(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setUseDirectReads(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setUseFsync(boolean) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setUserEndPoint(byte[]) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
setValueChangingOperation(boolean) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
setVersion(int) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
setWalBytesPerSync(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setWalDir(String) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setWalRecoveryMode(WALRecoveryMode) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setWalSizeLimitMB(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setWalTtlSeconds(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setWritableFileMaxBufferSize(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setWriteBufferManager(WriteBufferManager) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setWriteBufferSize(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setWriteThreadMaxYieldUsec(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
setWriteThreadSlowYieldUsec(long) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
SHUT_DOWN - org.apache.kafka.streams.kstream.internals.suppress.BufferFullStrategy
 
shutdown() - Method in class org.apache.kafka.streams.processor.internals.GlobalStreamThread
 
shutdown() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
Shutdown this stream thread.
shutDownWhenFull() - Method in class org.apache.kafka.streams.kstream.internals.suppress.BufferConfigInternal
 
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.
sink(String) - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
Sink(String, String) - Constructor for class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Sink
 
Sink(String, TopicNameExtractor<K, V>) - Constructor for class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Sink
 
sinkName - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
sinkName - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode
 
SinkNode<K,​V> - Class in org.apache.kafka.streams.processor.internals
 
sinkTopics() - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
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.
size() - Method in class org.apache.kafka.streams.processor.internals.RecordQueue
Returns the number of records in the queue
size() - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
size() - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 
size(ObjectSerializationCache, short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
size(ObjectSerializationCache, short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
size(ObjectSerializationCache, short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
size(ObjectSerializationCache, short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
sizeMs - Variable in class org.apache.kafka.streams.kstream.TimeWindows
The size of the windows in milliseconds.
skippedIdempotentUpdatesSensor(String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ProcessorNodeMetrics
 
skipRecordSensor(String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ThreadMetrics
 
skipStatsUpdateOnDbOpen() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
softPendingCompactionBytesLimit() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
source() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.GlobalStore
 
source() - Method in class org.apache.kafka.streams.processor.internals.RecordQueue
Returns the corresponding source node in the topology
source() - Method in interface org.apache.kafka.streams.TopologyDescription.GlobalStore
The source node reading from a "global" topic.
source(String) - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
Source(String, Set<String>, Pattern) - Constructor for class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Source
 
sourceName - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
sourceName - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode
 
SourceNode<K,​V> - Class in org.apache.kafka.streams.processor.internals
 
SourceNode(String, Deserializer<K>, Deserializer<V>) - Constructor for class org.apache.kafka.streams.processor.internals.SourceNode
 
SourceNode(String, TimestampExtractor, Deserializer<K>, Deserializer<V>) - Constructor for class org.apache.kafka.streams.processor.internals.SourceNode
 
sources() - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
sourceTopicChangelogs() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopicsInfo
Returns the topic names for any optimized source changelogs
sourceTopicNames() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
sourceTopics - Variable in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopicsInfo
 
sourceTopics() - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
sourceTopicsForStore(String) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
SPILL_TO_DISK - org.apache.kafka.streams.kstream.internals.suppress.BufferFullStrategy
 
staleStoresEnabled() - Method in class org.apache.kafka.streams.StoreQueryParameters
Get the flag staleStores.
Stamped<V> - Class in org.apache.kafka.streams.processor.internals
 
StampedRecord - Class in org.apache.kafka.streams.processor.internals
 
StampedRecord(ConsumerRecord<Object, Object>, long) - Constructor for class org.apache.kafka.streams.processor.internals.StampedRecord
 
STANDBY - org.apache.kafka.streams.processor.internals.Task.TaskType
 
standbyPartitionByHost() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
standbyStateStoreNames() - Method in class org.apache.kafka.streams.state.StreamsMetadata
State stores owned by the instance as a standby replica
StandbyTask - Class in org.apache.kafka.streams.processor.internals
A StandbyTask
standbyTasks() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
standbyTasks() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
standbyTasks() - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
standbyTasks() - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
standbyTasks() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
standbyTopicPartitions() - Method in class org.apache.kafka.streams.state.StreamsMetadata
(Source) Topic partitions for which the instance acts as standby.
start() - Method in class org.apache.kafka.streams.KafkaStreams
Start the KafkaStreams instance by starting all its threads.
start() - Method in class org.apache.kafka.streams.kstream.Window
Return the start timestamp of this window.
start() - Method in class org.apache.kafka.streams.processor.internals.GlobalStreamThread
 
start(int) - Method in class org.apache.kafka.streams.state.internals.Murmur3.IncrementalHash32
 
STARTING - org.apache.kafka.streams.processor.internals.StreamThread.State
 
startMs - Variable in class org.apache.kafka.streams.kstream.UnlimitedWindows
The start timestamp of the window.
startMs - Variable in class org.apache.kafka.streams.kstream.Window
 
startOn(long) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
Deprecated.
startOn(Instant) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
Return a new unlimited window for the specified start timestamp.
startTime() - Method in class org.apache.kafka.streams.kstream.Window
Return the start time of this window.
state - Variable in class org.apache.kafka.streams.KafkaStreams
 
state() - Method in class org.apache.kafka.streams.KafkaStreams
Return the current KafkaStreams.State of this KafkaStreams instance.
state() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
state() - Method in class org.apache.kafka.streams.processor.internals.GlobalStreamThread
 
state() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
 
state() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
STATE_CLEANUP_DELAY_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
state.cleanup.delay
STATE_DIR_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
state.dir
STATE_STORE_LEVEL_GROUP - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
stateChangelogTopics - Variable in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopicsInfo
 
stateDir() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
stateDir() - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
stateDir() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the state directory for the partition.
stateDirectory - Variable in class org.apache.kafka.streams.processor.internals.AbstractTask
 
StateDirectory - Class in org.apache.kafka.streams.processor.internals
Manages the directories where the state of Tasks owned by a StreamThread are stored.
StateDirectory(StreamsConfig, Time, boolean) - Constructor for class org.apache.kafka.streams.processor.internals.StateDirectory
Ensures that the state base directory as well as the application's sub-directory are created.
statefulActiveTasks() - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
StatefulProcessorNode<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
 
StatefulProcessorNode(String, ProcessorParameters<K, V>, String[]) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.StatefulProcessorNode
Create a node representing a stateful processor, where the named stores have already been registered.
StatefulProcessorNode(String, ProcessorParameters<K, V>, StoreBuilder<?>) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.StatefulProcessorNode
Create a node representing a stateful processor, where the store needs to be built and registered as part of building this node.
StatefulProcessorNode(ProcessorParameters<K, V>, Set<StoreBuilder<?>>, Set<KTableValueGetterSupplier<?, ?>>) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.StatefulProcessorNode
Create a node representing a stateful processor, where the named stores have already been registered.
statelessActiveTasks() - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
stateManager() - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
stateMgr - Variable in class org.apache.kafka.streams.processor.internals.AbstractTask
 
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.
StateRestoreCallbackAdapter - Class in org.apache.kafka.streams.processor.internals
 
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.
StateStoreMetrics - Class in org.apache.kafka.streams.state.internals.metrics
 
stateStoreNames() - Method in class org.apache.kafka.streams.state.StreamsMetadata
State stores owned by the instance as an active replica
stateStoreNameToSourceTopics() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
StateStoreNode<S extends StateStore> - Class in org.apache.kafka.streams.kstream.internals.graph
 
StateStoreNode(StoreBuilder<S>) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.StateStoreNode
 
StateStoreProvider - Interface in org.apache.kafka.streams.state.internals
Provides access to StateStores that have been created as part of the ProcessorTopology.
stateStores - Variable in class org.apache.kafka.streams.processor.internals.ProcessorNode
 
stateStores() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
stateStores() - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
StaticTopicNameExtractor<K,​V> - Class in org.apache.kafka.streams.processor.internals
Static topic name extractor
StaticTopicNameExtractor(String) - Constructor for class org.apache.kafka.streams.processor.internals.StaticTopicNameExtractor
 
statistics() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
statsDumpPeriodSec() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
StickyTaskAssignor - Class in org.apache.kafka.streams.processor.internals.assignment
 
StickyTaskAssignor() - Constructor for class org.apache.kafka.streams.processor.internals.assignment.StickyTaskAssignor
 
stillRunning() - Method in class org.apache.kafka.streams.processor.internals.GlobalStreamThread
 
store(String, QueryableStoreType<T>) - Method in class org.apache.kafka.streams.KafkaStreams
Deprecated.
since 2.5 release; use KafkaStreams.store(StoreQueryParameters) instead
store(StoreQueryParameters<T>) - Method in class org.apache.kafka.streams.KafkaStreams
Get a facade wrapping the local StateStore instances with the provided StoreQueryParameters.
STORE_ID_TAG - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
storeBuilder - Variable in class org.apache.kafka.streams.kstream.internals.graph.StateStoreNode
 
StoreBuilder<T extends StateStore> - Interface in org.apache.kafka.streams.state
Build a StateStore wrapped with optional caching and logging.
StoreChangelogReader - Class in org.apache.kafka.streams.processor.internals
ChangelogReader is created and maintained by the stream thread and used for both updating standby tasks and restoring active tasks.
StoreChangelogReader(Time, StreamsConfig, LogContext, Admin, Consumer<byte[], byte[]>, StateRestoreListener) - Constructor for class org.apache.kafka.streams.processor.internals.StoreChangelogReader
 
storeChangelogTopic(String, String, String) - Static method in class org.apache.kafka.streams.processor.internals.ProcessorStateManager
 
storeLevelSensor(String, String, String, String, Sensor.RecordingLevel, Sensor...) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
storeLevelTagMap(String, String, String, String) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
storeName - Variable in class org.apache.kafka.streams.kstream.Materialized
 
storeName - Variable in class org.apache.kafka.streams.kstream.StreamJoined
 
storeName() - Method in class org.apache.kafka.streams.kstream.internals.MaterializedInternal
 
storeName() - Method in class org.apache.kafka.streams.kstream.internals.StreamJoinedInternal
 
storeName() - Method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics.RocksDBMetricContext
 
storeName() - Method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetricsRecorder
 
storeName() - Method in class org.apache.kafka.streams.StoreQueryParameters
Get the name of the state store that should be queried.
storeNames() - Method in class org.apache.kafka.streams.kstream.internals.KTableKTableAbstractJoinValueGetterSupplier
 
storeNames() - Method in class org.apache.kafka.streams.kstream.internals.KTableMaterializedValueGetterSupplier
 
storeNames() - Method in class org.apache.kafka.streams.kstream.internals.KTableSourceValueGetterSupplier
 
storeNames() - Method in interface org.apache.kafka.streams.kstream.internals.KTableValueGetterSupplier
 
StoreQueryParameters<T> - Class in org.apache.kafka.streams
StoreQueryParameters allows you to pass a variety of parameters when fetching a store for interactive query.
stores() - Method in class org.apache.kafka.streams.kstream.internals.KStreamFlatTransform
 
stores() - Method in class org.apache.kafka.streams.kstream.internals.KStreamFlatTransformValues
 
stores() - Method in class org.apache.kafka.streams.kstream.internals.KStreamTransformValues
 
stores() - Method in class org.apache.kafka.streams.kstream.internals.TransformerSupplierAdapter
 
stores() - Method in interface org.apache.kafka.streams.processor.ConnectedStoreProvider
 
stores() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Processor
 
stores() - Method in interface org.apache.kafka.streams.TopologyDescription.Processor
The names of all connected stores.
stores(String, QueryableStoreType<T>) - Method in class org.apache.kafka.streams.state.internals.GlobalStateStoreProvider
 
stores(String, QueryableStoreType<T>) - Method in interface org.apache.kafka.streams.state.internals.StateStoreProvider
Find instances of StateStore that are accepted by QueryableStoreType.accepts(org.apache.kafka.streams.processor.StateStore) and have the provided storeName.
stores(String, QueryableStoreType<T>) - Method in class org.apache.kafka.streams.state.internals.WrappingStoreProvider
 
stores(StoreQueryParameters) - Method in class org.apache.kafka.streams.state.internals.StreamThreadStateStoreProvider
 
Stores - Class in org.apache.kafka.streams.state
Factory for creating state stores in Kafka Streams.
Stores() - Constructor for class org.apache.kafka.streams.state.Stores
 
storeSupplier - Variable in class org.apache.kafka.streams.kstream.Materialized
 
storeSupplier() - Method in class org.apache.kafka.streams.kstream.internals.MaterializedInternal
 
StoreSupplier<T extends StateStore> - Interface in org.apache.kafka.streams.state
A state store supplier which can create one or more StateStore instances.
storeToChangelogTopic() - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
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(Collection<String>, ConsumedInternal<K, V>) - Method in class org.apache.kafka.streams.kstream.internals.InternalStreamsBuilder
 
stream(Pattern) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KStream from the specified topic pattern.
stream(Pattern, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KStream from the specified topic pattern.
stream(Pattern, ConsumedInternal<K, V>) - Method in class org.apache.kafka.streams.kstream.internals.InternalStreamsBuilder
 
STREAM_TIME - org.apache.kafka.streams.processor.PunctuationType
 
StreamJoined<K,​V1,​V2> - Class in org.apache.kafka.streams.kstream
Class used to configure the name of the join processor, the repartition topic name, state stores or state store names in Stream-Stream join.
StreamJoined(StreamJoined<K, V1, V2>) - Constructor for class org.apache.kafka.streams.kstream.StreamJoined
 
StreamJoinedInternal<K,​V1,​V2> - Class in org.apache.kafka.streams.kstream.internals
 
StreamJoinedInternal(StreamJoined<K, V1, V2>) - Constructor for class org.apache.kafka.streams.kstream.internals.StreamJoinedInternal
 
streamPartitioner() - Method in class org.apache.kafka.streams.kstream.internals.ProducedInternal
 
streamPartitioner() - Method in class org.apache.kafka.streams.kstream.internals.RepartitionedInternal
 
streamPartitioner(StreamPartitioner<? super K, ? super V>) - Static method in class org.apache.kafka.streams.kstream.Produced
Create a Produced instance with provided partitioner.
streamPartitioner(StreamPartitioner<K, V>) - Static method in class org.apache.kafka.streams.kstream.Repartitioned
Create a Repartitioned instance with provided partitioner.
StreamPartitioner<K,​V> - Interface in org.apache.kafka.streams.processor
Determine how records are distributed among the partitions in a Kafka topic.
STREAMS_ADMIN_CLIENT - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
 
STREAMS_DEFAULT_STREAM_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
streams.default.stream}
STREAMS_INTERNAL_STREAM_COMMON_FOLDER - Static variable in class org.apache.kafka.streams.StreamsConfig
MapR specific constants.
STREAMS_METADATA_STATE_FOR_PARTITION_ASSIGNOR - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
 
StreamsAssignmentProtocolVersions - Class in org.apache.kafka.streams.processor.internals.assignment
 
StreamsBuilder - Class in org.apache.kafka.streams
StreamsBuilder provide the high-level Kafka Streams DSL to specify a Kafka Streams topology.
StreamsBuilder() - Constructor for class org.apache.kafka.streams.StreamsBuilder
 
StreamsConfig - Class in org.apache.kafka.streams
Configuration for a KafkaStreams instance.
StreamsConfig(Map<?, ?>) - Constructor for class org.apache.kafka.streams.StreamsConfig
Create a new StreamsConfig using the given properties.
StreamsConfig(Map<?, ?>, boolean) - Constructor for class org.apache.kafka.streams.StreamsConfig
 
StreamsConfig.InternalConfig - Class in org.apache.kafka.streams
 
StreamsException - Exception in org.apache.kafka.streams.errors
StreamsException is the top-level exception type generated by Kafka Streams.
StreamsException(String) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
 
StreamsException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
 
StreamsException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.StreamsException
 
streamsGraphNode - Variable in class org.apache.kafka.streams.kstream.internals.AbstractStream
 
StreamsGraphNode - Class in org.apache.kafka.streams.kstream.internals.graph
 
StreamsGraphNode(String) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
StreamSinkNode<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
 
StreamSinkNode(String, TopicNameExtractor<K, V>, ProducedInternal<K, V>) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.StreamSinkNode
 
StreamsMetadata - Class in org.apache.kafka.streams.state
Represents the state of an instance (process) in a KafkaStreams application.
StreamsMetadata(HostInfo, Set<String>, Set<TopicPartition>, Set<String>, Set<TopicPartition>) - Constructor for class org.apache.kafka.streams.state.StreamsMetadata
 
streamsMetadataState() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
StreamsMetadataState - Class in org.apache.kafka.streams.processor.internals
Provides access to the StreamsMetadata in a KafkaStreams application.
StreamsMetadataState(InternalTopologyBuilder, HostInfo) - Constructor for class org.apache.kafka.streams.processor.internals.StreamsMetadataState
 
StreamsMetrics - Interface in org.apache.kafka.streams
The Kafka Streams metrics interface for adding metric sensors and collecting metric values.
StreamsMetricsImpl - Class in org.apache.kafka.streams.processor.internals.metrics
 
StreamsMetricsImpl(Metrics, String, String) - Constructor for class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
StreamsMetricsImpl.Version - Enum in org.apache.kafka.streams.processor.internals.metrics
 
StreamSourceNode<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
 
StreamSourceNode(String, Collection<String>, ConsumedInternal<K, V>) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.StreamSourceNode
 
StreamSourceNode(String, Pattern, ConsumedInternal<K, V>) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.StreamSourceNode
 
StreamsPartitionAssignor - Class in org.apache.kafka.streams.processor.internals
 
StreamsPartitionAssignor() - Constructor for class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
StreamsProducer - Class in org.apache.kafka.streams.processor.internals
StreamsProducer manages the producers within a Kafka Streams application.
StreamsProducer(StreamsConfig, String, KafkaClientSupplier, TaskId, UUID, LogContext) - Constructor for class org.apache.kafka.streams.processor.internals.StreamsProducer
 
StreamsRebalanceListener - Class in org.apache.kafka.streams.processor.internals
 
StreamStreamJoinNode<K,​V1,​V2,​VR> - Class in org.apache.kafka.streams.kstream.internals.graph
Too much information to generalize, so Stream-Stream joins are represented by a specific node.
StreamStreamJoinNode.StreamStreamJoinNodeBuilder<K,​V1,​V2,​VR> - Class in org.apache.kafka.streams.kstream.internals.graph
 
streamStreamJoinNodeBuilder() - Static method in class org.apache.kafka.streams.kstream.internals.graph.StreamStreamJoinNode
 
StreamTableJoinNode<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
Represents a join between a KStream and a KTable or GlobalKTable
StreamTableJoinNode(String, ProcessorParameters<K, V>, String[], String) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.StreamTableJoinNode
 
StreamTask - Class in org.apache.kafka.streams.processor.internals
A StreamTask is associated with a PartitionGroup, and is assigned to a StreamThread for processing.
StreamTask(TaskId, Set<TopicPartition>, ProcessorTopology, Consumer<byte[], byte[]>, StreamsConfig, StreamsMetricsImpl, StateDirectory, ThreadCache, Time, ProcessorStateManager, RecordCollector, InternalProcessorContext) - Constructor for class org.apache.kafka.streams.processor.internals.StreamTask
 
StreamThread - Class in org.apache.kafka.streams.processor.internals
 
StreamThread(Time, StreamsConfig, Admin, Consumer<byte[], byte[]>, Consumer<byte[], byte[]>, ChangelogReader, String, TaskManager, StreamsMetricsImpl, InternalTopologyBuilder, String, LogContext, AtomicInteger, AtomicLong) - Constructor for class org.apache.kafka.streams.processor.internals.StreamThread
 
StreamThread.ProcessingMode - Enum in org.apache.kafka.streams.processor.internals
 
StreamThread.State - Enum in org.apache.kafka.streams.processor.internals
Stream thread states are the possible states that a stream thread can be in.
StreamThread.StateListener - Interface in org.apache.kafka.streams.processor.internals
Listen to state change events
StreamThreadStateStoreProvider - Class in org.apache.kafka.streams.state.internals
 
StreamThreadStateStoreProvider(StreamThread) - Constructor for class org.apache.kafka.streams.state.internals.StreamThreadStateStoreProvider
 
StreamToTableNode<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
Represents a KTable convert From KStream
StreamToTableNode(String, ProcessorParameters<K, V>, MaterializedInternal<K, V, ?>) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.StreamToTableNode
 
StrictBufferConfigImpl - Class in org.apache.kafka.streams.kstream.internals.suppress
 
StrictBufferConfigImpl() - Constructor for class org.apache.kafka.streams.kstream.internals.suppress.StrictBufferConfigImpl
 
StrictBufferConfigImpl(long, long, BufferFullStrategy) - Constructor for class org.apache.kafka.streams.kstream.internals.suppress.StrictBufferConfigImpl
 
StrictBufferConfigImpl(long, long, BufferFullStrategy, Map<String, String>) - Constructor for class org.apache.kafka.streams.kstream.internals.suppress.StrictBufferConfigImpl
 
SubscriptionInfo - Class in org.apache.kafka.streams.processor.internals.assignment
 
SubscriptionInfo(int, int, UUID, String, Map<TaskId, Long>, byte) - Constructor for class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
SubscriptionInfoData - Class in org.apache.kafka.streams.internals.generated
 
SubscriptionInfoData() - Constructor for class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
SubscriptionInfoData(Readable, short) - Constructor for class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
SubscriptionInfoData(Struct, short) - Constructor for class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
SubscriptionInfoData.PartitionToOffsetSum - Class in org.apache.kafka.streams.internals.generated
 
SubscriptionInfoData.TaskId - Class in org.apache.kafka.streams.internals.generated
 
SubscriptionInfoData.TaskOffsetSum - Class in org.apache.kafka.streams.internals.generated
 
SubscriptionJoinForeignProcessorSupplier<K,​KO,​VO> - Class in org.apache.kafka.streams.kstream.internals.foreignkeyjoin
Receives SubscriptionWrapper<K> events and processes them according to their Instruction.
SubscriptionJoinForeignProcessorSupplier(KTableValueGetterSupplier<KO, VO>) - Constructor for class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionJoinForeignProcessorSupplier
 
SubscriptionResolverJoinProcessorSupplier<K,​V,​VO,​VR> - Class in org.apache.kafka.streams.kstream.internals.foreignkeyjoin
Receives SubscriptionResponseWrapper<VO> events and filters out events which do not match the current hash of the primary key.
SubscriptionResolverJoinProcessorSupplier(KTableValueGetterSupplier<K, V>, Serializer<V>, Supplier<String>, ValueJoiner<V, VO, VR>, boolean) - Constructor for class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionResolverJoinProcessorSupplier
 
SubscriptionResponseWrapper<FV> - Class in org.apache.kafka.streams.kstream.internals.foreignkeyjoin
 
SubscriptionResponseWrapper(long[], FV) - Constructor for class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionResponseWrapper
 
SubscriptionResponseWrapper(long[], FV, byte) - Constructor for class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionResponseWrapper
 
SubscriptionResponseWrapperSerde<V> - Class in org.apache.kafka.streams.kstream.internals.foreignkeyjoin
 
SubscriptionResponseWrapperSerde(Serde<V>) - Constructor for class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionResponseWrapperSerde
 
SubscriptionStoreReceiveProcessorSupplier<K,​KO> - Class in org.apache.kafka.streams.kstream.internals.foreignkeyjoin
 
SubscriptionStoreReceiveProcessorSupplier(StoreBuilder<TimestampedKeyValueStore<Bytes, SubscriptionWrapper<K>>>, CombinedKeySchema<KO, K>) - Constructor for class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionStoreReceiveProcessorSupplier
 
subscriptionUserData(Set<String>) - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
SubscriptionWrapper<K> - Class in org.apache.kafka.streams.kstream.internals.foreignkeyjoin
 
SubscriptionWrapper(long[], SubscriptionWrapper.Instruction, K) - Constructor for class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionWrapper
 
SubscriptionWrapper(long[], SubscriptionWrapper.Instruction, K, byte) - Constructor for class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionWrapper
 
SubscriptionWrapper.Instruction - Enum in org.apache.kafka.streams.kstream.internals.foreignkeyjoin
 
SubscriptionWrapperSerde<K> - Class in org.apache.kafka.streams.kstream.internals.foreignkeyjoin
 
SubscriptionWrapperSerde(Supplier<String>, Serde<K>) - Constructor for class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionWrapperSerde
 
subtopologies() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopologyDescription
 
subtopologies() - Method in interface org.apache.kafka.streams.TopologyDescription
All sub-topologies of the represented topology.
Subtopology(int, Set<TopologyDescription.Node>) - Constructor for class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Subtopology
 
subTopologySourceNodes - Variable in class org.apache.kafka.streams.kstream.internals.AbstractStream
 
successors() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.AbstractNode
 
successors() - Method in interface org.apache.kafka.streams.TopologyDescription.Node
The successor of this node within a sub-topology.
supportedProtocols() - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
suppress(Suppressed<? super K>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
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.
SuppressedInternal<K> - Class in org.apache.kafka.streams.kstream.internals.suppress
 
SuppressedInternal(String, Duration, Suppressed.BufferConfig, TimeDefinitions.TimeDefinition<K>, boolean) - Constructor for class org.apache.kafka.streams.kstream.internals.suppress.SuppressedInternal
 
suppressionBufferCountSensor(String, String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.state.internals.metrics.StateStoreMetrics
 
suppressionBufferSizeSensor(String, String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.state.internals.metrics.StateStoreMetrics
 
suppressionEmitSensor(String, String, String, StreamsMetricsImpl) - Static method in class org.apache.kafka.streams.processor.internals.metrics.ProcessorNodeMetrics
 
suspend() - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
 
suspend() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
suspend() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
SUSPENDED - org.apache.kafka.streams.processor.internals.Task.State
 

T

table(String) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KTable for the specified topic.
table(String, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KTable for the specified topic.
table(String, Consumed<K, V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KTable for the specified topic.
table(String, ConsumedInternal<K, V>, MaterializedInternal<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.InternalStreamsBuilder
 
table(String, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KTable for the specified topic.
tableCacheNumshardbits() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
tableFactoryName() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
tableFormatConfig() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
TableProcessorNode<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
 
TableProcessorNode(String, ProcessorParameters<K, V>, StoreBuilder<TimestampedKeyValueStore<K, V>>) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.TableProcessorNode
 
TableProcessorNode(String, ProcessorParameters<K, V>, StoreBuilder<TimestampedKeyValueStore<K, V>>, String[]) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.TableProcessorNode
 
TableSourceNode<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
Used to represent either a KTable source or a GlobalKTable source.
TableSourceNode.TableSourceNodeBuilder<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
 
tableSourceNodeBuilder() - Static method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode
 
targetFileSizeBase() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
targetFileSizeMultiplier() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
Task - Interface in org.apache.kafka.streams.processor.internals
 
TASK_ID_TAG - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
TASK_LEVEL_GROUP - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
TASK_MANAGER_FOR_PARTITION_ASSIGNOR - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
 
Task.State - Enum in org.apache.kafka.streams.processor.internals
 
Task.TaskType - Enum in org.apache.kafka.streams.processor.internals
 
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
 
taskAssignor() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
TaskAssignor - Interface in org.apache.kafka.streams.processor.internals.assignment
 
TaskCorruptedException - Exception in org.apache.kafka.streams.errors
Indicates a specific task is corrupted and need to be re-initialized.
TaskCorruptedException(Map<TaskId, Collection<TopicPartition>>) - Constructor for exception org.apache.kafka.streams.errors.TaskCorruptedException
 
TaskCorruptedException(Map<TaskId, Collection<TopicPartition>>, InvalidOffsetException) - Constructor for exception org.apache.kafka.streams.errors.TaskCorruptedException
 
taskId() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
taskId() - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
taskId() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the task id.
taskId() - Method in class org.apache.kafka.streams.processor.TaskMetadata
 
taskId() - Method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetricsRecorder
 
TaskId - Class in org.apache.kafka.streams.processor
The task ID representation composed as topic group ID plus the assigned partition ID.
TaskId() - Constructor for class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
TaskId(int, int) - Constructor for class org.apache.kafka.streams.processor.TaskId
 
TaskId(Readable, short) - Constructor for class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
TaskId(Struct, short) - Constructor for class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
TaskIdFormatException - Exception in org.apache.kafka.streams.errors
Indicates a run time error incurred while trying parse the task id from the read string.
TaskIdFormatException(String) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
 
TaskIdFormatException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
 
TaskIdFormatException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
 
taskIDfromCacheName(String) - Static method in class org.apache.kafka.streams.state.internals.ThreadCache
Given a cache name of the form taskid-storename, return the task ID.
taskLevelSensor(String, String, String, Sensor.RecordingLevel, Sensor...) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
taskLevelTagMap(String, String) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
taskManager() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
taskManager() - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
TaskManager - Class in org.apache.kafka.streams.processor.internals
 
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
 
TaskMetrics - Class in org.apache.kafka.streams.processor.internals.metrics
 
TaskMigratedException - Exception in org.apache.kafka.streams.errors
Indicates that all tasks belongs to the thread have migrated to another thread.
TaskMigratedException(String) - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
 
TaskMigratedException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
 
taskName() - Method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics.RocksDBMetricContext
 
TaskOffsetSum() - Constructor for class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
TaskOffsetSum(Readable, short) - Constructor for class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
TaskOffsetSum(Struct, short) - Constructor for class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
taskOffsetSums() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
taskOffsetSums() - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
taskType() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
taskType() - Method in class org.apache.kafka.streams.processor.internals.GlobalStateManagerImpl
 
taskType() - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
 
taskType() - Method in class org.apache.kafka.streams.processor.internals.ProcessorStateManager
 
terminalNodes() - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
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.
thisStoreSupplier - Variable in class org.apache.kafka.streams.kstream.StreamJoined
 
thisStoreSupplier() - Method in class org.apache.kafka.streams.kstream.internals.StreamJoinedInternal
 
THREAD_ID_TAG - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
THREAD_ID_TAG_0100_TO_24 - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
THREAD_LEVEL_GROUP - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
THREAD_LEVEL_GROUP_0100_TO_24 - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
ThreadCache - Class in org.apache.kafka.streams.state.internals
An in-memory LRU cache store similar to MemoryLRUCache but byte-based, not record based
ThreadCache(LogContext, long, StreamsMetricsImpl) - Constructor for class org.apache.kafka.streams.state.internals.ThreadCache
 
ThreadCache.DirtyEntryFlushListener - Interface in org.apache.kafka.streams.state.internals
 
threadId() - Method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics.RocksDBMetricContext
 
threadLevelSensor(String, String, Sensor.RecordingLevel, Sensor...) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
threadLevelTagMap(String) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
threadMetadata() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
Return information about the current StreamThread.
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
 
ThreadMetrics - Class in org.apache.kafka.streams.processor.internals.metrics
 
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
 
ThreadStateTransitionValidator - Interface in org.apache.kafka.streams.processor.internals
Basic interface for keeping track of the state of a thread.
through(String) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
Deprecated.
through(String) - Method in interface org.apache.kafka.streams.kstream.KStream
Deprecated.
since 2.6; used KStream.repartition() instead
through(String, Produced<K, V>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
Deprecated.
through(String, Produced<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Deprecated.
since 2.6; use KStream.repartition(Repartitioned) instead
time - Variable in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
time() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
TIME - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
 
TimeOrderedKeyValueBuffer<K,​V> - Interface in org.apache.kafka.streams.state.internals
 
TimeOrderedKeyValueBuffer.Eviction<K,​V> - Class in org.apache.kafka.streams.state.internals
 
timestamp - Variable in class org.apache.kafka.streams.processor.internals.Stamped
 
timestamp - Variable in class org.apache.kafka.streams.processor.To
 
timestamp() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
timestamp() - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
timestamp() - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
timestamp() - Method in class org.apache.kafka.streams.processor.internals.ProcessorRecordContext
 
timestamp() - Method in class org.apache.kafka.streams.processor.internals.ToInternal
 
timestamp() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the current timestamp.
timestamp() - Method in interface org.apache.kafka.streams.processor.RecordContext
 
timestamp() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
 
TimestampedBytesStore - Interface in org.apache.kafka.streams.state
 
timestampedKeyValueStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
TimestampedKeyValueStore<K,​V> - Interface in org.apache.kafka.streams.state
A key-(value/timestamp) store that supports put/get/delete and range queries.
timestampedKeyValueStoreBuilder(KeyValueBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
Creates a StoreBuilder that can be used to build a TimestampedKeyValueStore.
TimestampedKeyValueStoreBuilder<K,​V> - Class in org.apache.kafka.streams.state.internals
 
TimestampedKeyValueStoreBuilder(KeyValueBytesStoreSupplier, Serde<K>, Serde<V>, Time) - Constructor for class org.apache.kafka.streams.state.internals.TimestampedKeyValueStoreBuilder
 
TimestampedKeyValueStoreMaterializer<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
TimestampedKeyValueStoreMaterializer(MaterializedInternal<K, V, KeyValueStore<Bytes, byte[]>>) - Constructor for class org.apache.kafka.streams.kstream.internals.TimestampedKeyValueStoreMaterializer
 
timestampedWindowStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
TimestampedWindowStore<K,​V> - Interface in org.apache.kafka.streams.state
Interface for storing the aggregated values of fixed-size time windows.
timestampedWindowStoreBuilder(WindowBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
Creates a StoreBuilder that can be used to build a TimestampedWindowStore.
TimestampedWindowStoreBuilder<K,​V> - Class in org.apache.kafka.streams.state.internals
 
TimestampedWindowStoreBuilder(WindowBytesStoreSupplier, Serde<K>, Serde<V>, Time) - Constructor for class org.apache.kafka.streams.state.internals.TimestampedWindowStoreBuilder
 
timestampExtractor - Variable in class org.apache.kafka.streams.kstream.Consumed
 
timestampExtractor() - Method in class org.apache.kafka.streams.kstream.internals.ConsumedInternal
 
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.
TimeWindow - Class in org.apache.kafka.streams.kstream.internals
A TimeWindow covers a half-open time interval with its start timestamp as an inclusive boundary and its end timestamp as exclusive boundary.
TimeWindow(long, long) - Constructor for class org.apache.kafka.streams.kstream.internals.TimeWindow
Create a new window for the given start time (inclusive) and end time (exclusive).
TimeWindowedCogroupedKStream<K,​V> - Interface in org.apache.kafka.streams.kstream
TimeWindowedCogroupKStream is an abstraction of a windowed record stream of KeyValue pairs.
TimeWindowedCogroupedKStreamImpl<K,​V,​W extends Window> - Class in org.apache.kafka.streams.kstream.internals
 
TimeWindowedDeserializer<T> - Class in org.apache.kafka.streams.kstream
The inner serde class can be specified by setting the property StreamsConfig.DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS or StreamsConfig.DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS if the no-arg constructor is called and hence it is not passed during initialization.
TimeWindowedDeserializer() - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
 
TimeWindowedDeserializer(Deserializer<T>) - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
 
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.
TimeWindowedKStreamImpl<K,​V,​W extends Window> - Class in org.apache.kafka.streams.kstream.internals
 
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
The inner serde class can be specified by setting the property StreamsConfig.DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS or StreamsConfig.DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS if the no-arg constructor is called and hence it is not passed during initialization.
TimeWindowedSerializer() - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedSerializer
 
TimeWindowedSerializer(Serializer<T>) - Constructor for class org.apache.kafka.streams.kstream.TimeWindowedSerializer
 
TimeWindows - Class in org.apache.kafka.streams.kstream
The fixed-size time-based window specifications used for aggregations.
to(String) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
to(TopicNameExtractor<K, V>, Produced<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Dynamically materialize this stream to topics using the provided Produced instance.
To - Class in org.apache.kafka.streams.processor
This class is used to provide the optional parameters when sending output records to downstream processor using ProcessorContext.forward(Object, Object, To).
To(To) - Constructor for class org.apache.kafka.streams.processor.To
 
toBinary(Bytes, long, long) - Static method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
toBinary(Windowed<K>, Serializer<K>, String) - Static method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
toBinary(Windowed<K>, Serializer<K>, String) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
toBinary(Windowed<Bytes>) - Static method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
toFile(String) - Static method in class org.apache.kafka.streams.kstream.Printed
Print the records of a KStream to a file.
ToInternal - Class in org.apache.kafka.streams.processor.internals
 
ToInternal() - Constructor for class org.apache.kafka.streams.processor.internals.ToInternal
 
topic() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
topic() - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
topic() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Sink
 
topic() - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
topic() - Method in class org.apache.kafka.streams.processor.internals.ProcessorRecordContext
 
topic() - Method in class org.apache.kafka.streams.processor.internals.StampedRecord
 
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_PARTITION_COMPARATOR - Static variable in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
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.
topicConfig - Variable in class org.apache.kafka.streams.kstream.Materialized
 
topicGroupId - Variable in class org.apache.kafka.streams.processor.TaskId
The ID of the topic group.
topicGroupId() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
topicGroupId() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
topicGroups() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
Returns the map of topic groups keyed by the group id.
topicName - Variable in class org.apache.kafka.streams.processor.internals.StaticTopicNameExtractor
 
topicNameExtractor() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Sink
 
topicNameExtractor() - Method in interface org.apache.kafka.streams.TopologyDescription.Sink
The TopicNameExtractor class that this sink node uses to dynamically extract the topic name to write to.
TopicNameExtractor<K,​V> - Interface in org.apache.kafka.streams.processor
An interface that allows to dynamically determine the name of the Kafka topic to send at the sink node of the topology.
topicNames() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamSourceNode
 
topicPartitions() - Method in class org.apache.kafka.streams.processor.TaskMetadata
 
topicPartitions() - Method in class org.apache.kafka.streams.state.StreamsMetadata
Topic partitions consumed by the instance as an active replica
topicPattern() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamSourceNode
 
topicPattern() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Source
 
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.streams.processor.internals.InternalTopologyBuilder.Source
Deprecated.
topics() - Method in interface org.apache.kafka.streams.TopologyDescription.Source
topicSet() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Source
 
topicSet() - Method in interface org.apache.kafka.streams.TopologyDescription.Source
The topic names this source node is reading from.
topology - Variable in class org.apache.kafka.streams.processor.internals.AbstractTask
 
Topology - Class in org.apache.kafka.streams
A logical representation of a ProcessorTopology.
Topology() - Constructor for class org.apache.kafka.streams.Topology
 
TOPOLOGY_OPTIMIZATION - Static variable in class org.apache.kafka.streams.StreamsConfig
topology.optimization
Topology.AutoOffsetReset - Enum in org.apache.kafka.streams
Sets the auto.offset.reset configuration when adding a source processor or when creating KStream or KTable via StreamsBuilder.
TopologyDescription - Interface in org.apache.kafka.streams
A meta representation of a topology.
TopologyDescription() - Constructor for class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopologyDescription
 
TopologyDescription.GlobalStore - Interface in org.apache.kafka.streams
Represents a global store.
TopologyDescription.Node - Interface in org.apache.kafka.streams
A node of a topology.
TopologyDescription.Processor - Interface in org.apache.kafka.streams
A processor node of a topology.
TopologyDescription.Sink - Interface in org.apache.kafka.streams
A sink node of a topology.
TopologyDescription.Source - Interface in org.apache.kafka.streams
A source node of a topology.
TopologyDescription.Subtopology - Interface in org.apache.kafka.streams
A connected sub-graph of a Topology.
TopologyException - Exception in org.apache.kafka.streams.errors
Indicates a pre run time error occurred while parsing the logical topology to construct the physical processor topology.
TopologyException(String) - Constructor for exception org.apache.kafka.streams.errors.TopologyException
 
TopologyException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TopologyException
 
TopologyException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TopologyException
 
toStoreKeyBinary(K, long, int, StateSerdes<K, ?>) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
toStoreKeyBinary(Bytes, long, int) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
toStoreKeyBinary(Windowed<K>, int, StateSerdes<K, ?>) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
toStoreKeyBinary(Windowed<Bytes>, int) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
toStream() - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
toStream() - Method in interface org.apache.kafka.streams.kstream.KTable
Convert this changelog stream to a KStream.
toStream(KeyValueMapper<? super K, ? super V, ? extends K1>) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
toStream(KeyValueMapper<? super K, ? super V, ? extends K1>, Named) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
toStream(KeyValueMapper<? super K, ? super V, ? extends KR>) - Method in interface org.apache.kafka.streams.kstream.KTable
Convert this changelog stream to a KStream using the given KeyValueMapper to select the new key.
toStream(KeyValueMapper<? super K, ? super V, ? extends KR>, Named) - Method in interface org.apache.kafka.streams.kstream.KTable
Convert this changelog stream to a KStream using the given KeyValueMapper to select the new key.
toStream(Named) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
toStream(Named) - Method in interface org.apache.kafka.streams.kstream.KTable
Convert this changelog stream to a KStream.
toString() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
toString() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
toString() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
toString() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
toString() - Method in class org.apache.kafka.streams.KeyQueryMetadata
 
toString() - Method in class org.apache.kafka.streams.KeyValue
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.Change
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.CombinedKey
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionResponseWrapper
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.foreignkeyjoin.SubscriptionWrapper
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.GlobalStoreNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.GroupedTableOperationRepartitionNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.OptimizableRepartitionNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.ProcessorGraphNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.ProcessorParameters
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.StatefulProcessorNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.StateStoreNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamSinkNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamSourceNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamStreamJoinNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamTableJoinNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamToTableNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.TableProcessorNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.UnoptimizableRepartitionNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.suppress.EagerBufferConfigImpl
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.suppress.FinalResultsSuppressionBuilder
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.suppress.StrictBufferConfigImpl
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.suppress.SuppressedInternal
 
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.LagInfo
 
toString() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
toString() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration.AssignmentConfigs
 
toString() - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
toString() - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
toString() - Method in class org.apache.kafka.streams.processor.internals.InternalTopicConfig
 
toString() - Method in class org.apache.kafka.streams.processor.internals.InternalTopicProperties
 
toString() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.GlobalStore
 
toString() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Processor
 
toString() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Sink
 
toString() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Source
 
toString() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Subtopology
 
toString() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopicsInfo
 
toString() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopologyDescription
 
toString() - Method in class org.apache.kafka.streams.processor.internals.ProcessorNode
 
toString() - Method in class org.apache.kafka.streams.processor.internals.ProcessorRecordContext
 
toString() - Method in class org.apache.kafka.streams.processor.internals.ProcessorStateManager.StateStoreMetadata
 
toString() - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
Produces a string representation containing useful information this topology starting with the given indent.
toString() - Method in class org.apache.kafka.streams.processor.internals.RepartitionTopicConfig
 
toString() - Method in class org.apache.kafka.streams.processor.internals.SinkNode
 
toString() - Method in class org.apache.kafka.streams.processor.internals.SourceNode
 
toString() - Method in class org.apache.kafka.streams.processor.internals.StampedRecord
 
toString() - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
Produces a string representation containing useful information about a Task.
toString() - Method in class org.apache.kafka.streams.processor.internals.StaticTopicNameExtractor
 
toString() - Method in class org.apache.kafka.streams.processor.internals.StoreChangelogReader
 
toString() - Method in class org.apache.kafka.streams.processor.internals.StreamsMetadataState
 
toString() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
Produces a string representation containing useful information about a Task.
toString() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
Produces a string representation containing useful information about a StreamThread.
toString() - Method in class org.apache.kafka.streams.processor.internals.TaskManager
Produces a string representation containing useful information about the TaskManager.
toString() - Method in class org.apache.kafka.streams.processor.internals.UnwindowedChangelogTopicConfig
 
toString() - Method in class org.apache.kafka.streams.processor.internals.WindowedChangelogTopicConfig
 
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.internals.BufferKey
 
toString() - Method in class org.apache.kafka.streams.state.internals.BufferValue
 
toString() - Method in class org.apache.kafka.streams.state.internals.ContextualRecord
 
toString() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
toString() - Method in class org.apache.kafka.streams.state.internals.InMemoryWindowBytesStoreSupplier
 
toString() - Method in class org.apache.kafka.streams.state.internals.Maybe
 
toString() - Method in class org.apache.kafka.streams.state.internals.OffsetCheckpoint
 
toString() - Method in class org.apache.kafka.streams.state.internals.TimeOrderedKeyValueBuffer.Eviction
 
toString() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
toString() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
 
toString() - Method in class org.apache.kafka.streams.StoreQueryParameters
 
toString(String) - Method in class org.apache.kafka.streams.processor.internals.ProcessorNode
 
toString(String) - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
Produces a string representation containing useful information this topology.
toString(String) - Method in class org.apache.kafka.streams.processor.internals.SinkNode
 
toString(String) - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
Produces a string representation containing useful information about a Task starting with the given indent.
toString(String) - Method in class org.apache.kafka.streams.processor.internals.StreamsMetadataState
 
toString(String) - Method in class org.apache.kafka.streams.processor.internals.StreamTask
Produces a string representation containing useful information about a Task starting with the given indent.
toString(String) - Method in class org.apache.kafka.streams.processor.internals.StreamThread
Produces a string representation containing useful information about a StreamThread, starting with the given indent.
toString(String) - Method in class org.apache.kafka.streams.processor.internals.TaskManager
 
toStruct(short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
toStruct(short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
toStruct(short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
toStruct(short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
toSysOut() - Static method in class org.apache.kafka.streams.kstream.Printed
Print the records of a KStream to system out.
toTable() - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
toTable() - Method in interface org.apache.kafka.streams.kstream.KStream
Convert this stream to a KTable.
toTable(Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
toTable(Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KStream
Convert this stream to a KTable.
toTable(Named) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
toTable(Named) - Method in interface org.apache.kafka.streams.kstream.KStream
Convert this stream to a KTable.
toTable(Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
toTable(Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface org.apache.kafka.streams.kstream.KStream
Convert this stream to a KTable.
TOTAL_DESCRIPTION - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
TOTAL_SUFFIX - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
transform(K, V) - Method in interface org.apache.kafka.streams.kstream.Transformer
Transform the record with the given key and value.
transform(K, V) - Method in interface org.apache.kafka.streams.kstream.ValueTransformerWithKey
Transform the given [key and ]value to a new value.
transform(TransformerSupplier<? super K, ? super V, KeyValue<K1, V1>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform each record of the input stream into zero or one record in the output stream (both key and value type can be altered arbitrarily).
transform(TransformerSupplier<? super K, ? super V, KeyValue<K1, V1>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform each record of the input stream into zero or one record in the output stream (both key and value type can be altered arbitrarily).
transform(TransformerSupplier<? super K, ? super V, KeyValue<KR, VR>>, String...) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
transform(TransformerSupplier<? super K, ? super V, KeyValue<KR, VR>>, Named, String...) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
transform(V) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
Transform the given value to a new value.
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.
TransformerSupplierAdapter<KIn,​VIn,​KOut,​VOut> - Class in org.apache.kafka.streams.kstream.internals
 
TransformerSupplierAdapter(TransformerSupplier<KIn, VIn, KeyValue<KOut, VOut>>) - Constructor for class org.apache.kafka.streams.kstream.internals.TransformerSupplierAdapter
 
transformValues(ValueTransformerSupplier<? super V, ? extends VR>, String...) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
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 class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, String...) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into a new value (with possibly a new type) of the output record.
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type), with default serializers, deserializers, and state store.
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>, String...) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type), with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>, Named, String...) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type), with the key serde, value serde, and the underlying materialized state storage configured in the Materialized instance.
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Named, String...) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Named, String...) - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
Transform the value of each input record into a new value (with possibly a new type) of the output record.
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Named, String...) - Method in interface org.apache.kafka.streams.kstream.KTable
Create a new KTable by transforming the value of each record in this KTable into a new value (with possibly a new type), with default serializers, deserializers, and state store.
transitionToActive(StreamTask, RecordCollector, ThreadCache) - Method in class org.apache.kafka.streams.processor.internals.GlobalProcessorContextImpl
 
transitionToActive(StreamTask, RecordCollector, ThreadCache) - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
Transition to active task and register a new task and cache to this processor context
transitionToActive(StreamTask, RecordCollector, ThreadCache) - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
transitionToStandby(ThreadCache) - Method in class org.apache.kafka.streams.processor.internals.GlobalProcessorContextImpl
 
transitionToStandby(ThreadCache) - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
Transition to standby task and register a dummy cache to this processor context
transitionToStandby(ThreadCache) - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
transitToUpdateStandby() - Method in interface org.apache.kafka.streams.processor.internals.ChangelogReader
Transit to update standby changelogs mode
transitToUpdateStandby() - Method in class org.apache.kafka.streams.processor.internals.StoreChangelogReader
 

U

unassignActive(TaskId) - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
unavailable() - Static method in class org.apache.kafka.streams.state.HostInfo
 
unbounded() - Static method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
Create a buffer unconstrained by size (either keys or bytes).
undefined() - Static method in class org.apache.kafka.streams.state.internals.Maybe
 
underlyingStoreNamefromCacheName(String) - Static method in class org.apache.kafka.streams.state.internals.ThreadCache
Given a cache name of the form taskid-storename, return the store name.
uninitialize() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
uninitialize() - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
Mark this context as being uninitialized
uniqueField() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
uniqueField() - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
UNKNOWN - Static variable in class org.apache.kafka.streams.processor.internals.assignment.StreamsAssignmentProtocolVersions
 
UNKNOWN - Static variable in class org.apache.kafka.streams.processor.internals.RecordQueue
 
UNKNOWN_HOST - Static variable in class org.apache.kafka.streams.processor.internals.StreamsMetadataState
 
UNKNOWN_OFFSET_SUM - Static variable in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
unknownTaggedFields() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
unknownTaggedFields() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
unknownTaggedFields() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
unknownTaggedFields() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
UnlimitedWindow - Class in org.apache.kafka.streams.kstream.internals
UnlimitedWindow is an "infinite" large window with a fixed (inclusive) start time.
UnlimitedWindow(long) - Constructor for class org.apache.kafka.streams.kstream.internals.UnlimitedWindow
Create a new window for the given start time (inclusive).
UnlimitedWindows - Class in org.apache.kafka.streams.kstream
The unlimited window specifications used for aggregations.
UnoptimizableRepartitionNode<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
Repartition node that is not subject of optimization algorithm
UnoptimizableRepartitionNode.UnoptimizableRepartitionNodeBuilder<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
 
unoptimizableRepartitionNodeBuilder() - Static method in class org.apache.kafka.streams.kstream.internals.graph.UnoptimizableRepartitionNode
 
UnoptimizableRepartitionNodeBuilder() - Constructor for class org.apache.kafka.streams.kstream.internals.graph.UnoptimizableRepartitionNode.UnoptimizableRepartitionNodeBuilder
 
unregister(Collection<TopicPartition>) - Method in interface org.apache.kafka.streams.processor.internals.ChangelogRegister
Unregisters and removes the passed in partitions from the set of changelogs
unregister(Collection<TopicPartition>) - Method in class org.apache.kafka.streams.processor.internals.StoreChangelogReader
 
until(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Deprecated.
since 2.1. Use JoinWindows.grace(Duration) instead.
until(long) - Method in class org.apache.kafka.streams.kstream.SessionWindows
Deprecated.
since 2.1. Use Materialized.retention or directly configure the retention in a store supplier and use Materialized.as(SessionBytesStoreSupplier).
until(long) - Method in class org.apache.kafka.streams.kstream.TimeWindows
Deprecated.
since 2.1. Use Materialized.retention or directly configure the retention in a store supplier and use Materialized.as(WindowBytesStoreSupplier).
until(long) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
Deprecated.
since 2.1.
until(long) - Method in class org.apache.kafka.streams.kstream.Windows
Deprecated.
since 2.1. Use Materialized.withRetention(Duration) or directly configure the retention in a store supplier and use Materialized.as(WindowBytesStoreSupplier).
untilTimeLimit(Duration, Suppressed.BufferConfig) - Static method in interface org.apache.kafka.streams.kstream.Suppressed
Configure the suppression to wait timeToWaitForMoreEvents amount of time after receiving a record before emitting it further downstream.
untilWindowCloses(Suppressed.StrictBufferConfig) - Static method in interface org.apache.kafka.streams.kstream.Suppressed
Configure the suppression to emit only the "final results" from the window.
UnwindowedChangelogTopicConfig - Class in org.apache.kafka.streams.processor.internals
UnwindowedChangelogTopicConfig captures the properties required for configuring the un-windowed store changelog topics.
update(Set<TopicPartition>, Map<String, List<String>>) - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
update(Set<TopicPartition>, Map<String, List<String>>) - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
update(Set<TopicPartition>, Map<String, List<String>>) - Method in interface org.apache.kafka.streams.processor.internals.Task
Updates input partitions and topology after rebalance
update(ConsumerRecord<byte[], byte[]>) - Method in class org.apache.kafka.streams.processor.internals.GlobalStateUpdateTask
 
update(To) - Method in class org.apache.kafka.streams.processor.internals.ToInternal
 
update(To) - Method in class org.apache.kafka.streams.processor.To
 
updateSourceTopics(Map<String, List<String>>) - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
UPGRADE_FROM_0100 - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "upgrade.from" for upgrading an application from version 0.10.0.x.
UPGRADE_FROM_0101 - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "upgrade.from" for upgrading an application from version 0.10.1.x.
UPGRADE_FROM_0102 - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "upgrade.from" for upgrading an application from version 0.10.2.x.
UPGRADE_FROM_0110 - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "upgrade.from" for upgrading an application from version 0.11.0.x.
UPGRADE_FROM_10 - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "upgrade.from" for upgrading an application from version 1.0.x.
UPGRADE_FROM_11 - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "upgrade.from" for upgrading an application from version 1.1.x.
UPGRADE_FROM_20 - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "upgrade.from" for upgrading an application from version 2.0.x.
UPGRADE_FROM_21 - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "upgrade.from" for upgrading an application from version 2.1.x.
UPGRADE_FROM_22 - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "upgrade.from" for upgrading an application from version 2.2.x.
UPGRADE_FROM_23 - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "upgrade.from" for upgrading an application from version 2.3.x.
UPGRADE_FROM_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
upgrade.from
upperRange(Bytes, long) - Method in interface org.apache.kafka.streams.state.internals.SegmentedBytesStore.KeySchema
Given a range of record keys and a time, construct a Segmented key that represents the upper range of keys to search when performing range queries.
upperRange(Bytes, long) - Method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
upperRange(Bytes, long) - Method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
upperRangeFixedSize(Bytes, long) - Method in interface org.apache.kafka.streams.state.internals.SegmentedBytesStore.KeySchema
Given a range of fixed size record keys and a time, construct a Segmented key that represents the upper range of keys to search when performing range queries.
upperRangeFixedSize(Bytes, long) - Method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
upperRangeFixedSize(Bytes, long) - Method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
useAdaptiveMutex() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
useCappedPrefixExtractor(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
useDirectIoForFlushAndCompaction() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
useDirectReads() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
usedSubscriptionMetadataVersion - Variable in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
useFixedLengthPrefixExtractor(int) - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
useFsync() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
UsePartitionTimeOnInvalidTimestamp - Class in org.apache.kafka.streams.processor
Retrieves embedded metadata timestamps from Kafka messages.
UsePartitionTimeOnInvalidTimestamp() - Constructor for class org.apache.kafka.streams.processor.UsePartitionTimeOnInvalidTimestamp
 
UsePreviousTimeOnInvalidTimestamp - Class in org.apache.kafka.streams.processor
Deprecated.
since 2.5. Use UsePartitionTimeOnInvalidTimestamp instead
UsePreviousTimeOnInvalidTimestamp() - Constructor for class org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestamp
Deprecated.
 
userEndPoint() - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
userEndPoint() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignorConfiguration
 
userEndPoint() - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
userEndPoint() - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 

V

validate(String) - Static method in class org.apache.kafka.streams.kstream.Named
 
validateCopartition() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
validateMillisecondDuration(Duration, String) - Static method in class org.apache.kafka.streams.internals.ApiUtils
Validates that milliseconds from duration can be retrieved.
validateMillisecondInstant(Instant, String) - Static method in class org.apache.kafka.streams.internals.ApiUtils
Validates that milliseconds from instant can be retrieved.
valSerde - Variable in class org.apache.kafka.streams.kstream.internals.AbstractStream
 
value - Variable in class org.apache.kafka.streams.KeyValue
The value of the key-value pair.
value - Variable in class org.apache.kafka.streams.processor.internals.Stamped
 
value - Variable in class org.apache.kafka.streams.state.internals.MeteredTimestampedKeyValueStore.RawAndDeserializedValue
 
value() - Method in class org.apache.kafka.streams.processor.internals.StampedRecord
 
value() - Method in class org.apache.kafka.streams.state.internals.ContextualRecord
 
value() - Method in class org.apache.kafka.streams.state.internals.TimeOrderedKeyValueBuffer.Eviction
 
value() - Method in class org.apache.kafka.streams.state.ValueAndTimestamp
 
ValueAndTimestamp<V> - Class in org.apache.kafka.streams.state
Combines a value from a KeyValue with a timestamp.
ValueAndTimestampSerde<V> - Class in org.apache.kafka.streams.state.internals
 
ValueAndTimestampSerde(Serde<V>) - Constructor for class org.apache.kafka.streams.state.internals.ValueAndTimestampSerde
 
ValueAndTimestampSerializer<V> - Class in org.apache.kafka.streams.state.internals
 
valueDeserializer() - Method in class org.apache.kafka.streams.kstream.internals.ConsumedInternal
 
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.
valueGetterSupplier() - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
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.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.kstream.internals.foreignkeyjoin.SubscriptionWrapper.Instruction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.kstream.internals.suppress.BufferFullStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.processor.internals.assignment.AssignorError
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.processor.internals.GlobalStreamThread.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl.Version
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.processor.internals.StreamThread.ProcessingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.processor.internals.StreamThread.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.processor.internals.Task.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.streams.processor.internals.Task.TaskType
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.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.kstream.internals.foreignkeyjoin.SubscriptionWrapper.Instruction
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.kstream.internals.suppress.BufferFullStrategy
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.internals.assignment.AssignorError
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.internals.GlobalStreamThread.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.internals.metrics.StreamsMetricsImpl.Version
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.internals.StreamThread.ProcessingMode
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.internals.StreamThread.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.internals.Task.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.internals.Task.TaskType
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.
valueSerde - Variable in class org.apache.kafka.streams.kstream.Consumed
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.Grouped
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.Joined
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.Materialized
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.Produced
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.Repartitioned
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.Serialized
Deprecated.
 
valueSerde - Variable in class org.apache.kafka.streams.kstream.StreamJoined
 
valueSerde() - Method in class org.apache.kafka.streams.kstream.internals.AbstractStream
 
valueSerde() - Method in class org.apache.kafka.streams.kstream.internals.ConsumedInternal
 
valueSerde() - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode
 
valueSerde() - Method in class org.apache.kafka.streams.kstream.internals.graph.OptimizableRepartitionNode
 
valueSerde() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamSourceNode
 
valueSerde() - Method in class org.apache.kafka.streams.kstream.internals.GroupedInternal
 
valueSerde() - Method in class org.apache.kafka.streams.kstream.internals.JoinedInternal
 
valueSerde() - Method in class org.apache.kafka.streams.kstream.internals.MaterializedInternal
 
valueSerde() - Method in class org.apache.kafka.streams.kstream.internals.ProducedInternal
 
valueSerde() - Method in class org.apache.kafka.streams.kstream.internals.RepartitionedInternal
 
valueSerde() - Method in class org.apache.kafka.streams.kstream.internals.SerializedInternal
Deprecated.
 
valueSerde() - Method in class org.apache.kafka.streams.kstream.internals.StreamJoinedInternal
 
valueSerde() - Method in class org.apache.kafka.streams.kstream.Joined
 
valueSerde() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
valueSerde() - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
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.
valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Grouped
Create a Grouped instance with the provided valueSerde.
valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Joined
Create an instance of Joined with a value Serde.
valueSerde(Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Produced
Create a Produced instance with provided valueSerde.
valueSerializer - Variable in class org.apache.kafka.streams.state.internals.ValueAndTimestampSerializer
 
valueSerializer() - Method in class org.apache.kafka.streams.state.StateSerdes
Return the value serializer.
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 class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
version() - Static method in class org.apache.kafka.streams.internals.metrics.ClientMetrics
 
version() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
version() - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
version() - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
view() - Method in interface org.apache.kafka.streams.kstream.internals.KStreamAggProcessorSupplier
 
view() - Method in class org.apache.kafka.streams.kstream.internals.KStreamAggregate
 
view() - Method in class org.apache.kafka.streams.kstream.internals.KStreamReduce
 
view() - Method in class org.apache.kafka.streams.kstream.internals.KStreamSessionWindowAggregate
 
view() - Method in class org.apache.kafka.streams.kstream.internals.KStreamWindowAggregate
 
view() - Method in class org.apache.kafka.streams.kstream.internals.KTableAggregate
 
view() - Method in class org.apache.kafka.streams.kstream.internals.KTableKTableJoinMerger
 
view() - Method in interface org.apache.kafka.streams.kstream.internals.KTableProcessorSupplier
 
view() - Method in class org.apache.kafka.streams.kstream.internals.KTableReduce
 
view() - Method in class org.apache.kafka.streams.kstream.internals.KTableRepartitionMap
 
view() - Method in class org.apache.kafka.streams.kstream.internals.suppress.KTableSuppressProcessorSupplier
 

W

walBytesPerSync() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
walDir() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
WALL_CLOCK_TIME - org.apache.kafka.streams.processor.PunctuationType
 
WallclockTimestampExtractor - Class in org.apache.kafka.streams.processor
Retrieves current wall clock timestamps as System.currentTimeMillis().
WallclockTimestampExtractor() - Constructor for class org.apache.kafka.streams.processor.WallclockTimestampExtractor
 
walRecoveryMode() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
walSizeLimitMB() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
walTtlSeconds() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
window() - Method in class org.apache.kafka.streams.kstream.Windowed
Return the window containing the values associated with this key.
Window - Class in org.apache.kafka.streams.kstream
A single window instance, defined by its start and end timestamp.
Window(long, long) - Constructor for class org.apache.kafka.streams.kstream.Window
Create a new window for the given start and end time.
WINDOW_STORE_CHANGE_LOG_ADDITIONAL_RETENTION_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
windowstore.changelog.additional.retention.ms
WindowBytesStoreSupplier - Interface in org.apache.kafka.streams.state
A store supplier that can be used to create one or more WindowStore<Byte, byte[]> instances of type <Byte, byte[]>.
Windowed<K> - Class in org.apache.kafka.streams.kstream
The result key type of a windowed stream aggregation.
Windowed(K, Window) - Constructor for class org.apache.kafka.streams.kstream.Windowed
 
windowedBy(SessionWindows) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
Create a new SessionWindowedCogroupedKStream instance that can be used to perform session windowed aggregations.
windowedBy(SessionWindows) - Method in class org.apache.kafka.streams.kstream.internals.CogroupedKStreamImpl
 
windowedBy(SessionWindows) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Create a new SessionWindowedKStream instance that can be used to perform session windowed aggregations.
windowedBy(Windows<W>) - Method in interface org.apache.kafka.streams.kstream.CogroupedKStream
Create a new TimeWindowedCogroupedKStream instance that can be used to perform windowed aggregations.
windowedBy(Windows<W>) - Method in class org.apache.kafka.streams.kstream.internals.CogroupedKStreamImpl
 
windowedBy(Windows<W>) - Method in interface org.apache.kafka.streams.kstream.KGroupedStream
Create a new TimeWindowedKStream instance that can be used to perform windowed aggregations.
WindowedChangelogTopicConfig - Class in org.apache.kafka.streams.processor.internals
WindowedChangelogTopicConfig captures the properties required for configuring the windowed store changelog topics.
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
 
WindowedSerializer<T> - Interface in org.apache.kafka.streams.kstream.internals
 
WindowedStreamPartitioner<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
WindowedStreamPartitioner(WindowedSerializer<K>) - Constructor for class org.apache.kafka.streams.kstream.internals.WindowedStreamPartitioner
 
WindowingDefaults - Class in org.apache.kafka.streams.kstream.internals
 
WindowKeySchema - Class in org.apache.kafka.streams.state.internals
 
WindowKeySchema() - Constructor for class org.apache.kafka.streams.state.internals.WindowKeySchema
 
windows() - Method in class org.apache.kafka.streams.kstream.internals.KStreamSessionWindowAggregate
 
windows() - Method in class org.apache.kafka.streams.kstream.internals.KStreamWindowAggregate
 
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 class org.apache.kafka.streams.state.internals.InMemoryWindowBytesStoreSupplier
 
windowSize() - Method in class org.apache.kafka.streams.state.internals.RocksDbWindowBytesStoreSupplier
 
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
Creates a StoreBuilder that can be used to build a WindowStore.
WindowStoreBuilder<K,​V> - Class in org.apache.kafka.streams.state.internals
 
WindowStoreBuilder(WindowBytesStoreSupplier, Serde<K>, Serde<V>, Time) - Constructor for class org.apache.kafka.streams.state.internals.WindowStoreBuilder
 
WindowStoreIterator<V> - Interface in org.apache.kafka.streams.state
Iterator interface of KeyValue with key typed Long used for WindowStore.fetch(Object, long, long) and WindowStore.fetch(Object, Instant, Instant) Users must call its close method explicitly upon completeness to release resources, or use try-with-resources statement (available since JDK7) for this Closeable class.
with(long) - Static method in class org.apache.kafka.streams.kstream.SessionWindows
Deprecated.
with(String) - Static method in class org.apache.kafka.streams.kstream.internals.NamedInternal
 
with(String, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Grouped
Create a Grouped instance with the provided name, keySerde, and valueSerde.
with(Duration) - Static method in class org.apache.kafka.streams.kstream.SessionWindows
Create a new window specification with the specified inactivity gap.
with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Consumed
Create an instance of Consumed with key and value Serdes.
with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Grouped
Create a Grouped instance with the provided keySerde and valueSerde.
with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Materialized
Materialize a StateStore with the provided key and value Serdes.
with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Produced
Create a Produced instance with provided keySerde and valueSerde.
with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Repartitioned
Create a Repartitioned instance with provided key serde and value serde.
with(Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.kstream.Serialized
Deprecated.
Construct a Serialized instance with the provided key and value Serdes.
with(Serde<K>, Serde<V>, Serde<VO>) - Static method in class org.apache.kafka.streams.kstream.Joined
Create an instance of Joined with key, value, and otherValue Serde instances.
with(Serde<K>, Serde<V>, Serde<VO>, String) - Static method in class org.apache.kafka.streams.kstream.Joined
Create an instance of Joined with key, value, and otherValue Serde instances.
with(Serde<K>, Serde<V>, StreamPartitioner<? super K, ? super V>) - Static method in class org.apache.kafka.streams.kstream.Produced
Create a Produced instance with provided keySerde, valueSerde, and partitioner.
with(Serde<K>, Serde<V>, TimestampExtractor, Topology.AutoOffsetReset) - Static method in class org.apache.kafka.streams.kstream.Consumed
Create an instance of Consumed with the supplied arguments.
with(Serde<K>, Serde<V1>, Serde<V2>) - Static method in class org.apache.kafka.streams.kstream.StreamJoined
Creates a StreamJoined instance with the provided serdes to configure the stores for the join.
with(TimestampExtractor) - Static method in class org.apache.kafka.streams.kstream.Consumed
Create an instance of Consumed with a TimestampExtractor.
with(WindowBytesStoreSupplier, WindowBytesStoreSupplier) - Static method in class org.apache.kafka.streams.kstream.StreamJoined
Creates a StreamJoined instance with the provided store suppliers.
with(Topology.AutoOffsetReset) - Static method in class org.apache.kafka.streams.kstream.Consumed
Create an instance of Consumed with a Topology.AutoOffsetReset.
withBuiltinTypes(String, Class<K>, Class<V>) - Static method in class org.apache.kafka.streams.state.StateSerdes
Create a new instance of StateSerdes for the given state name and key-/value-type classes.
withCachingDisabled() - Method in class org.apache.kafka.streams.kstream.Materialized
Disable caching for the materialized StateStore.
withCachingDisabled() - Method in class org.apache.kafka.streams.state.internals.AbstractStoreBuilder
 
withCachingDisabled() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer.Builder
As of 2.1, there's no way for users to directly interact with the buffer, so this method is implemented solely to be called by Streams (which it will do based on the cache.max.bytes.buffering config.
withCachingDisabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
Disable caching on the store.
withCachingEnabled() - Method in class org.apache.kafka.streams.kstream.Materialized
Enable caching for the materialized StateStore.
withCachingEnabled() - Method in class org.apache.kafka.streams.state.internals.AbstractStoreBuilder
 
withCachingEnabled() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer.Builder
As of 2.1, there's no way for users to directly interact with the buffer, so this method is implemented solely to be called by Streams (which it will do based on the cache.max.bytes.buffering config.
withCachingEnabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
Enable caching on the store.
withConsumedInternal(ConsumedInternal<K, V>) - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode.TableSourceNodeBuilder
 
withInternalTopicProperties(InternalTopicProperties) - Method in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
withJoined(Joined<K, V1, V2>) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamStreamJoinNode.StreamStreamJoinNodeBuilder
 
withJoinMergeProcessorParameters(ProcessorParameters<K, VR>) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamStreamJoinNode.StreamStreamJoinNodeBuilder
 
withJoinOtherProcessorParameters(ProcessorParameters<K, Change<V2>>) - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode.KTableKTableJoinNodeBuilder
 
withJoinOtherProcessorParameters(ProcessorParameters<K, V2>) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamStreamJoinNode.StreamStreamJoinNodeBuilder
 
withJoinOtherStoreNames(String[]) - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode.KTableKTableJoinNodeBuilder
 
withJoinThisProcessorParameters(ProcessorParameters<K, Change<V1>>) - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode.KTableKTableJoinNodeBuilder
 
withJoinThisProcessorParameters(ProcessorParameters<K, V1>) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamStreamJoinNode.StreamStreamJoinNodeBuilder
 
withJoinThisStoreNames(String[]) - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode.KTableKTableJoinNodeBuilder
 
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Consumed
Configure the instance of Consumed with a key Serde.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Grouped
Perform the grouping operation using the provided keySerde for serializing the key.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode.KTableKTableJoinNodeBuilder
 
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Joined
Set the key Serde to be used.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Materialized
Set the keySerde the materialize StateStore will use.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Produced
Produce records using the provided keySerde.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Repartitioned
Create a new instance of Repartitioned with the provided key serde.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Serialized
Deprecated.
Construct a Serialized instance with the provided key Serde.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
Configure with the provided Serde for the key
withKeyValueMapper(KeyValueMapper<? super K, ? super V, String>) - Method in class org.apache.kafka.streams.kstream.Printed
Print the records of a KStream with the provided KeyValueMapper The provided KeyValueMapper's mapped value type must be String.
withLabel(String) - Method in class org.apache.kafka.streams.kstream.Printed
Print the records of a KStream with the provided label.
withLoggingDisabled() - Method in class org.apache.kafka.streams.kstream.internals.suppress.EagerBufferConfigImpl
 
withLoggingDisabled() - Method in class org.apache.kafka.streams.kstream.internals.suppress.StrictBufferConfigImpl
 
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.kstream.Suppressed.BufferConfig
Disable the changelog for this suppression's internal buffer.
withLoggingDisabled() - Method in class org.apache.kafka.streams.state.internals.AbstractStoreBuilder
 
withLoggingDisabled() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer.Builder
 
withLoggingDisabled() - Method in interface org.apache.kafka.streams.state.StoreBuilder
Disable the changelog for store built by this StoreBuilder.
withLoggingEnabled(Map<String, String>) - Method in class org.apache.kafka.streams.kstream.internals.suppress.EagerBufferConfigImpl
 
withLoggingEnabled(Map<String, String>) - Method in class org.apache.kafka.streams.kstream.internals.suppress.StrictBufferConfigImpl
 
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.kstream.Suppressed.BufferConfig
Indicates that a changelog topic should be created containing the currently suppressed records.
withLoggingEnabled(Map<String, String>) - Method in class org.apache.kafka.streams.state.internals.AbstractStoreBuilder
 
withLoggingEnabled(Map<String, String>) - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer.Builder
 
withLoggingEnabled(Map<String, String>) - Method in interface org.apache.kafka.streams.state.StoreBuilder
Maintain a changelog for any changes made to the store.
withMaterializedInternal(MaterializedInternal<K, V, ?>) - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode.TableSourceNodeBuilder
 
withMaxBytes(long) - Method in class org.apache.kafka.streams.kstream.internals.suppress.EagerBufferConfigImpl
 
withMaxBytes(long) - Method in class org.apache.kafka.streams.kstream.internals.suppress.StrictBufferConfigImpl
 
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 class org.apache.kafka.streams.kstream.internals.suppress.EagerBufferConfigImpl
 
withMaxRecords(long) - Method in class org.apache.kafka.streams.kstream.internals.suppress.StrictBufferConfigImpl
 
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) - 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.internals.NamedInternal
 
withName(String) - Method in class org.apache.kafka.streams.kstream.internals.suppress.FinalResultsSuppressionBuilder
 
withName(String) - Method in class org.apache.kafka.streams.kstream.internals.suppress.SuppressedInternal
 
withName(String) - Method in class org.apache.kafka.streams.kstream.Joined
Set the base name used for all components of the join, this may include any repartition topics created to complete the join.
withName(String) - Method in class org.apache.kafka.streams.kstream.Named
 
withName(String) - Method in class org.apache.kafka.streams.kstream.Printed
Print the records of a KStream with provided processor name.
withName(String) - Method in class org.apache.kafka.streams.kstream.Produced
 
withName(String) - Method in class org.apache.kafka.streams.kstream.Repartitioned
Create a new instance of Repartitioned with the provided name used as part of repartition topic and processor name.
withName(String) - Method in class org.apache.kafka.streams.kstream.StreamJoined
Set the name to use for the join processor and the repartition topic(s) if required.
withName(String) - Method in interface org.apache.kafka.streams.kstream.Suppressed
Use the specified name for the suppression node in the topology.
withNoBound() - Method in class org.apache.kafka.streams.kstream.internals.suppress.BufferConfigInternal
 
withNoBound() - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
Set the buffer to be unconstrained by size (either keys or bytes).
withNodeName(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
withNodeName(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode.KTableKTableJoinNodeBuilder
 
withNodeName(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamStreamJoinNode.StreamStreamJoinNodeBuilder
 
withNodeName(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode.TableSourceNodeBuilder
 
withNumberOfPartitions(int) - Method in class org.apache.kafka.streams.kstream.Repartitioned
Create a new instance of Repartitioned with the provided number of partitions for repartition topic.
withOffsetResetPolicy(Topology.AutoOffsetReset) - Method in class org.apache.kafka.streams.kstream.Consumed
Configure the instance of Consumed with a Topology.AutoOffsetReset.
withOtherJoinSideNodeName(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode.KTableKTableJoinNodeBuilder
 
withOtherStoreSupplier(WindowBytesStoreSupplier) - Method in class org.apache.kafka.streams.kstream.StreamJoined
Configure with the provided WindowBytesStoreSupplier for the other store supplier.
withOtherValueSerde(Serde<V2>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
Configure with the provided Serde for the other value
withOtherValueSerde(Serde<VO>) - Method in class org.apache.kafka.streams.kstream.Joined
Set the otherValue Serde to be used.
withOtherWindowedStreamProcessorParameters(ProcessorParameters<K, V2>) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamStreamJoinNode.StreamStreamJoinNodeBuilder
 
withOtherWindowStoreBuilder(StoreBuilder<WindowStore<K, V2>>) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamStreamJoinNode.StreamStreamJoinNodeBuilder
 
withPartition(Integer) - Method in class org.apache.kafka.streams.StoreQueryParameters
Set a specific partition that should be queried exclusively.
withProcessorParameters(ProcessorParameters<K, V>) - Method in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
withProcessorParameters(ProcessorParameters<K, V>) - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode.TableSourceNodeBuilder
 
withQueryableStoreName(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode.KTableKTableJoinNodeBuilder
 
withRepartitionTopic(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
withRetention(Duration) - Method in class org.apache.kafka.streams.kstream.Materialized
Configure retention period for window and session stores.
withSinkName(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
withSourceName(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
withSourceName(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode.TableSourceNodeBuilder
 
withStoreBuilder(StoreBuilder<TimestampedKeyValueStore<K, VR>>) - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode.KTableKTableJoinNodeBuilder
 
withStoreName(String) - Method in class org.apache.kafka.streams.kstream.StreamJoined
Sets the base store name to use for both sides of the join.
withStreamPartitioner(StreamPartitioner<? super K, ? super V>) - Method in class org.apache.kafka.streams.kstream.Produced
Produce records using the provided partitioner.
withStreamPartitioner(StreamPartitioner<K, V>) - Method in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
withStreamPartitioner(StreamPartitioner<K, V>) - Method in class org.apache.kafka.streams.kstream.Repartitioned
Create a new instance of Repartitioned with the provided partitioner.
withThisJoinSideNodeName(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode.KTableKTableJoinNodeBuilder
 
withThisStoreSupplier(WindowBytesStoreSupplier) - Method in class org.apache.kafka.streams.kstream.StreamJoined
Configure with the provided WindowBytesStoreSupplier for this store supplier.
withThisWindowedStreamProcessorParameters(ProcessorParameters<K, V1>) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamStreamJoinNode.StreamStreamJoinNodeBuilder
 
withThisWindowStoreBuilder(StoreBuilder<WindowStore<K, V1>>) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamStreamJoinNode.StreamStreamJoinNodeBuilder
 
withTimestamp(long) - Method in class org.apache.kafka.streams.processor.To
Set the timestamp of the output record.
withTimestampExtractor(TimestampExtractor) - Method in class org.apache.kafka.streams.kstream.Consumed
Configure the instance of Consumed with a TimestampExtractor.
withTopic(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode.TableSourceNodeBuilder
 
withValueJoiner(ValueJoiner<? super V1, ? super V2, ? extends VR>) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamStreamJoinNode.StreamStreamJoinNodeBuilder
 
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Consumed
Configure the instance of Consumed with a value Serde.
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Grouped
Perform the grouping operation using the provided valueSerde for serializing the value.
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode.BaseRepartitionNodeBuilder
 
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Joined
Set the value Serde to be used.
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Materialized
Set the valueSerde the materialized StateStore will use.
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Produced
Produce records using the provided valueSerde.
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Repartitioned
Create a new instance of Repartitioned with the provided value serde.
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Serialized
Deprecated.
Construct a Serialized instance with the provided value Serde.
withValueSerde(Serde<V1>) - Method in class org.apache.kafka.streams.kstream.StreamJoined
Configure with the provided Serde for this value
withValueSerde(Serde<VR>) - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode.KTableKTableJoinNodeBuilder
 
wrap(Serde<T>) - Static method in class org.apache.kafka.streams.kstream.internals.FullChangeSerde
 
wrapped() - Method in class org.apache.kafka.streams.state.internals.WrappedStateStore
 
WrappedStateStore<S extends StateStore,​K,​V> - Class in org.apache.kafka.streams.state.internals
A storage engine wrapper for utilities like logging, caching, and metering.
WrappedStateStore(S) - Constructor for class org.apache.kafka.streams.state.internals.WrappedStateStore
 
WrappingNullableDeserializer<Outer,​InnerK,​InnerV> - Interface in org.apache.kafka.streams.kstream.internals
 
WrappingNullableSerde<T,​InnerK,​InnerV> - Class in org.apache.kafka.streams.kstream.internals
 
WrappingNullableSerde(WrappingNullableSerializer<T, InnerK, InnerV>, WrappingNullableDeserializer<T, InnerK, InnerV>) - Constructor for class org.apache.kafka.streams.kstream.internals.WrappingNullableSerde
 
WrappingNullableSerializer<Outer,​InnerK,​InnerV> - Interface in org.apache.kafka.streams.kstream.internals
 
WrappingNullableUtils - Class in org.apache.kafka.streams.kstream.internals
If a component's serdes are Wrapping serdes, then they require a little extra setup to be fully initialized at run time.
WrappingNullableUtils() - Constructor for class org.apache.kafka.streams.kstream.internals.WrappingNullableUtils
 
WrappingStoreProvider - Class in org.apache.kafka.streams.state.internals
Provides a wrapper over multiple underlying StateStoreProviders
writableFileMaxBufferSize() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
write(Map<TopicPartition, Long>) - Method in class org.apache.kafka.streams.state.internals.OffsetCheckpoint
Write the given offsets to the checkpoint file.
write(Writable, ObjectSerializationCache, short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.PartitionToOffsetSum
 
write(Writable, ObjectSerializationCache, short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskId
 
write(Writable, ObjectSerializationCache, short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData.TaskOffsetSum
 
write(Writable, ObjectSerializationCache, short) - Method in class org.apache.kafka.streams.internals.generated.SubscriptionInfoData
 
write(WriteBatch) - Method in interface org.apache.kafka.streams.state.internals.BatchWritingStore
 
write(WriteBatch) - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
writeBufferManager() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
writeBufferSize() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
writeStallDurationSensor(StreamsMetricsImpl, RocksDBMetrics.RocksDBMetricContext) - Static method in class org.apache.kafka.streams.state.internals.metrics.RocksDBMetrics
 
writeThreadMaxYieldUsec() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
writeThreadSlowYieldUsec() - Method in class org.apache.kafka.streams.state.internals.RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter
 
writeTo(DataOutputStream) - Method in class org.apache.kafka.streams.processor.TaskId
 
writeTo(ByteBuffer) - Method in class org.apache.kafka.streams.processor.TaskId
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.GlobalStoreNode
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.GroupedTableOperationRepartitionNode
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.OptimizableRepartitionNode
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.ProcessorGraphNode
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.StatefulProcessorNode
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.StateStoreNode
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamSinkNode
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamSourceNode
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamStreamJoinNode
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamTableJoinNode
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamToTableNode
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.TableProcessorNode
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.UnoptimizableRepartitionNode
 
A B C D E F G H I J K L M N O P Q R S T U V W 
All Classes All Packages