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

AbstractNotifyingBatchingRestoreCallback - Class in org.apache.kafka.streams.processor
Abstract implementation of the BatchingStateRestoreCallback used for batch restoration operations.
AbstractNotifyingBatchingRestoreCallback() - Constructor for class org.apache.kafka.streams.processor.AbstractNotifyingBatchingRestoreCallback
 
AbstractNotifyingRestoreCallback - Class in org.apache.kafka.streams.processor
Abstract implementation of the StateRestoreCallback used for batch restoration operations.
AbstractNotifyingRestoreCallback() - Constructor for class org.apache.kafka.streams.processor.AbstractNotifyingRestoreCallback
 
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
 
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
 
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.
activeTaskCheckpointableOffsets() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
activeTaskCheckpointableOffsets() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
activeTaskCount() - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
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.ThreadMetadata
 
adapt(StateRestoreCallback) - Static method in class org.apache.kafka.streams.processor.internals.StateRestoreCallbackAdapter
 
add(T) - Method in class org.apache.kafka.streams.processor.internals.QuickUnion
 
addAvgMaxLatency(Sensor, String, Map<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
 
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<KeyValueStore>, String, String, ConsumedInternal, String, ProcessorSupplier) - Method in class org.apache.kafka.streams.kstream.internals.InternalStreamsBuilder
 
addGlobalStore(StoreBuilder<KeyValueStore>, String, ConsumedInternal, ProcessorSupplier) - Method in class org.apache.kafka.streams.kstream.internals.InternalStreamsBuilder
 
addGlobalStore(StoreBuilder<KeyValueStore>, String, TimestampExtractor, Deserializer, Deserializer, String, String, ProcessorSupplier) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
addGlobalStore(StoreBuilder, String, String, Consumed, String, ProcessorSupplier) - Method in class org.apache.kafka.streams.StreamsBuilder
addGlobalStore(StoreBuilder, String, Deserializer, Deserializer, String, String, ProcessorSupplier) - Method in class org.apache.kafka.streams.Topology
Adds a global StateStore to the topology.
addGlobalStore(StoreBuilder, String, Consumed, ProcessorSupplier) - Method in class org.apache.kafka.streams.StreamsBuilder
Adds a global StateStore to the topology.
addGlobalStore(StoreBuilder, String, TimestampExtractor, Deserializer, Deserializer, String, String, ProcessorSupplier) - 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) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
addInvocationRateAndCount(Sensor, String, Map<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
 
addLatencyAndThroughputSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
Add a latency and throughput sensor for a specific operation, which will include the following sensors: average latency max latency throughput (num.operations / time unit) Also create a parent sensor with the same metrics that aggregates all entities with the same operation under the same scope if it has not been created.
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
 
addPreviousActiveTasks(Set<TaskId>) - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
addPreviousStandbyTasks(Set<TaskId>) - 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.
addRecords(TopicPartition, Iterable<ConsumerRecord<byte[], byte[]>>) - Method in class org.apache.kafka.streams.processor.internals.StreamTask
Adds records to queues.
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.
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.
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
 
addThroughputSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
addThroughputSensor(String, String, String, Sensor.RecordingLevel, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
Add a throughput sensor for a specific operation: throughput (num.operations / time unit) Also create a parent sensor with the same metrics that aggregates all entities with the same operation under the same scope if it has not been created.
ADMIN_CLIENT_PREFIX - Static variable in class org.apache.kafka.streams.StreamsConfig
Prefix used to isolate admin configs from other client configs.
adminClientMetrics() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
 
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.
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>, Merger<? super K, T>) - Method in class org.apache.kafka.streams.kstream.internals.SessionWindowedKStreamImpl
 
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.
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>, 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.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>) - Method in interface org.apache.kafka.streams.kstream.SessionWindowedKStream
Aggregate the values of records in this stream by the grouped key and defined SessionWindows.
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, 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 SessionWindows.
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.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.InMemoryKeyValueLoggedStore
 
all() - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
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.RocksDBStore
 
all() - Method in class org.apache.kafka.streams.state.internals.RocksDBWindowStore
 
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
 
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.
allParentsWrittenToTopology() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
allStateStoreName() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
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
user.endpoint
applicationId() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
applicationId() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
applicationId() - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
applicationId() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
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) - Method in interface org.apache.kafka.streams.state.internals.MemoryLRUCache.EldestEntryRemovalListener
 
