- AbstractProcessor<K,V> - Class in org.apache.kafka.streams.processor
-
- AbstractProcessor() - Constructor for class org.apache.kafka.streams.processor.AbstractProcessor
-
- addInternalTopic(String) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
-
Adds an internal topic
- addLatencySensor(String, String, String, String...) - Method in interface org.apache.kafka.streams.StreamsMetrics
-
- addProcessor(String, ProcessorSupplier, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
-
Add a new processor node that receives and processes messages output by one or more parent source or processor node.
- addSink(String, String, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
-
Add a new sink that forwards messages from upstream parent processor and/or source nodes to the named Kafka topic.
- addSink(String, String, StreamPartitioner, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
-
Add a new sink that forwards messages from upstream parent processor and/or source nodes to the named Kafka topic, using
the supplied partitioner.
- addSink(String, String, Serializer, Serializer, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
-
Add a new sink that forwards messages from upstream parent processor and/or source nodes to the named Kafka topic.
- addSink(String, String, Serializer<K>, Serializer<V>, StreamPartitioner<K, V>, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
-
Add a new sink that forwards messages from upstream parent processor and/or source nodes to the named Kafka topic.
- addSource(String, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
-
Add a new source that consumes the named topics and forwards the messages to child processor and/or sink nodes.
- addSource(String, Deserializer, Deserializer, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
-
Add a new source that consumes the named topics and forwards the messages to child processor and/or sink nodes.
- addStateStore(StateStoreSupplier, boolean, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
-
Adds a state store
- addStateStore(StateStoreSupplier, String...) - Method in class org.apache.kafka.streams.processor.TopologyBuilder
-
Adds a state store
- after - Variable in class org.apache.kafka.streams.kstream.JoinWindows
-
- after(long) - Method in class org.apache.kafka.streams.kstream.JoinWindows
-
Specifies that records of the same key are joinable if their timestamp stamps are within
timeDifference, and if the timestamp of a record from the secondary stream is
is later than or equal to the timestamp of a record from the first stream.
- aggregate(Initializer<T>, Aggregator<K1, V1, T>, Aggregator<K1, V1, T>, KeyValueMapper<K, V, KeyValue<K1, V1>>, Serializer<K1>, Serializer<V1>, Serializer<T>, Deserializer<K1>, Deserializer<V1>, Deserializer<T>, String) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Aggregate values of this table by the selected key.
- aggregateByKey(Initializer<T>, Aggregator<K, V, T>, Windows<W>, Serializer<K>, Serializer<T>, Deserializer<K>, Deserializer<T>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Aggregate values of this stream by key on a window basis.
- aggregateByKey(Initializer<T>, Aggregator<K, V, T>, Serializer<K>, Serializer<T>, Deserializer<K>, Deserializer<T>, String) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Aggregate values of this stream by key without a window basis, and hence
return an ever updating table
- Aggregator<K,V,T> - Interface in org.apache.kafka.streams.kstream
-
The Aggregator interface for aggregating values of the given key.
- all() - Method in interface org.apache.kafka.streams.state.KeyValueStore
-
Return an iterator over all keys in the database.
- apply(K, V, T) - Method in interface org.apache.kafka.streams.kstream.Aggregator
-
- apply() - Method in interface org.apache.kafka.streams.kstream.Initializer
-
- apply(K, V) - Method in interface org.apache.kafka.streams.kstream.KeyValueMapper
-
- apply(V, V) - Method in interface org.apache.kafka.streams.kstream.Reducer
-
- apply(V1, V2) - Method in interface org.apache.kafka.streams.kstream.ValueJoiner
-
- apply(V1) - Method in interface org.apache.kafka.streams.kstream.ValueMapper
-
- AUTO_OFFSET_RESET_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
auto.offset.reset
- pair(K, V) - Static method in class org.apache.kafka.streams.KeyValue
-
- parse(String) - Static method in class org.apache.kafka.streams.processor.TaskId
-
- partition() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Returns the partition id of the current input record
- partition(K, V, int) - Method in interface org.apache.kafka.streams.processor.StreamPartitioner
-
Determine the partition number for a message with the given key and value and the current number of partitions.
- partition - Variable in class org.apache.kafka.streams.processor.TaskId
-
- PARTITION_GROUPER_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
partition.grouper
- 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.
- period - Variable in class org.apache.kafka.streams.kstream.HoppingWindows
-
- persistent() - Method in interface org.apache.kafka.streams.processor.StateStore
-
If the storage is persistent
- persistent() - Method in interface org.apache.kafka.streams.state.Stores.KeyValueFactory
-
Keep all key-value entries off-heap in a local database, although for durability all entries are recorded in a Kafka
topic that can be read to restore the entries if they are lost.
- POLL_MS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
poll.ms
- Predicate<K,V> - Interface in org.apache.kafka.streams.kstream
-
The Predicate interface represents a predicate (boolean-valued function) of a key-value pair.
- process(ProcessorSupplier<K, V>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Processes all elements in this stream by applying a processor.
- process(K, V) - Method in interface org.apache.kafka.streams.processor.Processor
-
Process the message with the given key and value.
- Processor<K,V> - Interface in org.apache.kafka.streams.processor
-
A processor of key-value pair records.
- ProcessorContext - Interface in org.apache.kafka.streams.processor
-
Processor context interface.
- ProcessorStateException - Exception in org.apache.kafka.streams.errors
-
Indicates a processor state operation (e.g.
- ProcessorStateException(String) - Constructor for exception org.apache.kafka.streams.errors.ProcessorStateException
-
- ProcessorStateException(String, Throwable) - Constructor for exception org.apache.kafka.streams.errors.ProcessorStateException
-
- ProcessorStateException(Throwable) - Constructor for exception org.apache.kafka.streams.errors.ProcessorStateException
-
- ProcessorSupplier<K,V> - Interface in org.apache.kafka.streams.processor
-
A processor supplier that can create one or more
Processor
instances.
- punctuate(long) - Method in interface org.apache.kafka.streams.kstream.Transformer
-
- punctuate(long) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
-
- punctuate(long) - Method in class org.apache.kafka.streams.processor.AbstractProcessor
-
- punctuate(long) - Method in interface org.apache.kafka.streams.processor.Processor
-
- 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
-
Put a key-value pair with the current wall-clock time as the timestamp
into the corresponding window
- 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
- putAll(List<KeyValue<K, V>>) - Method in interface org.apache.kafka.streams.state.KeyValueStore
-
Update all the given key/value pairs
- schedule(long) - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Schedules a periodic operation for processors.
- segments - Variable in class org.apache.kafka.streams.kstream.Windows
-
- segments(int) - Method in class org.apache.kafka.streams.kstream.Windows
-
Specifies the number of segments to be used for rolling the window store,
this function is not exposed to users but can be called by developers that extend this JoinWindows specs
- SEQNUM_SIZE - Static variable in class org.apache.kafka.streams.state.WindowStoreUtils
-
- Serdes<K,V> - Class in org.apache.kafka.streams.state
-
Factory for creating serializers / deserializers for state stores in Kafka Streams.
- Serdes(String, Serializer<K>, Deserializer<K>, Serializer<V>, Deserializer<V>) - Constructor for class org.apache.kafka.streams.state.Serdes
-
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.
- setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.kafka.streams.KafkaStreams
-
Sets the handler invoked when a stream thread abruptly terminates due to an uncaught exception.
- sinkTopics - Variable in class org.apache.kafka.streams.processor.TopologyBuilder.TopicsInfo
-
- size - Variable in class org.apache.kafka.streams.kstream.HoppingWindows
-
- size - Variable in class org.apache.kafka.streams.kstream.TumblingWindows
-
- sourceTopics() - Method in class org.apache.kafka.streams.processor.TopologyBuilder
-
Get the names of topics that are to be consumed by the source nodes created by this builder.
- sourceTopics - Variable in class org.apache.kafka.streams.processor.TopologyBuilder.TopicsInfo
-
- start() - Method in class org.apache.kafka.streams.KafkaStreams
-
Start the stream instance by starting all its threads.
- start - Variable in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
- start() - Method in class org.apache.kafka.streams.kstream.Window
-
Returns the start timestamp of this window, inclusive
- startOn(long) - Method in class org.apache.kafka.streams.kstream.UnlimitedWindows
-
- 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.TopologyBuilder.TopicsInfo
-
- stateDir() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Returns the state directory for the partition.
- StateRestoreCallback - Interface in org.apache.kafka.streams.processor
-
Restoration logic for log-backed state stores upon restart,
it takes one record at a time from the logs to apply to the restoring state.
- StateStore - Interface in org.apache.kafka.streams.processor
-
A storage engine for managing state maintained by a stream processor.
- StateStoreSupplier - Interface in org.apache.kafka.streams.processor
-
A state store supplier which can create one or more
StateStore
instances.
- Stores - Class in org.apache.kafka.streams.state
-
Factory for creating state stores in Kafka Streams.
- Stores() - Constructor for class org.apache.kafka.streams.state.Stores
-
- Stores.InMemoryKeyValueFactory<K,V> - Interface in org.apache.kafka.streams.state
-
The interface used to create in-memory key-value stores.
- Stores.KeyValueFactory<K,V> - Interface in org.apache.kafka.streams.state
-
The interface used to specify the different kinds of key-value stores.
- Stores.PersistentKeyValueFactory<K,V> - Interface in org.apache.kafka.streams.state
-
The interface used to create off-heap key-value stores that use a local database.
- Stores.StoreFactory - Class in org.apache.kafka.streams.state
-
- Stores.StoreFactory() - Constructor for class org.apache.kafka.streams.state.Stores.StoreFactory
-
- Stores.ValueFactory<K> - Class in org.apache.kafka.streams.state
-
The factory for creating off-heap key-value stores.
- Stores.ValueFactory() - Constructor for class org.apache.kafka.streams.state.Stores.ValueFactory
-
- stream(String...) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
-
Creates a KStream instance for the specified topic.
- stream(Deserializer<K>, Deserializer<V>, String...) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
-
Creates a KStream instance for the specified topic.
- STREAM_THREAD_INSTANCE - Static variable in class org.apache.kafka.streams.StreamsConfig.InternalConfig
-
- StreamPartitioner<K,V> - Interface in org.apache.kafka.streams.processor
-
Determine how messages are distributed among the partitions in a Kafka topic.
- StreamsConfig - Class in org.apache.kafka.streams
-
Configuration for Kafka Streams.
- StreamsConfig(Map<?, ?>) - Constructor for class org.apache.kafka.streams.StreamsConfig
-
- StreamsConfig.InternalConfig - Class in org.apache.kafka.streams
-
- StreamsConfig.InternalConfig() - Constructor for class org.apache.kafka.streams.StreamsConfig.InternalConfig
-
- 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
-
- StreamsMetrics - Interface in org.apache.kafka.streams
-
The Kafka Streams metrics interface for adding metric sensors and collecting metric values.
- table(String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
-
Creates a KTable instance for the specified topic.
- table(Serializer<K>, Serializer<V>, Deserializer<K>, Deserializer<V>, String) - Method in class org.apache.kafka.streams.kstream.KStreamBuilder
-
Creates a KTable instance for the specified topic.
- 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
-
- taskId() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Returns the task id
- TaskId - Class in org.apache.kafka.streams.processor
-
The task id representation composed as topic group id plus the assigned partition id.
- TaskId(int, int) - Constructor for class org.apache.kafka.streams.processor.TaskId
-
- 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
-
- test(K, V) - Method in interface org.apache.kafka.streams.kstream.Predicate
-
- through(String) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Sends key-value to a topic, also creates a new instance of KStream from the topic.
- through(String, Serializer<K>, Serializer<V>, Deserializer<K>, Deserializer<V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Sends key-value to a topic, also creates a new instance of KStream from the topic.
- through(String) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Sends key-value to a topic, also creates a new instance of KTable from the topic.
- through(String, Serializer<K>, Serializer<V>, Deserializer<K>, Deserializer<V>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Sends key-value to a topic, also creates a new instance of KTable from the topic.
- timestamp() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Returns the timestamp of the current input record.
- TIMESTAMP_EXTRACTOR_CLASS_CONFIG - Static variable in class org.apache.kafka.streams.StreamsConfig
-
timestamp.extractor
- TIMESTAMP_SIZE - Static variable in class org.apache.kafka.streams.state.WindowStoreUtils
-
- 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
.
- timestampFromBinaryKey(byte[]) - Static method in class org.apache.kafka.streams.state.WindowStoreUtils
-
- to(String) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Sends key-value to a topic using default serializers specified in the config.
- to(String, Serializer<K>, Serializer<V>) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Sends key-value to a topic.
- to(String) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Sends key-value to a topic using default serializers specified in the config.
- to(String, Serializer<K>, Serializer<V>) - Method in interface org.apache.kafka.streams.kstream.KTable
-
Sends key-value to a topic.
- toBinaryKey(K, long, int, Serdes<K, ?>) - Static method in class org.apache.kafka.streams.state.WindowStoreUtils
-
- topic() - Method in interface org.apache.kafka.streams.processor.ProcessorContext
-
Returns the topic name of the current input record
- topic() - Method in class org.apache.kafka.streams.state.Serdes
-
- topicGroupId - Variable in class org.apache.kafka.streams.processor.TaskId
-
- topicGroups() - Method in class org.apache.kafka.streams.processor.TopologyBuilder
-
Returns the map of topic groups keyed by the group id.
- TopologyBuilder - Class in org.apache.kafka.streams.processor
-
A component that is used to build a ProcessorTopology
.
- TopologyBuilder() - Constructor for class org.apache.kafka.streams.processor.TopologyBuilder
-
Create a new builder.
- TopologyBuilder.TopicsInfo - Class in org.apache.kafka.streams.processor
-
- TopologyBuilder.TopicsInfo(Set<String>, Set<String>, Set<String>, Set<String>) - Constructor for class org.apache.kafka.streams.processor.TopologyBuilder.TopicsInfo
-
- TopologyBuilderException - Exception in org.apache.kafka.streams.errors
-
Indicates a pre-run time error incurred while parsing the builder to construct the processor topology
- TopologyBuilderException(String) - Constructor for exception org.apache.kafka.streams.errors.TopologyBuilderException
-
- toStream() - Method in interface org.apache.kafka.streams.kstream.KTable
-
Creates a new instance of KStream from this KTable
- toString() - Method in class org.apache.kafka.streams.KeyValue
-
- toString() - Method in class org.apache.kafka.streams.kstream.Windowed
-
- toString() - Method in class org.apache.kafka.streams.processor.TaskId
-
- transform(TransformerSupplier<K, V, KeyValue<K1, V1>>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Applies a stateful transformation to all elements in this stream.
- transform(K, V) - Method in interface org.apache.kafka.streams.kstream.Transformer
-
Transform the message with the given key and value.
- transform(V) - Method in interface org.apache.kafka.streams.kstream.ValueTransformer
-
Transform the message with the given key and value.
- Transformer<K,V,R> - Interface in org.apache.kafka.streams.kstream
-
A stateful Transformer interface for transform a key-value pair into a new value.
- TransformerSupplier<K,V,R> - Interface in org.apache.kafka.streams.kstream
-
A transformer supplier which can create one or more
Transformer
instances.
- transformValues(ValueTransformerSupplier<V, R>, String...) - Method in interface org.apache.kafka.streams.kstream.KStream
-
Applies a stateful transformation to all values in this stream.
- TumblingWindows - Class in org.apache.kafka.streams.kstream
-
The tumbling window specifications used for aggregations.