All Classes Interface Summary Class Summary Enum Summary Exception Summary
Class |
Description |
AbstractProcessor<K,V> |
|
AbstractProcessorContext |
|
AbstractRocksDBSegmentedBytesStore<S extends Segment> |
|
AbstractStoreBuilder<K,V,T extends StateStore> |
|
AbstractStream<K,V> |
|
AbstractTask |
|
Aggregator<K,V,VA> |
The Aggregator interface for aggregating values of the given key.
|
ApiUtils |
|
AssignmentInfo |
|
AssignorConfiguration |
|
AssignorConfiguration.AssignmentConfigs |
|
AssignorConfiguration.AssignmentListener |
|
AssignorError |
|
BaseRepartitionNode<K,V> |
|
BaseRepartitionNode.BaseRepartitionNodeBuilder<K,V,T extends BaseRepartitionNode<K,V>> |
|
BatchingStateRestoreCallback |
|
BatchWritingStore |
|
BrokerNotFoundException |
Indicates that none of the specified brokers
could be found.
|
BufferConfigInternal<BC extends Suppressed.BufferConfig<BC>> |
|
BufferFullStrategy |
|
BufferKey |
|
BufferValue |
|
CachedStateStore<K,V> |
|
CacheFlushListener<K,V> |
Listen to cache flush events
|
CachingKeyValueStore |
|
Cancellable |
|
Change<T> |
|
ChangedDeserializer<T> |
|
ChangedSerializer<T> |
|
ChangeLoggingKeyValueBytesStore |
|
ChangeLoggingTimestampedKeyValueBytesStore |
|
ChangelogReader |
|
ChangelogRegister |
|
ClientMetrics |
|
ClientState |
|
ClientUtils |
|
ClientUtils.QuietAdminClientConfig |
|
CogroupedKStream<K,VOut> |
CogroupedKStream is an abstraction of multiple grouped record streams of KeyValue pairs.
|
CogroupedKStreamImpl<K,VOut> |
|
CombinedKey<KF,KP> |
|
CombinedKeySchema<KO,K> |
Factory for creating CombinedKey serializers / deserializers.
|
CompositeReadOnlyKeyValueStore<K,V> |
|
CompositeReadOnlySessionStore<K,V> |
|
CompositeReadOnlyWindowStore<K,V> |
|
ConnectedStoreProvider |
Provides a set of StoreBuilder s that will be automatically added to the topology and connected to the
associated processor.
|
Consumed<K,V> |
|
ConsumedInternal<K,V> |
|
ContextualRecord |
|
CopartitionedTopicsEnforcer |
|
DefaultKafkaClientSupplier |
|
DefaultPartitionGrouper |
Deprecated.
|
DefaultProductionExceptionHandler |
ProductionExceptionHandler that always instructs streams to fail when an exception
happens while attempting to produce result records.
|
DefaultStreamPartitioner<K,V> |
|
DelegatingPeekingKeyValueIterator<K,V> |
Optimized KeyValueIterator used when the same element could be peeked multiple times.
|
DeserializationExceptionHandler |
Interface that specifies how an exception from source node deserialization
(e.g., reading from Kafka) should be handled.
|
DeserializationExceptionHandler.DeserializationHandlerResponse |
Enumeration that describes the response from the exception handler.
|
EagerBufferConfigImpl |
|
FailOnInvalidTimestamp |
Retrieves embedded metadata timestamps from Kafka messages.
|
FallbackPriorTaskAssignor |
A special task assignor implementation to be used as a fallback in case the
configured assignor couldn't be invoked.
|
FinalResultsSuppressionBuilder<K extends Windowed> |
|
ForeachAction<K,V> |
The ForeachAction interface for performing an action on a key-value
pair .
|
ForeignJoinSubscriptionProcessorSupplier<K,KO,VO> |
|
ForeignJoinSubscriptionSendProcessorSupplier<K,KO,V> |
|
ForwardingDisabledProcessorContext |
ProcessorContext implementation that will throw on any forward call.
|
FullChangeSerde<T> |
|
GlobalKTable<K,V> |
GlobalKTable is an abstraction of a changelog stream from a primary-keyed table.
|
GlobalKTableImpl<K,V> |
|
GlobalProcessorContextImpl |
|
GlobalStateManager |
|
GlobalStateManagerImpl |
This class is responsible for the initialization, restoration, closing, flushing etc
of Global State Stores.
|
GlobalStateStoreProvider |
|
GlobalStateUpdateTask |
Updates the state for all Global State Stores.
|
GlobalStoreNode<K,V,S extends StateStore> |
|
GlobalStreamThread |
This is the thread responsible for keeping all Global State Stores updated.
|
GlobalStreamThread.State |
The states that the global stream thread can be in
|
GraphGraceSearchUtil |
|
Grouped<K,V> |
|
GroupedInternal<K,V> |
|
GroupedTableOperationRepartitionNode<K,V> |
|
GroupedTableOperationRepartitionNode.GroupedTableOperationRepartitionNodeBuilder<K,V> |
|
HighAvailabilityTaskAssignor |
|
HostInfo |
Represents a user defined endpoint in a KafkaStreams application.
|
Initializer<VA> |
The Initializer interface for creating an initial value in aggregations.
|
InMemoryKeyValueStore |
|
InMemorySessionBytesStoreSupplier |
|
InMemorySessionStore |
|
InMemoryTimeOrderedKeyValueBuffer<K,V> |
|
InMemoryTimeOrderedKeyValueBuffer.Builder<K,V> |
|
InMemoryWindowBytesStoreSupplier |
|
InMemoryWindowStore |
|
InternalNameProvider |
|
InternalProcessorContext |
|
InternalStreamNotExistException |
|
InternalStreamsBuilder |
|
InternalTopicConfig |
InternalTopicConfig captures the properties required for configuring
the internal topics we create for change-logs and repartitioning etc.
|
InternalTopicManager |
|
InternalTopicProperties |
|
InternalTopologyBuilder |
|
InternalTopologyBuilder.AbstractNode |
|
InternalTopologyBuilder.GlobalStore |
|
InternalTopologyBuilder.Processor |
|
InternalTopologyBuilder.Sink<K,V> |
|
InternalTopologyBuilder.Source |
|
InternalTopologyBuilder.StateStoreFactory<S extends StateStore> |
|
InternalTopologyBuilder.Subtopology |
|
InternalTopologyBuilder.TopicsInfo |
|
InternalTopologyBuilder.TopologyDescription |
|
InvalidStateStoreException |
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.
|
Joined<K,V,VO> |
|
JoinedInternal<K,V,VO> |
|
JoinWindows |
The window specifications used for joins.
|
KafkaClientSupplier |
KafkaClientSupplier can be used to provide custom Kafka clients to a KafkaStreams instance.
|
KafkaStreams |
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.State |
Kafka Streams states are the possible state that a Kafka Streams instance can be in.
|
KafkaStreams.StateListener |
|
KafkaStreamsInternalStorageInitializer |
|
KeyQueryMetadata |
Represents all the metadata related to a key, where a particular key resides in a KafkaStreams application.
|
KeyValue<K,V> |
A key-value pair defined for a single Kafka Streams record.
|
KeyValueBytesStoreSupplier |
|
KeyValueIterator<K,V> |
|
KeyValueIteratorFacade<K,V> |
|
KeyValueMapper<K,V,VR> |
The KeyValueMapper interface for mapping a key-value pair to a new value of arbitrary type.
|
KeyValueStore<K,V> |
A key-value store that supports put/get/delete and range queries.
|
KeyValueStoreBuilder<K,V> |
|
KeyValueToTimestampedKeyValueByteStoreAdapter |
|
KGroupedStream<K,V> |
KGroupedStream is an abstraction of a grouped record stream of KeyValue pairs.
|
KGroupedTable<K,V> |
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> |
|
KStream<K,V> |
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> |
|
KStreamAggregate<K,V,T> |
|
KStreamFlatTransform<KIn,VIn,KOut,VOut> |
|
KStreamFlatTransform.KStreamFlatTransformProcessor<KIn,VIn,KOut,VOut> |
|
KStreamFlatTransformValues<KIn,VIn,VOut> |
|
KStreamFlatTransformValues.KStreamFlatTransformValuesProcessor<KIn,VIn,VOut> |
|
KStreamImpl<K,V> |
|
KStreamPrint<K,V> |
|
KStreamReduce<K,V> |
|
KStreamSessionWindowAggregate<K,V,Agg> |
|
KStreamTransformValues<K,V,R> |
|
KStreamTransformValues.KStreamTransformValuesProcessor<K,V,R> |
|
KStreamWindowAggregate<K,V,Agg,W extends Window> |
|
KTable<K,V> |
KTable is an abstraction of a changelog stream from a primary-keyed table.
|
KTableAggregate<K,V,T> |
|
KTableImpl<K,S,V> |
The implementation class of KTable .
|
KTableKTableAbstractJoinValueGetterSupplier<K,R,V1,V2> |
|
KTableKTableJoinMerger<K,V> |
|
KTableKTableJoinNode<K,V1,V2,VR> |
Too much specific information to generalize so the KTable-KTable join requires a specific node.
|
KTableKTableJoinNode.KTableKTableJoinNodeBuilder<K,V1,V2,VR> |
|
KTableMaterializedValueGetterSupplier<K,V> |
|
KTableProcessorSupplier<K,V,T> |
|
KTableReduce<K,V> |
|
KTableRepartitionMap<K,V,K1,V1> |
KTable repartition map functions are not exposed to public APIs, but only used for keyed aggregations.
|
KTableSource<K,V> |
|
KTableSourceValueGetterSupplier<K,V> |
|
KTableSuppressProcessorSupplier<K,V> |
|
KTableValueGetter<K,V> |
|
KTableValueGetterSupplier<K,V> |
|
LagInfo |
Encapsulates information about lag, at a store partition replica (active or standby).
|
LockException |
Indicates that the state store directory lock could not be acquired because another thread holds the lock.
|
LogAndContinueExceptionHandler |
Deserialization handler that logs a deserialization exception and then
signals the processing pipeline to continue processing more records.
|
LogAndFailExceptionHandler |
Deserialization handler that logs a deserialization exception and then
signals the processing pipeline to stop processing more records and fail.
|
LogAndSkipOnInvalidTimestamp |
Retrieves embedded metadata timestamps from Kafka messages.
|
Materialized<K,V,S extends StateStore> |
Used to describe how a StateStore should be materialized.
|
MaterializedInternal<K,V,S extends StateStore> |
|
Maybe<T> |
A container that may be empty, may contain null, or may contain a value.
|
MemoryLRUCache |
An in-memory LRU cache store based on HashSet and HashMap.
|
MemoryLRUCache.EldestEntryRemovalListener |
|
MemoryNavigableLRUCache |
|
Merger<K,V> |
The interface for merging aggregate values for SessionWindows with the given key.
|
MeteredKeyValueStore<K,V> |
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> |
|
MeteredTimestampedKeyValueStore<K,V> |
A Metered TimestampedKeyValueStore wrapper that is used for recording operation metrics, and hence its
inner KeyValueStore implementation do not need to provide its own metrics collecting functionality.
|
MeteredTimestampedKeyValueStore.RawAndDeserializedValue<ValueType> |
|
MeteredWindowStore<K,V> |
|
Murmur3 |
This class was taken from Hive org.apache.hive.common.util;
https://github.com/apache/hive/blob/master/storage-api/src/java/org/apache/hive/common/util/Murmur3.java
Commit: dffa3a16588bc8e95b9d0ab5af295a74e06ef702
Murmur3 is successor to Murmur2 fast non-crytographic hash algorithms.
|
Murmur3.IncrementalHash32 |
|
Named |
|
NamedCacheMetrics |
|
NamedInternal |
|
NamedSuppressed<K> |
Internally-facing interface to work around the fact that all Suppressed config objects
are name-able, but do not present a getter (for consistency with other config objects).
|
OffsetCheckpoint |
This class saves out a map of topic/partition=>offsets to a file.
|
OptimizableRepartitionNode<K,V> |
|
OptimizableRepartitionNode.OptimizableRepartitionNodeBuilder<K,V> |
|
PartitionGroup |
PartitionGroup is used to buffer all co-partitioned records for processing.
|
PartitionGrouper |
Deprecated.
|
PeekingKeyValueIterator<K,V> |
|
Predicate<K,V> |
The Predicate interface represents a predicate (boolean-valued function) of a KeyValue pair.
|
Printed<K,V> |
An object to define the options used when printing a KStream .
|
PrintedInternal<K,V> |
|
PrintForeachAction<K,V> |
|
Processor<K,V> |
A processor of key-value pair records.
|
ProcessorContext |
Processor context interface.
|
ProcessorContextImpl |
|
ProcessorContextUtils |
This class bridges the gap for components that _should_ be compatible with
the public ProcessorContext interface, but have come to depend on features
in InternalProcessorContext.
|
ProcessorGraphNode<K,V> |
Used to represent any type of stateless operation:
map, mapValues, flatMap, flatMapValues, filter, filterNot, branch
|
ProcessorNode<K,V> |
|
ProcessorNodeMetrics |
|
ProcessorNodePunctuator |
|
ProcessorParameters<K,V> |
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.
|
ProcessorRecordContext |
|
ProcessorStateException |
Indicates a processor state operation (e.g.
|
ProcessorStateManager |
ProcessorStateManager is the source of truth for the current offset for each state store,
which is either the read offset during restoring, or the written offset during normal processing.
|
ProcessorStateManager.StateStoreMetadata |
|
ProcessorSupplier<K,V> |
A processor supplier that can create one or more Processor instances.
|
ProcessorTopology |
|
Produced<K,V> |
|
ProducedInternal<K,V> |
|
ProductionExceptionHandler |
Interface that specifies how an exception when attempting to produce a result to
Kafka should be handled.
|
ProductionExceptionHandler.ProductionExceptionHandlerResponse |
|
PunctuationQueue |
|
PunctuationSchedule |
|
PunctuationType |
|
Punctuator |
|
QueryableStoreProvider |
|
QueryableStoreType<T> |
|
QueryableStoreTypes |
|
QueryableStoreTypes.KeyValueStoreType<K,V> |
|
QueryableStoreTypes.SessionStoreType<K,V> |
|
QueryableStoreTypes.WindowStoreType<K,V> |
|
QuickUnion<T> |
|
QuietStreamsConfig |
A StreamsConfig that does not log its configuration on construction.
|
ReadOnlyKeyValueStore<K,V> |
A key-value store that only supports read operations.
|
ReadOnlyKeyValueStoreFacade<K,V> |
|
ReadOnlySessionStore<K,AGG> |
A session store that only supports read operations.
|
ReadOnlyWindowStore<K,V> |
A window store that only supports read operations.
|
ReadOnlyWindowStoreFacade<K,V> |
|
RecordBatchingStateRestoreCallback |
|
RecordCollector |
|
RecordCollector.Supplier |
|
RecordCollectorImpl |
|
RecordContext |
The context associated with the current record being processed by
an Processor
|
RecordConverter |
|
RecordConverters |
|
RecordQueue |
RecordQueue is a FIFO queue of StampedRecord (ConsumerRecord + timestamp).
|
Reducer<V> |
The Reducer interface for combining two values of the same type into a new value.
|
Repartitioned<K,V> |
This class is used to provide the optional parameters for internal repartition topics.
|
RepartitionedInternal<K,V> |
|
RepartitionTopicConfig |
RepartitionTopicConfig captures the properties required for configuring
the repartition topics.
|
RestoringTasks |
|
RocksDBConfigSetter |
An interface to that allows developers to customize the RocksDB settings for a given Store.
|
RocksDBGenericOptionsToDbOptionsColumnFamilyOptionsAdapter |
The generic Options class allows users to set all configs on one object if only default column family
is used.
|
RocksDbKeyValueBytesStoreSupplier |
|
RocksDBMetrics |
|
RocksDBMetrics.RocksDBMetricContext |
|
RocksDBMetricsRecorder |
|
RocksDBMetricsRecordingTrigger |
|
RocksDBSegmentedBytesStore |
|
RocksDbSessionBytesStoreSupplier |
|
RocksDBSessionStore |
|
RocksDBStore |
A persistent key-value store based on RocksDB.
|
RocksDBTimestampedSegmentedBytesStore |
|
RocksDBTimestampedStore |
A persistent key-(value-timestamp) store based on RocksDB.
|
RocksDbWindowBytesStoreSupplier |
|
RocksDBWindowStore |
|
Segment |
|
SegmentedBytesStore |
The interface representing a StateStore that has 1 or more segments that are based
on time.
|
SegmentedBytesStore.KeySchema |
|
Serialized<K,V> |
Deprecated.
|
SerializedInternal<K,V> |
Deprecated. |
SessionBytesStoreSupplier |
|
SessionKeySchema |
|
SessionStore<K,AGG> |
Interface for storing the aggregated values of sessions.
|
SessionStoreBuilder<K,V> |
|
SessionWindow |
A session window covers a closed time interval with its start and end timestamp both being an inclusive boundary.
|
SessionWindowedCogroupedKStream<K,V> |
SessionWindowedCogroupKStream is an abstraction of a windowed record stream of KeyValue pairs.
|
SessionWindowedCogroupedKStreamImpl<K,V> |
|
SessionWindowedDeserializer<T> |
|
SessionWindowedKStream<K,V> |
SessionWindowedKStream is an abstraction of a windowed record stream of KeyValue pairs.
|
SessionWindowedKStreamImpl<K,V> |
|
SessionWindowedSerializer<T> |
|
SessionWindows |
A session based window specification used for aggregating events into sessions.
|
SinkNode<K,V> |
|
SourceNode<K,V> |
|
Stamped<V> |
|
StampedRecord |
|
StandbyTask |
A StandbyTask
|
StateDirectory |
Manages the directories where the state of Tasks owned by a StreamThread are
stored.
|
StatefulProcessorNode<K,V> |
|
StateRestoreCallback |
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 |
|
StateRestoreListener |
Class for listening to various states of the restoration process of a StateStore.
|
StateSerdes<K,V> |
Factory for creating serializers / deserializers for state stores in Kafka Streams.
|
StateStore |
A storage engine for managing state maintained by a stream processor.
|
StateStoreMetrics |
|
StateStoreNode<S extends StateStore> |
|
StateStoreProvider |
|
StaticTopicNameExtractor<K,V> |
Static topic name extractor
|
StickyTaskAssignor |
|
StoreBuilder<T extends StateStore> |
Build a StateStore wrapped with optional caching and logging.
|
StoreChangelogReader |
ChangelogReader is created and maintained by the stream thread and used for both updating standby tasks and
restoring active tasks.
|
StoreQueryParameters<T> |
StoreQueryParameters allows you to pass a variety of parameters when fetching a store for interactive query.
|
Stores |
Factory for creating state stores in Kafka Streams.
|
StoreSupplier<T extends StateStore> |
A state store supplier which can create one or more StateStore instances.
|
StreamJoined<K,V1,V2> |
Class used to configure the name of the join processor, the repartition topic name,
state stores or state store names in Stream-Stream join.
|
StreamJoinedInternal<K,V1,V2> |
|
StreamPartitioner<K,V> |
Determine how records are distributed among the partitions in a Kafka topic.
|
StreamsAssignmentProtocolVersions |
|
StreamsBuilder |
StreamsBuilder provide the high-level Kafka Streams DSL to specify a Kafka Streams topology.
|
StreamsConfig |
|
StreamsConfig.InternalConfig |
|
StreamsException |
|
StreamsGraphNode |
|
StreamSinkNode<K,V> |
|
StreamsMetadata |
Represents the state of an instance (process) in a KafkaStreams application.
|
StreamsMetadataState |
|
StreamsMetrics |
The Kafka Streams metrics interface for adding metric sensors and collecting metric values.
|
StreamsMetricsImpl |
|
StreamsMetricsImpl.Version |
|
StreamSourceNode<K,V> |
|
StreamsPartitionAssignor |
|
StreamsProducer |
StreamsProducer manages the producers within a Kafka Streams application.
|
StreamsRebalanceListener |
|
StreamStreamJoinNode<K,V1,V2,VR> |
Too much information to generalize, so Stream-Stream joins are represented by a specific node.
|
StreamStreamJoinNode.StreamStreamJoinNodeBuilder<K,V1,V2,VR> |
|
StreamTableJoinNode<K,V> |
Represents a join between a KStream and a KTable or GlobalKTable
|
StreamTask |
A StreamTask is associated with a PartitionGroup , and is assigned to a StreamThread for processing.
|
StreamThread |
|
StreamThread.ProcessingMode |
|
StreamThread.State |
Stream thread states are the possible states that a stream thread can be in.
|
StreamThread.StateListener |
Listen to state change events
|
StreamThreadStateStoreProvider |
|
StreamToTableNode<K,V> |
Represents a KTable convert From KStream
|
StrictBufferConfigImpl |
|
SubscriptionInfo |
|
SubscriptionInfoData |
|
SubscriptionInfoData.PartitionToOffsetSum |
|
SubscriptionInfoData.TaskId |
|
SubscriptionInfoData.TaskOffsetSum |
|
SubscriptionJoinForeignProcessorSupplier<K,KO,VO> |
Receives SubscriptionWrapper<K> events and processes them according to their Instruction.
|
SubscriptionResolverJoinProcessorSupplier<K,V,VO,VR> |
Receives SubscriptionResponseWrapper<VO> events and filters out events which do not match the current hash
of the primary key.
|
SubscriptionResponseWrapper<FV> |
|
SubscriptionResponseWrapperSerde<V> |
|
SubscriptionStoreReceiveProcessorSupplier<K,KO> |
|
SubscriptionWrapper<K> |
|
SubscriptionWrapper.Instruction |
|
SubscriptionWrapperSerde<K> |
|
Suppressed<K> |
|
Suppressed.BufferConfig<BC extends Suppressed.BufferConfig<BC>> |
|
Suppressed.EagerBufferConfig |
Marker interface for a buffer configuration that will strictly enforce size constraints
(bytes and/or number of records) on the buffer, so it is suitable for reducing duplicate
results downstream, but does not promise to eliminate them entirely.
|
Suppressed.StrictBufferConfig |
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> |
|
TableProcessorNode<K,V> |
|
TableSourceNode<K,V> |
Used to represent either a KTable source or a GlobalKTable source.
|
TableSourceNode.TableSourceNodeBuilder<K,V> |
|
Task |
|
Task.State |
|
Task.TaskType |
|
TaskAssignmentException |
|
TaskAssignor |
|
TaskCorruptedException |
Indicates a specific task is corrupted and need to be re-initialized.
|
TaskId |
The task ID representation composed as topic group ID plus the assigned partition ID.
|
TaskIdFormatException |
Indicates a run time error incurred while trying parse the task id
from the read string.
|
TaskManager |
|
TaskMetadata |
Represents the state of a single task running within a KafkaStreams application.
|
TaskMetrics |
|
TaskMigratedException |
Indicates that all tasks belongs to the thread have migrated to another thread.
|
ThreadCache |
An in-memory LRU cache store similar to MemoryLRUCache but byte-based, not
record based
|
ThreadCache.DirtyEntryFlushListener |
|
ThreadMetadata |
Represents the state of a single thread running within a KafkaStreams application.
|
ThreadMetrics |
|
ThreadStateTransitionValidator |
Basic interface for keeping track of the state of a thread.
|
TimeOrderedKeyValueBuffer<K,V> |
|
TimeOrderedKeyValueBuffer.Eviction<K,V> |
|
TimestampedBytesStore |
|
TimestampedKeyValueStore<K,V> |
A key-(value/timestamp) store that supports put/get/delete and range queries.
|
TimestampedKeyValueStoreBuilder<K,V> |
|
TimestampedKeyValueStoreMaterializer<K,V> |
|
TimestampedWindowStore<K,V> |
Interface for storing the aggregated values of fixed-size time windows.
|
TimestampedWindowStoreBuilder<K,V> |
|
TimestampExtractor |
An interface that allows the Kafka Streams framework to extract a timestamp from an instance of ConsumerRecord .
|
TimeWindow |
A TimeWindow covers a half-open time interval with its start timestamp as an inclusive boundary and its end
timestamp as exclusive boundary.
|
TimeWindowedCogroupedKStream<K,V> |
TimeWindowedCogroupKStream is an abstraction of a windowed record stream of KeyValue pairs.
|
TimeWindowedCogroupedKStreamImpl<K,V,W extends Window> |
|
TimeWindowedDeserializer<T> |
|
TimeWindowedKStream<K,V> |
TimeWindowedKStream is an abstraction of a windowed record stream of KeyValue pairs.
|
TimeWindowedKStreamImpl<K,V,W extends Window> |
|
TimeWindowedSerializer<T> |
|
TimeWindows |
The fixed-size time-based window specifications used for aggregations.
|
To |
|
ToInternal |
|
TopicNameExtractor<K,V> |
An interface that allows to dynamically determine the name of the Kafka topic to send at the sink node of the topology.
|
Topology |
|
Topology.AutoOffsetReset |
|
TopologyDescription |
|
TopologyDescription.GlobalStore |
|
TopologyDescription.Node |
A node of a topology.
|
TopologyDescription.Processor |
A processor node of a topology.
|
TopologyDescription.Sink |
A sink node of a topology.
|
TopologyDescription.Source |
A source node of a topology.
|
TopologyDescription.Subtopology |
|
TopologyException |
|
Transformer<K,V,R> |
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> |
A TransformerSupplier interface which can create one or more Transformer instances.
|
TransformerSupplierAdapter<KIn,VIn,KOut,VOut> |
|
UnlimitedWindow |
UnlimitedWindow is an "infinite" large window with a fixed (inclusive) start time.
|
UnlimitedWindows |
The unlimited window specifications used for aggregations.
|
UnoptimizableRepartitionNode<K,V> |
Repartition node that is not subject of optimization algorithm
|
UnoptimizableRepartitionNode.UnoptimizableRepartitionNodeBuilder<K,V> |
|
UnwindowedChangelogTopicConfig |
UnwindowedChangelogTopicConfig captures the properties required for configuring
the un-windowed store changelog topics.
|
UsePartitionTimeOnInvalidTimestamp |
Retrieves embedded metadata timestamps from Kafka messages.
|
UsePreviousTimeOnInvalidTimestamp |
Deprecated.
|
ValueAndTimestamp<V> |
Combines a value from a KeyValue with a timestamp.
|
ValueAndTimestampSerde<V> |
|
ValueAndTimestampSerializer<V> |
|
ValueJoiner<V1,V2,VR> |
The ValueJoiner interface for joining two values into a new value of arbitrary type.
|
ValueMapper<V,VR> |
The ValueMapper interface for mapping a value to a new value of arbitrary type.
|
ValueMapperWithKey<K,V,VR> |
The ValueMapperWithKey interface for mapping a value to a new value of arbitrary type.
|
ValueTransformer<V,VR> |
The ValueTransformer interface for stateful mapping of a value to a new value (with possible new type).
|
ValueTransformerSupplier<V,VR> |
A ValueTransformerSupplier interface which can create one or more ValueTransformer instances.
|
ValueTransformerWithKey<K,V,VR> |
The ValueTransformerWithKey interface for stateful mapping of a value to a new value (with possible new type).
|
ValueTransformerWithKeySupplier<K,V,VR> |
|
WallclockTimestampExtractor |
Retrieves current wall clock timestamps as System.currentTimeMillis() .
|
Window |
A single window instance, defined by its start and end timestamp.
|
WindowBytesStoreSupplier |
|
Windowed<K> |
The result key type of a windowed stream aggregation.
|
WindowedChangelogTopicConfig |
WindowedChangelogTopicConfig captures the properties required for configuring
the windowed store changelog topics.
|
WindowedSerdes |
|
WindowedSerdes.SessionWindowedSerde<T> |
|
WindowedSerdes.TimeWindowedSerde<T> |
|
WindowedSerializer<T> |
|
WindowedStreamPartitioner<K,V> |
|
WindowingDefaults |
|
WindowKeySchema |
|
Windows<W extends Window> |
The window specification for fixed size windows that is used to define window boundaries and grace period.
|
WindowStore<K,V> |
Interface for storing the aggregated values of fixed-size time windows.
|
WindowStoreBuilder<K,V> |
|
WindowStoreIterator<V> |
|
WrappedStateStore<S extends StateStore,K,V> |
A storage engine wrapper for utilities like logging, caching, and metering.
|
WrappingNullableDeserializer<Outer,InnerK,InnerV> |
|
WrappingNullableSerde<T,InnerK,InnerV> |
|
WrappingNullableSerializer<Outer,InnerK,InnerV> |
|
WrappingNullableUtils |
If a component's serdes are Wrapping serdes, then they require a little extra setup
to be fully initialized at run time.
|
WrappingStoreProvider |
|