apply(K, V, V) - Method in interface org.apache.kafka.streams.kstream.internals.CacheFlushListener
Called when records are flushed from the ThreadCache
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(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.ChangeLoggingKeyValueBytesStore
 
approximateNumEntries() - Method in class org.apache.kafka.streams.state.internals.CompositeReadOnlyKeyValueStore
 
approximateNumEntries() - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueLoggedStore
 
approximateNumEntries() - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
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.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.
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.Materialized
Materialize a StateStore with the given name.
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(int) - Method in class org.apache.kafka.streams.processor.internals.assignment.StickyTaskAssignor
 
assign(int) - Method in interface org.apache.kafka.streams.processor.internals.assignment.TaskAssignor
 
assign(Cluster, Map<String, PartitionAssignor.Subscription>) - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
assign(TaskId, boolean) - 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
 
AssignmentInfo - Class in org.apache.kafka.streams.processor.internals.assignment
 
AssignmentInfo() - Constructor for class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
AssignmentInfo(int, List<TaskId>, Map<TaskId, Set<TopicPartition>>, Map<HostInfo, Set<TopicPartition>>, int) - Constructor for class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
AssignmentInfo(List<TaskId>, Map<TaskId, Set<TopicPartition>>, Map<HostInfo, Set<TopicPartition>>) - Constructor for class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
AT_LEAST_ONCE - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter "processing.guarantee" for at-least-once processing guarantees.

B

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
 
BatchingStateRestoreCallback - Interface in org.apache.kafka.streams.processor
Interface for batching restoration of a StateStore It is expected that implementations of this class will not call the StateRestoreCallback.restore(byte[], byte[]) method.
before(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Deprecated.
before(Duration) - Method in class org.apache.kafka.streams.kstream.JoinWindows
Changes the start window boundary to timeDifference but keep the end window boundary as is.
beforeMs - Variable in class org.apache.kafka.streams.kstream.JoinWindows
Maximum time difference for tuples that are before the join tuple.
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
 
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.EagerBufferConfigImpl
 
bufferFullStrategy() - Method in class org.apache.kafka.streams.kstream.internals.suppress.StrictBufferConfigImpl
 
BufferFullStrategy - Enum in org.apache.kafka.streams.kstream.internals.suppress
 
bufferSize() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
bufferSize() - Method in interface org.apache.kafka.streams.state.internals.TimeOrderedKeyValueBuffer
 
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.processor.internals.InternalTopologyBuilder
 
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.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(Integer) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
build(String) - Method in class org.apache.kafka.streams.kstream.internals.PrintedInternal
Builds the ProcessorSupplier that will be used to print the records flowing through a KStream.
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) - Constructor for class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer.Builder
 
buildFinalResultsSuppression(Duration) - Method in class org.apache.kafka.streams.kstream.internals.suppress.FinalResultsSuppressionBuilder
 
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
 

C

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
 
cachedTasksIds() - Method in class org.apache.kafka.streams.processor.internals.TaskManager
Returns ids of tasks whose states are kept on the local storage.
CacheFlushListener<K,​V> - Interface in org.apache.kafka.streams.kstream.internals
Listen to cache flush events
cacheLevelSensor(String, String, String, Sensor.RecordingLevel, Sensor...) - 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
 
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
castOrWrap(Serde<?>) - Static method in class org.apache.kafka.streams.kstream.internals.FullChangeSerde
 
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
 
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
Performs bulk read operations from a set of partitions.
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
 
checkpointed() - Method in class org.apache.kafka.streams.processor.internals.GlobalStateManagerImpl
 
checkpointed() - 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 class org.apache.kafka.streams.processor.internals.PartitionGroup
 
clear() - Method in class org.apache.kafka.streams.processor.internals.RecordQueue
Clear the fifo queue of its elements, also clear the time tracker's kept stamped elements
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
ClientState - Class in org.apache.kafka.streams.processor.internals.assignment
 
ClientState() - Constructor for class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
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.FullChangeSerde
 
close() - Method in class org.apache.kafka.streams.kstream.internals.KStreamTransform.KStreamTransformProcessor
 
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.suppress.KTableSuppressProcessor
 
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.GlobalStateUpdateTask
 
close() - Method in class org.apache.kafka.streams.processor.internals.PartitionGroup
 
close() - Method in class org.apache.kafka.streams.processor.internals.ProcessorNode
 
close() - Method in class org.apache.kafka.streams.processor.internals.PunctuationQueue
 
close() - Method in interface org.apache.kafka.streams.processor.internals.RecordCollector
Close the internal Producer.
close() - Method in class org.apache.kafka.streams.processor.internals.RecordCollectorImpl
 
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.InMemoryKeyValueStore
 
close() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
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.RocksDBStore
 
close() - Method in class org.apache.kafka.streams.state.internals.WrappedStateStore.AbstractStateStore
 
close() - Method in interface org.apache.kafka.streams.state.KeyValueIterator
 
close() - Method in interface org.apache.kafka.streams.state.WindowStoreIterator
 
close(boolean, boolean) - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
- StandbyTask.commit() - close state
close(boolean, boolean) - Method in class org.apache.kafka.streams.processor.internals.StreamTask
- suspend(clean) - close topology - if (clean) StreamTask.commit() - flush state and producer - commit offsets - close state - if (clean) write checkpoint - if (eos) close producer
close(boolean, boolean) - Method in interface org.apache.kafka.streams.processor.internals.Task
 
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(Duration) - Method in class org.apache.kafka.streams.KafkaStreams
Shutdown this KafkaStreams by signaling all the threads to stop, and then wait up to the timeout for the threads to join.
close(Map<TopicPartition, Long>) - Method in class org.apache.kafka.streams.processor.internals.GlobalStateManagerImpl
 
close(Map<TopicPartition, Long>) - Method in class org.apache.kafka.streams.processor.internals.ProcessorStateManager
Close all stores (even in case of failure).
closeSuspended(boolean, boolean, RuntimeException) - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
 
closeSuspended(boolean, boolean, RuntimeException) - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
closeSuspended(boolean, boolean, RuntimeException) - Method in interface org.apache.kafka.streams.processor.internals.Task
 
code() - Method in enum org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor.Error
 
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 class org.apache.kafka.streams.processor.internals.StandbyTask
- flush store - checkpoint store - update offset limits
commit() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
- flush state and producer - if(!eos) write checkpoint - commit offsets and start new transaction
commit() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
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
commitNeeded() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
commitNeeded() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
compareTo(Object) - Method in class org.apache.kafka.streams.processor.internals.Stamped
 
compareTo(TaskId) - Method in class org.apache.kafka.streams.processor.TaskId
 
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
 
CompositeRestoreListener - Class in org.apache.kafka.streams.processor.internals
 
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.ChangedDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.internals.ChangedSerializer
 
configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.streams.kstream.internals.FullChangeSerde
 
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
 
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.
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.
consumerMetrics() - Method in class org.apache.kafka.streams.processor.internals.GlobalStreamThread
 
consumerMetrics() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
 
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.
context() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
context() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
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
 
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
 
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 into SessionWindows.
count() - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Count the number of records in this stream by the grouped key and the defined windows.
count(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 into SessionWindows.
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 the defined windows.
create(InternalTopologyBuilder, StreamsConfig, KafkaClientSupplier, AdminClient, UUID, String, Metrics, Time, StreamsMetadataState, long, StateDirectory, StateRestoreListener) - 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.
createAppDirAndInternalStreams(StreamsConfig) - Static method in class org.apache.kafka.streams.mapr.KafkaStreamsInternalStorageInitializer
 
createAppDirAndInternalStreamsForKafkaStreams(StreamsConfig) - Static method in class org.apache.kafka.streams.mapr.Utils
Deprecated.
 
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
 
createStream(String) - Static method in class org.apache.kafka.streams.mapr.Utils
Deprecated.
createStreamWithPublicPerms(String) - Static method in class org.apache.kafka.streams.mapr.Utils
Deprecated.
createTaskAndStoreLatencyAndThroughputSensors(Sensor.RecordingLevel, String, StreamsMetricsImpl, String, String, String, Map<String, String>, Map<String, String>) - Static method in class org.apache.kafka.streams.state.internals.metrics.Sensors
 
CumulativeCount - Class in org.apache.kafka.streams.processor.internals.metrics
A non-SampledStat version of Count for measuring -total metrics in streams
CumulativeCount() - Constructor for class org.apache.kafka.streams.processor.internals.metrics.CumulativeCount
 
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
 

D

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
 
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_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
Default implementation of the PartitionGrouper interface that groups partitions by the partition id.
DefaultPartitionGrouper() - Constructor for class org.apache.kafka.streams.processor.DefaultPartitionGrouper
 
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.
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.InMemoryKeyValueLoggedStore
 
delete(K) - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
delete(K) - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
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.ChangeLoggingKeyValueBytesStore
 
delete(Bytes) - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
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
 
deserializer() - Method in class org.apache.kafka.streams.kstream.internals.FullChangeSerde
 
directoryForTask(TaskId) - Method in class org.apache.kafka.streams.processor.internals.StateDirectory
Get or create the directory for the provided TaskId.

E

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
 
earliestResetTopicsPattern() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
EMIT - org.apache.kafka.streams.kstream.internals.suppress.BufferFullStrategy
 
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.
enableLogCompactionForStreamIfNotEnabled(String) - Static method in class org.apache.kafka.streams.mapr.Utils
Deprecated.
enableLogging() - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
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 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
 
encode() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
encode() - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
encodeClientUUID(ByteBuffer) - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
encodeTasks(ByteBuffer, Collection<TaskId>) - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
encodeUserEndPoint(ByteBuffer, byte[]) - 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.
endMs - Variable in class org.apache.kafka.streams.kstream.Window
 
endTime() - Method in class org.apache.kafka.streams.kstream.Window
Return the end time of this window.
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.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.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.state.HostInfo
 
equals(Object) - Method in class org.apache.kafka.streams.state.internals.ContextualRecord
 
equals(Object) - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
errCode() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
ERROR - org.apache.kafka.streams.KafkaStreams.State
 
evicts() - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 
evictWhile(Supplier<Boolean>, Consumer<KeyValue<Bytes, ContextualRecord>>) - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
evictWhile(Supplier<Boolean>, Consumer<KeyValue<Bytes, ContextualRecord>>) - 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.
exists(T) - Method in class org.apache.kafka.streams.processor.internals.QuickUnion
 
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.
extractEndTimestamp(byte[]) - Static method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
extractKeyBytes(byte[]) - Static method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
extractStartTimestamp(byte[]) - Static method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
extractStoreKey(byte[], StateSerdes<K, ?>) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
extractStoreKeyBytes(byte[]) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
extractStoreSequence(byte[]) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
extractStoreTimestamp(byte[]) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
extractStoreWindow(byte[], long) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
extractWindow(byte[]) - Static method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 

F

FAIL - org.apache.kafka.streams.errors.DeserializationExceptionHandler.DeserializationHandlerResponse
 
FAIL - org.apache.kafka.streams.errors.ProductionExceptionHandler.ProductionExceptionHandlerResponse
 
FailOnInvalidTimestamp - Class in org.apache.kafka.streams.processor
Retrieves embedded metadata timestamps from Kafka messages.
FailOnInvalidTimestamp() - Constructor for class org.apache.kafka.streams.processor.FailOnInvalidTimestamp
 
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 class org.apache.kafka.streams.state.internals.RocksDBSessionStore
 
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.RocksDBWindowStore
 
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.RocksDBWindowStore
 
fetch(K, long, long) - Method in interface org.apache.kafka.streams.state.ReadOnlyWindowStore
Deprecated.
Use #fetch(K, Instant, Instant) instead
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 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 class org.apache.kafka.streams.state.internals.RocksDBSessionStore
 
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.RocksDBWindowStore
 
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 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, 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, 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.CompositeReadOnlyWindowStore
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.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 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
 
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.
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.
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 class org.apache.kafka.streams.state.internals.RocksDBSessionStore
 
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 class org.apache.kafka.streams.state.internals.RocksDBSessionStore
 
findSessions(K, K, long, long) - Method in interface org.apache.kafka.streams.state.SessionStore
Fetch any sessions in the given range of keys and the sessions end is ≥ earliestSessionEndTime and the sessions start is ≤ latestSessionStartTime This iterator must be closed after use.
flatMap(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>>) - Method in 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).
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(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.
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.InMemoryKeyValueStore
 
flush() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
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.AbstractStateStore
 
flush(String) - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 
flushes() - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 
flushState() - Method in class org.apache.kafka.streams.processor.internals.GlobalStateUpdateTask
 
flushState() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
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.
ForeachAction<K,​V> - Interface in org.apache.kafka.streams.kstream
The ForeachAction interface for performing an action on a key-value pair.
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
 
forward(K, V, int) - Method in class org.apache.kafka.streams.processor.internals.GlobalProcessorContextImpl
 
forward(K, V, int) - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
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
 
forward(K, V, String) - Method in class org.apache.kafka.streams.processor.internals.GlobalProcessorContextImpl
 
forward(K, V, String) - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
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
 
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
 
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
 
fromCode(int) - Static method in enum org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor.Error
 
fromStoreKey(byte[], long) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
fromStoreKey(byte[], long, StateSerdes<K, ?>) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
 
FullChangeSerde<T> - Class in org.apache.kafka.streams.kstream.internals
 
FullChangeSerde(Serde<T>) - Constructor for class org.apache.kafka.streams.kstream.internals.FullChangeSerde
 

G

generateStoreNameIfNeeded(InternalNameProvider, String) - Method in class org.apache.kafka.streams.kstream.internals.MaterializedInternal
 
get() - Method in class org.apache.kafka.streams.kstream.internals.KStreamAggregate
 
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.KStreamTransform
 
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.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 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.internals.StreamTask.ProducerSupplier
 
get() - Method in interface org.apache.kafka.streams.processor.internals.TimestampSupplier
 
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.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.InMemoryKeyValueLoggedStore
 
get(K) - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
get(K) - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
get(K) - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
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.ChangeLoggingKeyValueBytesStore
 
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.
getAdminClient(Map<String, Object>) - Method in interface org.apache.kafka.streams.KafkaClientSupplier
Create an AdminClient which is used for internal topic management.
getAdminClient(Map<String, Object>) - Method in class org.apache.kafka.streams.processor.internals.DefaultKafkaClientSupplier
 
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
getCache() - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
getCache() - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
Get the thread-global cache
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
 
getConsumerConfigs(String, String) - Method in class org.apache.kafka.streams.StreamsConfig
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
 
getMainConsumerConfigs(String, String) - 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
Find the StreamsMetadatas for a given storeName and key.
getMetadataWithKey(String, K, StreamPartitioner<? super K, ?>) - Method in class org.apache.kafka.streams.processor.internals.StreamsMetadataState
Find the StreamsMetadatas for a given storeName and key.
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
 
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.
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
 
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
 
getShortTopicNameFromFullTopicName(String) - Static method in class org.apache.kafka.streams.mapr.Utils
Deprecated.
getSourceTopicNames() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
getStateMgr() - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
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.
getStateStores() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
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(String, QueryableStoreType<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
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
 
getTimestampExtractor() - Method in class org.apache.kafka.streams.processor.internals.SourceNode
 
getTopicNames() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamSourceNode
 
getUpdates() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.SubscriptionUpdates
 
getVersionThreeAndFourByteLength(byte[]) - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
getWindowSize() - Method in class org.apache.kafka.streams.kstream.TimeWindowedDeserializer
 
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
 
GlobalKTableImpl(KTableValueGetterSupplier<K, V>) - Constructor for class org.apache.kafka.streams.kstream.internals.GlobalKTableImpl
 
GlobalKTableImpl(KTableValueGetterSupplier<K, V>, boolean) - Constructor for class org.apache.kafka.streams.kstream.internals.GlobalKTableImpl
 
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(ProcessorTopology, InternalProcessorContext, GlobalStateManager, DeserializationExceptionHandler, LogContext) - 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 - Class in org.apache.kafka.streams.kstream.internals.graph
 
GlobalStoreNode(StoreBuilder<KeyValueStore>, String, String, ConsumedInternal, String, ProcessorSupplier) - 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, Metrics, 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 late events that arrive more than afterWindowEnd after the end of its window.
grace(Duration) - Method in class org.apache.kafka.streams.kstream.SessionWindows
Reject late events that arrive more than afterWindowEnd after the end of its window.
grace(Duration) - Method in class org.apache.kafka.streams.kstream.TimeWindows
Reject late 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 late-arriving events after the end of the window.) Lateness is defined as (stream_time - record_timestamp).
GraphGraceSearchUtil - Class in org.apache.kafka.streams.kstream.internals.graph
 
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
 

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
 
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.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
 
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.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.state.HostInfo
 
hashCode() - Method in class org.apache.kafka.streams.state.internals.ContextualRecord
 
hashCode() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
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 Segments.
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
 
hasStateStores() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
hasStateStores() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
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
headers() - Method in interface org.apache.kafka.streams.processor.RecordContext
 
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
 
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() - 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.
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.StreamsPartitionAssignor.Error
 
incrementCapacity() - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
init(Producer<byte[], byte[]>) - Method in interface org.apache.kafka.streams.processor.internals.RecordCollector
Initialize the collector with a producer.
init(Producer<byte[], byte[]>) - Method in class org.apache.kafka.streams.processor.internals.RecordCollectorImpl
 
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(ProcessorContext) - Method in class org.apache.kafka.streams.kstream.internals.KStreamTransform.KStreamTransformProcessor
 
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 class org.apache.kafka.streams.kstream.internals.suppress.KTableSuppressProcessor
 
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.ChangeLoggingKeyValueBytesStore
 
init(ProcessorContext, StateStore) - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueLoggedStore
 
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.InMemoryTimeOrderedKeyValueBuffer
 
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.RocksDBSessionStore
 
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.AbstractStateStore
 
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
Initializer<VA> - Interface in org.apache.kafka.streams.kstream
The Initializer interface for creating an initial value in aggregations.
initializeStateStores() - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
 
initializeStateStores() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
 
initializeStateStores() - Method in interface org.apache.kafka.streams.processor.internals.Task
Initialize the task and return true if the task is ready to run, i.e, it has not state stores
initializeTopology() - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
 
initializeTopology() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
- (re-)initialize the topology of the task
initializeTopology() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
InMemoryKeyValueLoggedStore<K,​V> - Class in org.apache.kafka.streams.state.internals
 
InMemoryKeyValueLoggedStore(KeyValueStore<K, V>, Serde<K>, Serde<V>) - Constructor for class org.apache.kafka.streams.state.internals.InMemoryKeyValueLoggedStore
 
inMemoryKeyValueStore(String) - Static method in class org.apache.kafka.streams.state.Stores
Create an in-memory KeyValueBytesStoreSupplier.
InMemoryKeyValueStore<K,​V> - Class in org.apache.kafka.streams.state.internals
 
InMemoryKeyValueStore(String, Serde<K>, Serde<V>) - Constructor for class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
InMemoryTimeOrderedKeyValueBuffer - Class in org.apache.kafka.streams.state.internals
 
InMemoryTimeOrderedKeyValueBuffer.Builder - Class in org.apache.kafka.streams.state.internals
 
inner() - Method in class org.apache.kafka.streams.kstream.internals.ChangedDeserializer
 
inner() - Method in class org.apache.kafka.streams.kstream.internals.ChangedSerializer
 
inner() - Method in class org.apache.kafka.streams.state.internals.WrappedStateStore.AbstractStateStore
 
inner() - Method in interface org.apache.kafka.streams.state.internals.WrappedStateStore
Return the inner most storage engine
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 - Class in org.apache.kafka.streams.processor.internals
 
InternalTopicManager(AdminClient, StreamsConfig) - Constructor for class org.apache.kafka.streams.processor.internals.InternalTopicManager
 
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 - Class in org.apache.kafka.streams.processor.internals
 
InternalTopologyBuilder.Source - Class in org.apache.kafka.streams.processor.internals
 
InternalTopologyBuilder.StateStoreFactory - Class in org.apache.kafka.streams.processor.internals
 
InternalTopologyBuilder.SubscriptionUpdates - Class in org.apache.kafka.streams.processor.internals
Used to capture subscribed topic via Patterns discovered during the partition assignment process.
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
 
isClosed() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
isEmpty() - Method in class org.apache.kafka.streams.processor.internals.RecordQueue
Tests if the queue is empty
isEosEnabled() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
isGlobalKTable() - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode
 
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
 
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.InMemoryKeyValueStore
 
isOpen() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
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.AbstractStateStore
 
isQueryable() - Method in class org.apache.kafka.streams.kstream.internals.MaterializedInternal
 
isRunning() - Method in enum org.apache.kafka.streams.KafkaStreams.State
 
isRunning() - Method in enum org.apache.kafka.streams.processor.internals.GlobalStreamThread.State
 
isRunning() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
 
isRunning() - Method in enum org.apache.kafka.streams.processor.internals.StreamThread.State
 
isRunningAndNotRebalancing() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
 
isValidTransition(KafkaStreams.State) - Method in enum org.apache.kafka.streams.KafkaStreams.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<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(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
 
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 records of this stream with another KStream's records using windowed inner equi join using the Joined instance for configuration of the key serde, this stream's value serde, and the other stream's value serde.
join(KTable<K, V1>, ValueJoiner<? super V, ? super V1, ? extends R>) - 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, 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.
Joined<K,​V,​VO> - Class in org.apache.kafka.streams.kstream
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
 
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
 
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.
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
 
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.Serialized
Deprecated.
 
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.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.MaterializedInternal
 
keySerde() - Method in class org.apache.kafka.streams.kstream.internals.ProducedInternal
 
keySerde() - Method in class org.apache.kafka.streams.kstream.internals.SerializedInternal
Deprecated.
 
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 instances of type <Byte, byte[]>.
KeyValueIterator<K,​V> - Interface in org.apache.kafka.streams.state
Iterator interface of KeyValue.
KeyValueMapper<K,​V,​VR> - Interface in org.apache.kafka.streams.kstream
The KeyValueMapper interface for mapping a key-value pair to a new value of arbitrary type.
keyValueStore() - Static method in class org.apache.kafka.streams.state.QueryableStoreTypes
KeyValueStore<K,​V> - Interface in org.apache.kafka.streams.state
A key-value store that supports put/get/delete and range queries.
keyValueStoreBuilder(KeyValueBytesStoreSupplier, Serde<K>, Serde<V>) - Static method in class org.apache.kafka.streams.state.Stores
Creates a StoreBuilder than 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
 
KeyValueStoreMaterializer<K,​V> - Class in org.apache.kafka.streams.kstream.internals
 
KeyValueStoreMaterializer(MaterializedInternal<K, V, KeyValueStore<Bytes, byte[]>>) - Constructor for class org.apache.kafka.streams.kstream.internals.KeyValueStoreMaterializer
 
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
 
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
 
KStreamTransform<K,​V,​K1,​V1> - Class in org.apache.kafka.streams.kstream.internals
 
KStreamTransform(TransformerSupplier<? super K, ? super V, ? extends KeyValue<? extends K1, ? extends V1>>) - Constructor for class org.apache.kafka.streams.kstream.internals.KStreamTransform
 
KStreamTransform.KStreamTransformProcessor<K1,​V1,​K2,​V2> - Class in org.apache.kafka.streams.kstream.internals
 
KStreamTransformProcessor(Transformer<? super K1, ? super V1, ? extends KeyValue<? extends K2, ? extends V2>>) - Constructor for class org.apache.kafka.streams.kstream.internals.KStreamTransform.KStreamTransformProcessor
 
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, boolean, 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
 
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) - 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
 
KTableSuppressProcessor<K,​V> - Class in org.apache.kafka.streams.kstream.internals.suppress
 
KTableSuppressProcessor(SuppressedInternal<K>, String, Serde<K>, FullChangeSerde<V>) - Constructor for class org.apache.kafka.streams.kstream.internals.suppress.KTableSuppressProcessor
 
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
 
lateRecordDropSensor(InternalProcessorContext) - Static method in class org.apache.kafka.streams.kstream.internals.metrics.Sensors
 
LATEST - org.apache.kafka.streams.Topology.AutoOffsetReset
 
LATEST_SUPPORTED_VERSION - Static variable in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
LATEST_SUPPORTED_VERSION - Static variable in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
latestResetTopicsPattern() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
latestSupportedVersion() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
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<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(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
 
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
Join records of this stream with another KStream's records using windowed left equi join using the Joined instance for configuration of the key serde, this stream's value serde, and the other stream's value serde.
leftJoin(KTable<K, V1>, ValueJoiner<? super V, ? super V1, ? extends R>) - 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, 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.
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
 
LogAndContinueExceptionHandler - Class in org.apache.kafka.streams.errors
Deserialization handler that logs a deserialization exception and then signals the processing pipeline to continue processing more records.
LogAndContinueExceptionHandler() - Constructor for class org.apache.kafka.streams.errors.LogAndContinueExceptionHandler
 
LogAndFailExceptionHandler - Class in org.apache.kafka.streams.errors
Deserialization handler that logs a deserialization exception and then signals the processing pipeline to stop processing more records and fail.
LogAndFailExceptionHandler() - Constructor for class org.apache.kafka.streams.errors.LogAndFailExceptionHandler
 
LogAndSkipOnInvalidTimestamp - Class in org.apache.kafka.streams.processor
Retrieves embedded metadata timestamps from Kafka messages.
LogAndSkipOnInvalidTimestamp() - Constructor for class org.apache.kafka.streams.processor.LogAndSkipOnInvalidTimestamp
 
logConfig() - Method in 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.
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
Visible for testing
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
 
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
 
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. Use JoinWindows.gracePeriodMs() instead.
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.
makeReady(Map<String, InternalTopicConfig>) - Method in class org.apache.kafka.streams.processor.internals.InternalTopicManager
Prepares a set of given internal topics.
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).
mapper - Variable in class org.apache.kafka.streams.kstream.Printed
 
maprFSpathCreate(FileSystem, String, ArrayList<MapRFileAce>, String, String) - Static method in class org.apache.kafka.streams.mapr.Utils
Deprecated.
maprFSpathExists(FileSystem, String) - Static method in class org.apache.kafka.streams.mapr.Utils
Deprecated.
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(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.
markSourceStoreAndTopic(StoreBuilder, String) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
materialize() - Method in class org.apache.kafka.streams.kstream.internals.KeyValueStoreMaterializer
 
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
 
MAX_TASK_IDLE_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
max.task.idle.ms
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.
maxNumPartitions(Cluster, Set<String>) - Method in class org.apache.kafka.streams.processor.DefaultPartitionGrouper
 
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.
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
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
measure(MetricConfig, long) - Method in class org.apache.kafka.streams.processor.internals.metrics.CumulativeCount
 
MemoryLRUCache<K,​V> - Class in org.apache.kafka.streams.state.internals
An in-memory LRU cache store based on HashSet and HashMap.
MemoryLRUCache.EldestEntryRemovalListener<K,​V> - Interface in org.apache.kafka.streams.state.internals
 
MemoryNavigableLRUCache<K,​V> - Class in org.apache.kafka.streams.state.internals
 
MemoryNavigableLRUCache(String, int, Serde<K>, Serde<V>) - Constructor for class org.apache.kafka.streams.state.internals.MemoryNavigableLRUCache
 
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.
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
Find the currently running KafkaStreams instance (potentially remotely) that use the same application ID as this instance (i.e., all instances that belong to the same Kafka Streams application) and that contain a StateStore with the given storeName and the StateStore contains the given key and return StreamsMetadata for it.
metadataForKey(String, K, StreamPartitioner<? super K, ?>) - Method in class org.apache.kafka.streams.KafkaStreams
Find the currently running KafkaStreams instance (potentially remotely) that use the same application ID as this instance (i.e., all instances that belong to the same Kafka Streams application) and that contain a StateStore with the given storeName and the StateStore contains the given key and return StreamsMetadata for it.
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
 
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 consumer 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_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.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.
migratedTask() - Method in exception org.apache.kafka.streams.errors.TaskMigratedException
 
minTimestamp() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
minTimestamp() - Method in interface org.apache.kafka.streams.state.internals.TimeOrderedKeyValueBuffer
 

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.state.internals.AbstractStoreBuilder
 
name() - Method in class org.apache.kafka.streams.kstream.internals.GroupedInternal
 
name() - Method in class org.apache.kafka.streams.kstream.internals.suppress.SuppressedInternal
 
name() - Method in class org.apache.kafka.streams.kstream.Joined
 
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.AbstractStoreBuilder
 
name() - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
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.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.AbstractStateStore
 
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
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.
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.
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
 
newValue - Variable in class org.apache.kafka.streams.kstream.internals.Change
 
next(long) - Method in class org.apache.kafka.streams.processor.internals.PunctuationSchedule
 
NO_OP_STATE_RESTORE_LISTENER - Static variable in class org.apache.kafka.streams.processor.internals.CompositeRestoreListener
 
NO_OPTIMIZATION - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter (@link #TOPOLOGY_OPTIMIZATION "topology.optimization" for disabling topology optimization
node() - Method in class org.apache.kafka.streams.processor.internals.PartitionGroup.RecordInfo
 
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, Sensor.RecordingLevel, Sensor...) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
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.
NONE - org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor.Error
 
NONEXIST_TOPIC - Static variable in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
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
 
NUM_STANDBY_REPLICAS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
num.standby.replicas
NUM_STREAM_THREADS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
num.stream.threads
numberOfPartitions() - Method in class org.apache.kafka.streams.processor.internals.InternalTopicConfig
 
numRecords() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
numRecords() - Method in interface org.apache.kafka.streams.state.internals.TimeOrderedKeyValueBuffer
 

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.
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.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
 
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
 
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
 
oldValue - Variable in class org.apache.kafka.streams.kstream.internals.Change
 
onAssignment(PartitionAssignor.Assignment) - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
onBatchRestored(TopicPartition, String, long, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingBatchingRestoreCallback
 
onBatchRestored(TopicPartition, String, long, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingRestoreCallback
 
onBatchRestored(TopicPartition, String, long, long) - Method in class org.apache.kafka.streams.processor.internals.CompositeRestoreListener
 
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.UsePreviousTimeOnInvalidTimestamp
Returns the current stream-time as new timestamp for the record.
onRestoreEnd(TopicPartition, String, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingBatchingRestoreCallback
 
onRestoreEnd(TopicPartition, String, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingRestoreCallback
 
onRestoreEnd(TopicPartition, String, long) - Method in class org.apache.kafka.streams.processor.internals.CompositeRestoreListener
 
onRestoreEnd(TopicPartition, String, long) - Method in interface org.apache.kafka.streams.processor.StateRestoreListener
Method called when restoring the StateStore is complete.
onRestoreStart(TopicPartition, String, long, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingBatchingRestoreCallback
 
onRestoreStart(TopicPartition, String, long, long) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingRestoreCallback
 
onRestoreStart(TopicPartition, String, long, long) - Method in class org.apache.kafka.streams.processor.internals.CompositeRestoreListener
 
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
 
openDB(ProcessorContext) - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
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
 
OPTIMIZE - Static variable in class org.apache.kafka.streams.StreamsConfig
Config value for parameter (@link #TOPOLOGY_OPTIMIZATION "topology.optimization" for enabling topology optimization
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.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.graph - package org.apache.kafka.streams.kstream.internals.graph
 
org.apache.kafka.streams.kstream.internals.metrics - package org.apache.kafka.streams.kstream.internals.metrics
 
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
 
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
 
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
Join records of this stream with another KStream's records using windowed outer equi join using the Joined instance for configuration of the key serde, this stream's value serde, and the other stream's value serde.
outerJoin(KTable<K, V1>, ValueJoiner<? super V, ? super V1, ? extends R>) - 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.
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

pair(K, V) - Static method in class org.apache.kafka.streams.KeyValue
Create a new key-value pair.
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.processor.internals.AbstractProcessorContext
 
partition() - Method in class org.apache.kafka.streams.processor.internals.ForwardingDisabledProcessorContext
 
partition() - Method in class org.apache.kafka.streams.processor.internals.PartitionGroup.RecordInfo
 
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 class org.apache.kafka.streams.processor.internals.StateRestorer
 
partition() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Returns the partition id of the current input record; could be -1 if it is not available (for example, if this method is invoked from the punctuate call)
partition() - Method in interface org.apache.kafka.streams.processor.RecordContext
 
partition(String, K, V, int) - Method in 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
partition.grouper
partitioner - Variable in class org.apache.kafka.streams.kstream.Produced
 
PartitionGroup - Class in org.apache.kafka.streams.processor.internals
A PartitionGroup is composed from a set of partitions.
PartitionGroup.RecordInfo - Class in org.apache.kafka.streams.processor.internals
 
PartitionGrouper - Interface in org.apache.kafka.streams.processor
A partition grouper that generates partition groups given the list of topic-partitions.
partitionGroups(Map<Integer, Set<String>>, Cluster) - Method in class org.apache.kafka.streams.processor.DefaultPartitionGrouper
Generate tasks with the assigned topic partitions.
partitionGroups(Map<Integer, Set<String>>, Cluster) - Method in interface org.apache.kafka.streams.processor.PartitionGrouper
Returns a map of task ids to groups of partitions.
partitions() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
partitions() - Method in class org.apache.kafka.streams.processor.internals.PartitionGroup
 
partitions() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
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
 
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.
PeekingKeyValueIterator<K,​V> - Interface in org.apache.kafka.streams.state.internals
 
peekNext() - Method in interface org.apache.kafka.streams.state.internals.PeekingKeyValueIterator
 
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.InMemoryKeyValueStore
 
persistent() - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
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.AbstractStateStore
 
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.
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
port() - Method in class org.apache.kafka.streams.state.HostInfo
 
port() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
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.
prepareUserEndPoint() - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
prevActiveTaskIds() - Method in class org.apache.kafka.streams.processor.internals.TaskManager
 
prevActiveTasks() - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
prevStandbyTasks() - Method in class org.apache.kafka.streams.processor.internals.assignment.ClientState
 
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
 
process() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
Process one record.
process(K1, V1) - Method in class org.apache.kafka.streams.kstream.internals.KStreamTransform.KStreamTransformProcessor
 
process(K, Change<V>) - Method in class org.apache.kafka.streams.kstream.internals.suppress.KTableSuppressProcessor
 
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).
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
processLatestVersionAssignment(AssignmentInfo, List<TopicPartition>, Map<TaskId, Set<TopicPartition>>, Map<TopicPartition, PartitionInfo>) - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
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_METRICS_GROUP - Static variable in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
processorConnectedStateStores(String) - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
ProcessorContext - Interface in org.apache.kafka.streams.processor
Processor context interface.
ProcessorContextImpl - Class in org.apache.kafka.streams.processor.internals
 
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(String, ProcessorParameters<K, V>, boolean) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.ProcessorGraphNode
 
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
 
ProcessorNodePunctuator - Interface in org.apache.kafka.streams.processor.internals
 
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) - Constructor for class org.apache.kafka.streams.processor.internals.ProcessorRecordContext
 
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(TaskId, Collection<TopicPartition>, boolean, StateDirectory, Map<String, String>, ChangelogReader, boolean, LogContext) - Constructor for class org.apache.kafka.streams.processor.internals.ProcessorStateManager
 
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
 
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.
producerMetrics() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
 
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
 
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
 
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).
put(long, Bytes, ContextualRecord) - Method in class org.apache.kafka.streams.state.internals.InMemoryTimeOrderedKeyValueBuffer
 
put(long, Bytes, ContextualRecord) - 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.InMemoryKeyValueLoggedStore
 
put(K, V) - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
put(K, V) - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
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
 
put(K, V) - Method in class org.apache.kafka.streams.state.internals.RocksDBWindowStore
 
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
Use the current record timestamp as the windowStartTimestamp and delegate to WindowStore.put(Object, Object, long).
put(K, V, long) - Method in class org.apache.kafka.streams.state.internals.MeteredWindowStore
 
put(K, V, long) - Method in class org.apache.kafka.streams.state.internals.RocksDBWindowStore
 
put(K, V, long) - Method in interface org.apache.kafka.streams.state.WindowStore
Put a key-value pair with the given timestamp into the corresponding window
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.RocksDBStore
 
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(Windowed<K>, AGG) - Method in class org.apache.kafka.streams.state.internals.RocksDBSessionStore
 
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
 
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.InMemoryKeyValueLoggedStore
 
putAll(List<KeyValue<K, V>>) - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
putAll(List<KeyValue<K, V>>) - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
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.ChangeLoggingKeyValueBytesStore
 
putAll(List<KeyValue<Bytes, byte[]>>) - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
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.InMemoryKeyValueLoggedStore
 
putIfAbsent(K, V) - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
putIfAbsent(K, V) - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
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.ChangeLoggingKeyValueBytesStore
 
putIfAbsent(Bytes, byte[]) - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
puts() - Method in class org.apache.kafka.streams.state.internals.ThreadCache
 

Q

queryableStoreName() - Method in interface org.apache.kafka.streams.kstream.GlobalKTable
Get the name of the local state store that can be used to query this GlobalKTable.
queryableStoreName() - Method in class org.apache.kafka.streams.kstream.internals.GlobalKTableImpl
 
queryableStoreName() - Method in class org.apache.kafka.streams.kstream.internals.KTableImpl
 
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<StateStoreProvider>, GlobalStateStoreProvider) - Constructor for class org.apache.kafka.streams.state.internals.QueryableStoreProvider
 
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
 
QuickUnion<T> - Class in org.apache.kafka.streams.processor.internals
 
QuickUnion() - Constructor for class org.apache.kafka.streams.processor.internals.QuickUnion
 

R

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.InMemoryKeyValueLoggedStore
 
range(K, K) - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueStore
 
range(K, K) - Method in class org.apache.kafka.streams.state.internals.MemoryLRUCache
 
range(K, K) - Method in class org.apache.kafka.streams.state.internals.MemoryNavigableLRUCache
 
range(K, K) - Method in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
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.ChangeLoggingKeyValueBytesStore
 
range(Bytes, Bytes) - Method in class org.apache.kafka.streams.state.internals.RocksDBStore
 
rawKey(K) - Method in class org.apache.kafka.streams.state.StateSerdes
Serialize the given key.
rawValue(V) - Method in class org.apache.kafka.streams.state.StateSerdes
Serialize the given value.
read() - Method in class org.apache.kafka.streams.state.internals.OffsetCheckpoint
 
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.
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 Implementations should be thread-safe as concurrent reads and writes are expected.
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(MetricConfig, double, long) - Method in class org.apache.kafka.streams.processor.internals.metrics.CumulativeCount
 
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(String, LogContext, ProductionExceptionHandler, Sensor) - 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.state.internals.ContextualRecord
 
RecordContext - Interface in org.apache.kafka.streams.processor
The context associated with the current record being processed by an Processor
RecordInfo() - Constructor for class org.apache.kafka.streams.processor.internals.PartitionGroup.RecordInfo
 
recordLatency(Sensor, long, long) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
recordLatency(Sensor, long, long) - Method in interface org.apache.kafka.streams.StreamsMetrics
Record the given latency value of the sensor.
recordLatenessSensor(InternalProcessorContext) - Static method in class org.apache.kafka.streams.kstream.internals.metrics.Sensors
 
RecordQueue - Class in org.apache.kafka.streams.processor.internals
RecordQueue is a FIFO queue of StampedRecord (ConsumerRecord + timestamp).
recordThroughput(Sensor, long) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
recordThroughput(Sensor, long) - Method in interface org.apache.kafka.streams.StreamsMetrics
Record the throughput value of a sensor.
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 values of this stream by the grouped key into SessionWindows.
reduce(Reducer<V>) - Method in interface org.apache.kafka.streams.kstream.TimeWindowedKStream
Combine the values of records in this stream by the grouped key.
reduce(Reducer<V>, 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 values of this stream by the grouped key into SessionWindows.
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.
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.
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(StateRestorer) - Method in interface org.apache.kafka.streams.processor.internals.ChangelogReader
Register a state store and it's partition for later restoration.
register(StateRestorer) - Method in class org.apache.kafka.streams.processor.internals.StoreChangelogReader
 
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.GlobalStateManagerImpl
 
register(StateStore, StateRestoreCallback) - Method in class org.apache.kafka.streams.processor.internals.ProcessorStateManager
 
register(StateStore, StateRestoreCallback) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
Registers and possibly restores the specified storage engine.
reinitializeStateStoresForPartitions(Collection<TopicPartition>, InternalProcessorContext) - Method in class org.apache.kafka.streams.processor.internals.GlobalStateManagerImpl
 
reinitializeStateStoresForPartitions(Collection<TopicPartition>, InternalProcessorContext) - Method in class org.apache.kafka.streams.processor.internals.ProcessorStateManager
 
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 class org.apache.kafka.streams.state.internals.RocksDBSessionStore
 
remove(Windowed<K>) - Method in interface org.apache.kafka.streams.state.SessionStore
Remove the session aggregated with provided Windowed key from the store
removeAllCacheLevelSensors(String, String) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
removeAllNodeLevelSensors(String, String) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
removeAllStoreLevelSensors(String, String) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
removeAllTaskLevelSensors(String) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
removeAllThreadLevelSensors() - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
removeChild(StreamsGraphNode) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
removed(K) - Method in class org.apache.kafka.streams.state.internals.InMemoryKeyValueLoggedStore
Called when the underlying InMemoryKeyValueLoggedStore.inner KeyValueStore removes an entry in response to a call from this store.
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.
repartitionRequired() - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
repartitionSourceTopics - Variable in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopicsInfo
 
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.
RepartitionTopicConfig(String, Map<String, String>) - Constructor for class org.apache.kafka.streams.processor.internals.RepartitionTopicConfig
 
REPLICATION_FACTOR_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
replication.factor
REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
request.timeout.ms
reset() - Method in interface org.apache.kafka.streams.processor.internals.ChangelogReader
 
reset() - Method in class org.apache.kafka.streams.processor.internals.StoreChangelogReader
 
resetPolicy - Variable in class org.apache.kafka.streams.kstream.Consumed
 
restore(byte[], byte[]) - Method in class org.apache.kafka.streams.processor.AbstractNotifyingBatchingRestoreCallback
Single put restore operations not supported, please use AbstractNotifyingRestoreCallback or StateRestoreCallback instead for single action restores.
restore(byte[], byte[]) - Method in class org.apache.kafka.streams.processor.internals.CompositeRestoreListener
 
restore(byte[], byte[]) - Method in interface org.apache.kafka.streams.processor.internals.RecordBatchingStateRestoreCallback
 
restore(byte[], byte[]) - Method in interface org.apache.kafka.streams.processor.StateRestoreCallback
 
restore(RestoringTasks) - Method in interface org.apache.kafka.streams.processor.internals.ChangelogReader
Restore all registered state stores by reading from their changelogs.
restore(RestoringTasks) - Method in class org.apache.kafka.streams.processor.internals.StoreChangelogReader
 
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 class org.apache.kafka.streams.processor.internals.CompositeRestoreListener
 
restoreAll(Collection<KeyValue<byte[], byte[]>>) - Method in interface org.apache.kafka.streams.processor.internals.RecordBatchingStateRestoreCallback
 
restoreBatch(Collection<ConsumerRecord<byte[], byte[]>>) - Method in class org.apache.kafka.streams.processor.internals.CompositeRestoreListener
 
restoreBatch(Collection<ConsumerRecord<byte[], byte[]>>) - Method in interface org.apache.kafka.streams.processor.internals.RecordBatchingStateRestoreCallback
 
restoreConsumerPrefix(String) - Static method in class org.apache.kafka.streams.StreamsConfig
restoredOffsets() - Method in interface org.apache.kafka.streams.processor.internals.ChangelogReader
 
restoredOffsets() - Method in class org.apache.kafka.streams.processor.internals.StoreChangelogReader
 
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
- update offset limits
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.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.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.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
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.
RocksDbKeyValueBytesStoreSupplier - Class in org.apache.kafka.streams.state.internals
 
RocksDbKeyValueBytesStoreSupplier(String) - Constructor for class org.apache.kafka.streams.state.internals.RocksDbKeyValueBytesStoreSupplier
 
RocksDbSessionBytesStoreSupplier - Class in org.apache.kafka.streams.state.internals
 
RocksDbSessionBytesStoreSupplier(String, long) - Constructor for class org.apache.kafka.streams.state.internals.RocksDbSessionBytesStoreSupplier
 
RocksDBSessionStore<K,​AGG> - 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.
RocksDbWindowBytesStoreSupplier - Class in org.apache.kafka.streams.state.internals
 
RocksDbWindowBytesStoreSupplier(String, long, long, long, boolean) - Constructor for class org.apache.kafka.streams.state.internals.RocksDbWindowBytesStoreSupplier
 
RocksDBWindowStore<K,​V> - Class in org.apache.kafka.streams.state.internals
 
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
 
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
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
 

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
 
SECURITY_PROTOCOL_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
security.protocol
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.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.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, 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, long, long) - Method in class org.apache.kafka.streams.state.internals.SessionKeySchema
 
segmentsToSearch(Segments, 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.
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
Sensors - Class in org.apache.kafka.streams.kstream.internals.metrics
 
Sensors - Class in org.apache.kafka.streams.state.internals.metrics
 
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
 
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 {@link org.apache.kafka.streams.kstream.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.
 
serializer() - Method in class org.apache.kafka.streams.kstream.internals.FullChangeSerde
 
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).
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.
setApplicationIdAndInternalStream(String, String, String) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
setAssignmentMetadata(Map<TaskId, Set<TopicPartition>>, Map<TaskId, Set<TopicPartition>>) - Method in class org.apache.kafka.streams.processor.internals.TaskManager
 
setBuildPriority(int) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
setClusterMetadata(Cluster) - Method in class org.apache.kafka.streams.processor.internals.TaskManager
 
setConfig(String, Options, Map<String, Object>) - Method in interface org.apache.kafka.streams.state.RocksDBConfigSetter
Set the rocks db options for the provided storeName.
setCurrentNode(ProcessorNode) - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
setCurrentNode(ProcessorNode) - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
 
setDefaultStream(String) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
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
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.
setHasWrittenToTopology(boolean) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
setInner(Deserializer<T>) - Method in class org.apache.kafka.streams.kstream.internals.ChangedDeserializer
 
setInner(Serializer<T>) - Method in class org.apache.kafka.streams.kstream.internals.ChangedSerializer
 
setMergeNode(boolean) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
setPartitionsByHostState(Map<HostInfo, Set<TopicPartition>>) - Method in class org.apache.kafka.streams.processor.internals.TaskManager
 
setRecordContext(ProcessorRecordContext) - Method in class org.apache.kafka.streams.processor.internals.AbstractProcessorContext
 
setRecordContext(ProcessorRecordContext) - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
 
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.
setTimestamp(long) - Method in class org.apache.kafka.streams.processor.internals.ProcessorRecordContext
 
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.
setValueChangingOperation(boolean) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamsGraphNode
 
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 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) - Constructor for class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.Sink
 
sinkName - Variable in class org.apache.kafka.streams.kstream.internals.graph.BaseRepartitionNode
 
SinkNode<K,​V> - Class in org.apache.kafka.streams.processor.internals
 
sinks() - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
sinkTopics - Variable in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.TopicsInfo
 
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
 
sizeBytes() - Method in class org.apache.kafka.streams.processor.internals.ProcessorRecordContext
 
sizeBytes() - Method in class org.apache.kafka.streams.state.internals.ContextualRecord
 
sizeMs - Variable in class org.apache.kafka.streams.kstream.TimeWindows
The size of the windows in milliseconds.
skippedRecordsSensor() - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
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
 
SourceNode<K,​V> - Class in org.apache.kafka.streams.processor.internals
 
SourceNode(String, List<String>, Deserializer<K>, Deserializer<V>) - Constructor for class org.apache.kafka.streams.processor.internals.SourceNode
 
SourceNode(String, List<String>, TimestampExtractor, Deserializer<K>, Deserializer<V>) - Constructor for class org.apache.kafka.streams.processor.internals.SourceNode
 
sourceNodes - Variable in class org.apache.kafka.streams.kstream.internals.AbstractStream
 
sources() - Method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
sourceTopicPattern() - 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
 
SPILL_TO_DISK - org.apache.kafka.streams.kstream.internals.suppress.BufferFullStrategy
 
Stamped<V> - Class in org.apache.kafka.streams.processor.internals
 
Stamped(V, long) - Constructor for class org.apache.kafka.streams.processor.internals.Stamped
 
StampedRecord - Class in org.apache.kafka.streams.processor.internals
 
StampedRecord(ConsumerRecord<Object, Object>, long) - Constructor for class org.apache.kafka.streams.processor.internals.StampedRecord
 
StandbyTask - Class in org.apache.kafka.streams.processor.internals
A StandbyTask
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
 
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
 
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.GlobalStreamThread
 
state() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
 
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
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 - 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) - 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.
StatefulProcessorNode<K,​V> - Class in org.apache.kafka.streams.kstream.internals.graph
 
StatefulProcessorNode(String, ProcessorParameters<K, V>, String[], boolean) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.StatefulProcessorNode
Create a node representing a stateful processor, where the named store has already been registered.
StatefulProcessorNode(String, ProcessorParameters<K, V>, StoreBuilder<? extends StateStore>, boolean) - 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.
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.
StateRestorer - Class in org.apache.kafka.streams.processor.internals
 
StateSerdes<K,​V> - Class in org.apache.kafka.streams.state
Factory for creating serializers / deserializers for state stores in Kafka Streams.
StateSerdes(String, Serde<K>, Serde<V>) - Constructor for class org.apache.kafka.streams.state.StateSerdes
Create a context for serialization using the specified serializers and deserializers which must match the key and value types used as parameters for this object; the state changelog topic is provided to bind this serde factory to, so that future calls for serialize / deserialize do not need to provide the topic name any more.
StateStore - Interface in org.apache.kafka.streams.processor
A storage engine for managing state maintained by a stream processor.
stateStoreNames() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
stateStoreNameToSourceTopics() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
StateStoreNode - Class in org.apache.kafka.streams.kstream.internals.graph
 
StateStoreNode(StoreBuilder) - 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.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
 
StickyTaskAssignor<ID> - Class in org.apache.kafka.streams.processor.internals.assignment
 
StickyTaskAssignor(Map<ID, ClientState>, Set<TaskId>) - 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
Get a facade wrapping the local StateStore instances with the provided storeName if the Store's type is accepted by the provided queryableStoreType.
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
 
StoreChangelogReader(Consumer<byte[], byte[]>, Duration, StateRestoreListener, LogContext, String) - 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, Sensor.RecordingLevel, Sensor...) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
storeName - Variable in class org.apache.kafka.streams.kstream.internals.KTableSource
 
storeName - Variable in class org.apache.kafka.streams.kstream.Materialized
 
storeName() - Method in class org.apache.kafka.streams.kstream.internals.MaterializedInternal
 
storeName() - Method in class org.apache.kafka.streams.processor.internals.StateRestorer
 
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
 
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.StreamThreadStateStoreProvider
 
stores(String, QueryableStoreType<T>) - Method in class org.apache.kafka.streams.state.internals.WrappingStoreProvider
Provides access to StateStores accepted by QueryableStoreType.accepts(StateStore)
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 topics.
stream(String, Consumed<K, V>) - Method in class org.apache.kafka.streams.StreamsBuilder
Create a KStream from the specified topics.
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
 
streamExists(String) - Static method in class org.apache.kafka.streams.mapr.Utils
Deprecated.
streamPartitioner() - Method in class org.apache.kafka.streams.kstream.internals.ProducedInternal
 
streamPartitioner(StreamPartitioner<? super K, ? super V>) - Static method in class org.apache.kafka.streams.kstream.Produced
Create a Produced instance with provided partitioner.
StreamPartitioner<K,​V> - Interface in org.apache.kafka.streams.processor
Determine how records are distributed among the partitions in a Kafka topic.
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.
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, boolean) - 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>) - Constructor for class org.apache.kafka.streams.state.StreamsMetadata
 
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) - Constructor for class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
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
 
