package kstream
- Alphabetic
- By Inheritance
- kstream
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Type Members
- class CogroupedKStream[KIn, VOut] extends AnyRef
Wraps the Java class CogroupedKStream and delegates method calls to the underlying Java object.
Wraps the Java class CogroupedKStream and delegates method calls to the underlying Java object.
- KIn
Type of keys
- VOut
Type of values
- See also
org.apache.kafka.streams.kstream.CogroupedKStream
- type Consumed[K, V] = kstream.Consumed[K, V]
- type Grouped[K, V] = kstream.Grouped[K, V]
- type Joined[K, V, VO] = kstream.Joined[K, V, VO]
- class KGroupedStream[K, V] extends AnyRef
Wraps the Java class KGroupedStream and delegates method calls to the underlying Java object.
Wraps the Java class KGroupedStream and delegates method calls to the underlying Java object.
- K
Type of keys
- V
Type of values
- See also
org.apache.kafka.streams.kstream.KGroupedStream
- class KGroupedTable[K, V] extends AnyRef
Wraps the Java class KGroupedTable and delegates method calls to the underlying Java object.
Wraps the Java class KGroupedTable and delegates method calls to the underlying Java object.
- K
Type of keys
- V
Type of values
- See also
org.apache.kafka.streams.kstream.KGroupedTable
- class KStream[K, V] extends AnyRef
Wraps the Java class KStream and delegates method calls to the underlying Java object.
Wraps the Java class KStream and delegates method calls to the underlying Java object.
- K
Type of keys
- V
Type of values
- See also
org.apache.kafka.streams.kstream.KStream
- class KTable[K, V] extends AnyRef
Wraps the Java class org.apache.kafka.streams.kstream.KTable and delegates method calls to the underlying Java object.
Wraps the Java class org.apache.kafka.streams.kstream.KTable and delegates method calls to the underlying Java object.
- K
Type of keys
- V
Type of values
- See also
org.apache.kafka.streams.kstream.KTable
- type Materialized[K, V, S <: StateStore] = kstream.Materialized[K, V, S]
- type Produced[K, V] = kstream.Produced[K, V]
- type Repartitioned[K, V] = kstream.Repartitioned[K, V]
- class SessionWindowedCogroupedKStream[K, V] extends AnyRef
Wraps the Java class SessionWindowedCogroupedKStream and delegates method calls to the underlying Java object.
Wraps the Java class SessionWindowedCogroupedKStream and delegates method calls to the underlying Java object.
- K
Type of keys
- V
Type of values
- See also
org.apache.kafka.streams.kstream.SessionWindowedCogroupedKStream
- class SessionWindowedKStream[K, V] extends AnyRef
Wraps the Java class SessionWindowedKStream and delegates method calls to the underlying Java object.
Wraps the Java class SessionWindowedKStream and delegates method calls to the underlying Java object.
- K
Type of keys
- V
Type of values
- See also
org.apache.kafka.streams.kstream.SessionWindowedKStream
- type StreamJoined[K, V, VO] = kstream.StreamJoined[K, V, VO]
- class TimeWindowedCogroupedKStream[K, V] extends AnyRef
Wraps the Java class TimeWindowedCogroupedKStream and delegates method calls to the underlying Java object.
Wraps the Java class TimeWindowedCogroupedKStream and delegates method calls to the underlying Java object.
- K
Type of keys
- V
Type of values
- See also
org.apache.kafka.streams.kstream.TimeWindowedCogroupedKStream
- class TimeWindowedKStream[K, V] extends AnyRef
Wraps the Java class TimeWindowedKStream and delegates method calls to the underlying Java object.
Wraps the Java class TimeWindowedKStream and delegates method calls to the underlying Java object.
- K
Type of keys
- V
Type of values
- See also
org.apache.kafka.streams.kstream.TimeWindowedKStream
Value Members
- object Consumed
- object Grouped
- object Joined
- object Materialized
- object Produced
- object Repartitioned
- object StreamJoined
Deprecated Value Members
- object Suppressed
Duplicates the static factory methods inside the Java interface org.apache.kafka.streams.kstream.Suppressed.
Duplicates the static factory methods inside the Java interface org.apache.kafka.streams.kstream.Suppressed.
This was required for compatibility w/ Scala 2.11 + Java 1.8 because the Scala 2.11 compiler doesn't support the use of static methods inside Java interfaces. We have since dropped Scala 2.11 support.
- Annotations
- @deprecated
- Deprecated
(Since version 2.5) Use org.apache.kafka.streams.kstream.Suppressed