StreamsPartitionAssignor.Error - Enum 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, Collection<TopicPartition>, ProcessorTopology, Consumer<byte[], byte[]>, ChangelogReader, StreamsConfig, StreamsMetricsImpl, StateDirectory, ThreadCache, Time, StreamTask.ProducerSupplier, Sensor) - Constructor for class org.apache.kafka.streams.processor.internals.StreamTask
 
StreamTask(TaskId, Collection<TopicPartition>, ProcessorTopology, Consumer<byte[], byte[]>, ChangelogReader, StreamsConfig, StreamsMetricsImpl, StateDirectory, ThreadCache, Time, StreamTask.ProducerSupplier, RecordCollector, Sensor) - Constructor for class org.apache.kafka.streams.processor.internals.StreamTask
 
StreamTask.ProducerSupplier - Interface in org.apache.kafka.streams.processor.internals
 
StreamTask.TaskMetrics - Class in org.apache.kafka.streams.processor.internals
 
StreamThread - Class in org.apache.kafka.streams.processor.internals
 
StreamThread(Time, StreamsConfig, Producer<byte[], byte[]>, Consumer<byte[], byte[]>, Consumer<byte[], byte[]>, String, TaskManager, StreamThread.StreamsMetricsThreadImpl, InternalTopologyBuilder, String, LogContext, AtomicInteger) - Constructor for class org.apache.kafka.streams.processor.internals.StreamThread
 
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
Wrapper over StreamThread that implements StateStoreProvider
StreamThreadStateStoreProvider(StreamThread) - Constructor for class org.apache.kafka.streams.state.internals.StreamThreadStateStoreProvider
 
streamTime() - Method in class org.apache.kafka.streams.processor.internals.GlobalProcessorContextImpl
 
streamTime() - Method in interface org.apache.kafka.streams.processor.internals.InternalProcessorContext
 
streamTime() - Method in class org.apache.kafka.streams.processor.internals.ProcessorContextImpl
 
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
 
subscription(Set<String>) - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
SubscriptionInfo - Class in org.apache.kafka.streams.processor.internals.assignment
 
SubscriptionInfo(int, int, UUID, Set<TaskId>, Set<TaskId>, String) - Constructor for class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
SubscriptionInfo(int, UUID, Set<TaskId>, Set<TaskId>, String) - Constructor for class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
SubscriptionInfo(UUID, Set<TaskId>, Set<TaskId>, String) - Constructor for class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
subscriptionUpdates() - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
SubscriptionUpdates() - Constructor for class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder.SubscriptionUpdates
 
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
 
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.
supportedVersions - Variable 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.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
 
suspend() - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
- flush store - checkpoint store
suspend() - Method in class org.apache.kafka.streams.processor.internals.StreamTask
- close topology - StreamTask.commit() - flush state and producer - if (!eos) write checkpoint - commit offsets
suspend() - Method in interface org.apache.kafka.streams.processor.internals.Task
 

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.
TableProcessorNode<K,​V,​S extends StateStore> - Class in org.apache.kafka.streams.kstream.internals.graph
 
TableProcessorNode(String, ProcessorParameters<K, V>, MaterializedInternal<K, V, S>, String[]) - Constructor for class org.apache.kafka.streams.kstream.internals.graph.TableProcessorNode
 
TableSourceNode<K,​V,​S extends StateStore> - Class in org.apache.kafka.streams.kstream.internals.graph
Used to represent either a KTable source or a GlobalKTable source.
TableSourceNode.TableSourceNodeBuilder<K,​V,​S extends StateStore> - Class in org.apache.kafka.streams.kstream.internals.graph
 
tableSourceNodeBuilder() - Static method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode
 
tagMap(String...) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
Task - Interface in org.apache.kafka.streams.processor.internals
 
TASK_MANAGER_FOR_PARTITION_ASSIGNOR - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
 
TaskAssignmentException - Exception in org.apache.kafka.streams.errors
Indicates a run time error incurred while trying to assign stream tasks to threads.
TaskAssignmentException(String) - Constructor for exception org.apache.kafka.streams.errors.TaskAssignmentException
 
TaskAssignmentException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskAssignmentException
 
TaskAssignmentException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskAssignmentException
 
TaskAssignor<C,​T extends java.lang.Comparable<T>> - Interface in org.apache.kafka.streams.processor.internals.assignment
 
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 - Class in org.apache.kafka.streams.processor
The task ID representation composed as topic group ID plus the assigned partition ID.
TaskId(int, int) - Constructor for class org.apache.kafka.streams.processor.TaskId
 
TaskIdFormatException - Exception in org.apache.kafka.streams.errors
Indicates a run time error incurred while trying parse the task id from the read string.
TaskIdFormatException(String) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
 
TaskIdFormatException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
 
TaskIdFormatException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskIdFormatException
 
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, Sensor.RecordingLevel, Sensor...) - Method in class org.apache.kafka.streams.processor.internals.metrics.StreamsMetricsImpl
 
TaskManager - Class in org.apache.kafka.streams.processor.internals
 
taskManger() - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
TaskMetadata - Class in org.apache.kafka.streams.processor
Represents the state of a single task running within a KafkaStreams application.
TaskMetadata(String, Set<TopicPartition>) - Constructor for class org.apache.kafka.streams.processor.TaskMetadata
 
TaskMigratedException - Exception in org.apache.kafka.streams.errors
Indicates that a task got migrated to another thread.
TaskMigratedException() - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
 
TaskMigratedException(Task) - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
 
TaskMigratedException(Task, Throwable) - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
 
TaskMigratedException(Task, TopicPartition, long, long) - Constructor for exception org.apache.kafka.streams.errors.TaskMigratedException
 
tasks() - Method in class org.apache.kafka.streams.processor.internals.StreamThread
 
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.
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
 
threadLevelSensor(String, Sensor.RecordingLevel, Sensor...) - 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, Set<TaskMetadata>, Set<TaskMetadata>) - Constructor for class org.apache.kafka.streams.processor.ThreadMetadata
 
threadName() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
threads - Variable in class org.apache.kafka.streams.KafkaStreams
 
threadState() - Method in class org.apache.kafka.streams.processor.ThreadMetadata
 
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
 
through(String) - Method in interface org.apache.kafka.streams.kstream.KStream
Materialize this stream to a topic and creates a new KStream from the topic using default serializers, deserializers, and producer's DefaultPartitioner.
through(String, Produced<K, V>) - Method in class org.apache.kafka.streams.kstream.internals.KStreamImpl
 
through(String, Produced<K, V>) - Method in interface org.apache.kafka.streams.kstream.KStream
Materialize this stream to a topic and creates a new KStream from the topic using the Produced instance for configuration of the key serde, value serde, and StreamPartitioner.
time - Variable in class org.apache.kafka.streams.state.internals.MeteredKeyValueStore
 
TimeOrderedKeyValueBuffer - Interface 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.PartitionGroup
Return the timestamp of this partition group as the smallest partition timestamp among all its partitions
timestamp() - Method in class org.apache.kafka.streams.processor.internals.ProcessorRecordContext
 
timestamp() - Method in class org.apache.kafka.streams.processor.internals.RecordQueue
Returns the tracked partition timestamp
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
 
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.
TimestampSupplier - Interface in org.apache.kafka.streams.processor.internals
 
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).
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
 
timeWindowedSerdeFrom(Class<T>) - Static method in class org.apache.kafka.streams.kstream.WindowedSerdes
Construct a TimeWindowedSerde object for the specified inner class type.
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
 
timeWindowForSize(long, long) - Static method in class org.apache.kafka.streams.state.internals.WindowKeySchema
Safely construct a time window of the given size, taking care of bounding endMs to Long.MAX_VALUE if necessary
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(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.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_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.
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.
topicPartitions() - Method in class org.apache.kafka.streams.processor.TaskMetadata
 
topicPartitions() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
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() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
topology() - Method in interface org.apache.kafka.streams.processor.internals.Task
 
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 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.
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.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.TableProcessorNode
 
toString() - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode
 
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.TimeWindows
 
toString() - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
 
toString() - Method in class org.apache.kafka.streams.kstream.Window
 
toString() - Method in class org.apache.kafka.streams.kstream.Windowed
 
toString() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
Produces a string representation containing useful information about a Task.
toString() - Method in class org.apache.kafka.streams.processor.internals.assignment.AssignmentInfo
 
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.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.SubscriptionUpdates
 
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.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.StaticTopicNameExtractor
 
toString() - Method in class org.apache.kafka.streams.processor.internals.StreamsMetadataState
 
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.OffsetCheckpoint
 
toString() - Method in class org.apache.kafka.streams.state.StreamsMetadata
 
toString(String) - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
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.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.SourceNode
 
toString(String) - Method in class org.apache.kafka.streams.processor.internals.StreamsMetadataState
 
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 interface org.apache.kafka.streams.processor.internals.Task
 
toString(String) - Method in class org.apache.kafka.streams.processor.internals.TaskManager
 
toSysOut() - Static method in class org.apache.kafka.streams.kstream.Printed
Print the records of a KStream to system out.
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 more records 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(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.
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 possible 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 possible 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.

U

unbounded() - Static method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
Create a buffer unconstrained by size (either keys or bytes).
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
unite(T, T...) - Method in class org.apache.kafka.streams.processor.internals.QuickUnion
 
UNKNOWN_HOST - Static variable in class org.apache.kafka.streams.processor.internals.StreamsMetadataState
 
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.
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.
UnwindowedChangelogTopicConfig(String, Map<String, String>) - Constructor for class org.apache.kafka.streams.processor.internals.UnwindowedChangelogTopicConfig
 
update(ConsumerRecord<byte[], byte[]>) - Method in class org.apache.kafka.streams.processor.internals.GlobalStateUpdateTask
 
update(TopicPartition, List<ConsumerRecord<byte[], byte[]>>) - Method in class org.apache.kafka.streams.processor.internals.StandbyTask
Updates a state store using records from one change log partition
update(To) - Method in class org.apache.kafka.streams.processor.internals.ToInternal
 
update(To) - Method in class org.apache.kafka.streams.processor.To
 
updateOffsetLimits() - Method in class org.apache.kafka.streams.processor.internals.AbstractTask
 
updateSubscribedTopics(Set<String>, String) - Method in class org.apache.kafka.streams.processor.internals.InternalTopologyBuilder
 
updateSubscriptionsFromAssignment(List<TopicPartition>) - Method in class org.apache.kafka.streams.processor.internals.TaskManager
 
updateSubscriptionsFromMetadata(Set<String>) - Method in class org.apache.kafka.streams.processor.internals.TaskManager
 
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_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
 
usedSubscriptionMetadataVersion - Variable in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
UsePreviousTimeOnInvalidTimestamp - Class in org.apache.kafka.streams.processor
Retrieves embedded metadata timestamps from Kafka messages.
UsePreviousTimeOnInvalidTimestamp() - Constructor for class org.apache.kafka.streams.processor.UsePreviousTimeOnInvalidTimestamp
 
userEndPoint() - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
userEndPoint() - Method in class org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor
 
Utils - Class in org.apache.kafka.streams.mapr
Deprecated.
- use mapr-eco-tools utils instead
Utils() - Constructor for class org.apache.kafka.streams.mapr.Utils
Deprecated.
 

V

validateDirectoryPerms(FileSystem, String, String, String) - Static method in class org.apache.kafka.streams.mapr.Utils
Deprecated.
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() - Method in class org.apache.kafka.streams.processor.internals.StampedRecord
 
value() - Method in class org.apache.kafka.streams.state.internals.ContextualRecord
 
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.
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.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.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.StreamsPartitionAssignor.Error
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.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.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.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.StreamsPartitionAssignor.Error
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.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
 
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.Serialized
Deprecated.
 
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.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.MaterializedInternal
 
valueSerde() - Method in class org.apache.kafka.streams.kstream.internals.ProducedInternal
 
valueSerde() - Method in class org.apache.kafka.streams.kstream.internals.SerializedInternal
Deprecated.
 
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() - 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.processor.internals.assignment.AssignmentInfo
 
version() - Method in class org.apache.kafka.streams.processor.internals.assignment.SubscriptionInfo
 
VERSION_PROBING - org.apache.kafka.streams.processor.internals.StreamsPartitionAssignor.Error
 
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 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
 

W

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
 
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 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.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.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.
WindowedChangelogTopicConfig(String, Map<String, String>) - Constructor for class org.apache.kafka.streams.processor.internals.WindowedChangelogTopicConfig
 
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.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
A windowed store interface extending StateStore.
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, 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(List<ProcessorNode>, Map<String, SourceNode>, List<StateStore>, Map<String, String>) - Static method in class org.apache.kafka.streams.processor.internals.ProcessorTopology
 
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.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(TimestampExtractor) - Static method in class org.apache.kafka.streams.kstream.Consumed
Create an instance of Consumed with a TimestampExtractor.
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) - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode.TableSourceNodeBuilder
 
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.KTableKTableJoinNode.KTableKTableJoinNodeBuilder
 
withJoinMergeProcessorParameters(ProcessorParameters<K, VR>) - Method in class org.apache.kafka.streams.kstream.internals.graph.StreamStreamJoinNode.StreamStreamJoinNodeBuilder
 
withJoinOtherProcessorParameters(ProcessorParameters<K, 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, 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.GroupedTableOperationRepartitionNode.GroupedTableOperationRepartitionNodeBuilder
 
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.internals.graph.OptimizableRepartitionNode.OptimizableRepartitionNodeBuilder
 
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Joined
Set the key Serde to be used.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Materialized
Set the keySerde the materialize StateStore will use.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Produced
Produce records using the provided keySerde.
withKeySerde(Serde<K>) - Method in class org.apache.kafka.streams.kstream.Serialized
Deprecated.
Construct a Serialized instance with the provided key Serde.
withKeyValueMapper(KeyValueMapper<? super K, ? super V, String>) - Method in class org.apache.kafka.streams.kstream.Printed
Print the records of a KStream with the provided KeyValueMapper The provided KeyValueMapper's mapped value type must be String.
withLabel(String) - Method in class org.apache.kafka.streams.kstream.Printed
Print the records of a KStream with the provided label.
withLoggingDisabled() - Method in class org.apache.kafka.streams.kstream.Materialized
Disable change logging for the materialized StateStore.
withLoggingDisabled() - Method in class org.apache.kafka.streams.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.Materialized
Indicates that a changelog should be created for the store.
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) - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode.KTableKTableJoinNodeBuilder
 
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.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.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 interface org.apache.kafka.streams.kstream.Suppressed
Use the specified name for the suppression node in the topology.
withNoBound() - Method in interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig
Set the buffer to be unconstrained by size (either keys or bytes).
withNodeName(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.GroupedTableOperationRepartitionNode.GroupedTableOperationRepartitionNodeBuilder
 
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.OptimizableRepartitionNode.OptimizableRepartitionNodeBuilder
 
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
 
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
 
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
 
withProcessorParameters(ProcessorParameters) - Method in class org.apache.kafka.streams.kstream.internals.graph.GroupedTableOperationRepartitionNode.GroupedTableOperationRepartitionNodeBuilder
 
withProcessorParameters(ProcessorParameters) - Method in class org.apache.kafka.streams.kstream.internals.graph.OptimizableRepartitionNode.OptimizableRepartitionNodeBuilder
 
withProcessorParameters(ProcessorParameters<K, V>) - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode.TableSourceNodeBuilder
 
withRepartitionTopic(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.GroupedTableOperationRepartitionNode.GroupedTableOperationRepartitionNodeBuilder
 
withRepartitionTopic(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.OptimizableRepartitionNode.OptimizableRepartitionNodeBuilder
 
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.GroupedTableOperationRepartitionNode.GroupedTableOperationRepartitionNodeBuilder
 
withSinkName(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.OptimizableRepartitionNode.OptimizableRepartitionNodeBuilder
 
withSourceName(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.GroupedTableOperationRepartitionNode.GroupedTableOperationRepartitionNodeBuilder
 
withSourceName(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.OptimizableRepartitionNode.OptimizableRepartitionNodeBuilder
 
withSourceName(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode.TableSourceNodeBuilder
 
withStoreBuilder(StoreBuilder<S>) - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode.TableSourceNodeBuilder
 
withStreamPartitioner(StreamPartitioner<? super K, ? super V>) - Method in class org.apache.kafka.streams.kstream.Produced
Produce records using the provided partitioner.
withThisJoinSideNodeName(String) - Method in class org.apache.kafka.streams.kstream.internals.graph.KTableKTableJoinNode.KTableKTableJoinNodeBuilder
 
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.KTableKTableJoinNode.KTableKTableJoinNodeBuilder
 
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.GroupedTableOperationRepartitionNode.GroupedTableOperationRepartitionNodeBuilder
 
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.internals.graph.OptimizableRepartitionNode.OptimizableRepartitionNodeBuilder
 
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Joined
Set the value Serde to be used.
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Materialized
Set the valueSerde the materialized StateStore will use.
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Produced
Produce records using the provided valueSerde.
withValueSerde(Serde<V>) - Method in class org.apache.kafka.streams.kstream.Serialized
Deprecated.
Construct a Serialized instance with the provided value Serde.
WrappedStateStore - Interface in org.apache.kafka.streams.state.internals
A storage engine wrapper for utilities like logging, caching, and metering.
WrappedStateStore.AbstractStateStore - Class in org.apache.kafka.streams.state.internals
 
wrappedStore() - Method in class org.apache.kafka.streams.state.internals.WrappedStateStore.AbstractStateStore
 
wrappedStore() - Method in interface org.apache.kafka.streams.state.internals.WrappedStateStore
Return the state store this store directly wraps
WrappingStoreProvider - Class in org.apache.kafka.streams.state.internals
Provides a wrapper over multiple underlying StateStoreProviders
WrappingStoreProvider(List<StateStoreProvider>) - Constructor for class org.apache.kafka.streams.state.internals.WrappingStoreProvider
 
write(Map<TopicPartition, Long>) - Method in class org.apache.kafka.streams.state.internals.OffsetCheckpoint
 
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.TableProcessorNode
 
writeToTopology(InternalTopologyBuilder) - Method in class org.apache.kafka.streams.kstream.internals.graph.TableSourceNode
 
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