class TimeWindowedKStream[K, V] extends AnyRef
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
- Alphabetic
- By Inheritance
- TimeWindowedKStream
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Instance Constructors
- new TimeWindowedKStream(inner: kstream.TimeWindowedKStream[K, V])
- inner
The underlying Java abstraction for TimeWindowedKStream
Value Members
- final def !=(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- final def ##: Int
- Definition Classes
- AnyRef → Any
- final def ==(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- def aggregate[VR](initializer: => VR, named: Named)(aggregator: (K, V, VR) => VR)(implicit materialized: Materialized[K, VR, ByteArrayWindowStore]): KTable[Windowed[K], VR]
Aggregate the values of records in this stream by the grouped key.
Aggregate the values of records in this stream by the grouped key.
- initializer
an initializer function that computes an initial intermediate aggregation result
- named
a Named config used to name the processor in the topology
- aggregator
an aggregator function that computes a new aggregate result
- materialized
an instance of
Materialized
used to materialize a state store.- returns
a KTable that contains "update" records with unmodified keys, and values that represent the latest (rolling) aggregate for each key
- See also
org.apache.kafka.streams.kstream.TimeWindowedKStream#aggregate
- def aggregate[VR](initializer: => VR)(aggregator: (K, V, VR) => VR)(implicit materialized: Materialized[K, VR, ByteArrayWindowStore]): KTable[Windowed[K], VR]
Aggregate the values of records in this stream by the grouped key.
Aggregate the values of records in this stream by the grouped key.
- initializer
an initializer function that computes an initial intermediate aggregation result
- aggregator
an aggregator function that computes a new aggregate result
- materialized
an instance of
Materialized
used to materialize a state store.- returns
a KTable that contains "update" records with unmodified keys, and values that represent the latest (rolling) aggregate for each key
- See also
org.apache.kafka.streams.kstream.TimeWindowedKStream#aggregate
- final def asInstanceOf[T0]: T0
- Definition Classes
- Any
- def clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.CloneNotSupportedException]) @native()
- def count(named: Named)(implicit materialized: Materialized[K, Long, ByteArrayWindowStore]): KTable[Windowed[K], Long]
Count the number of records in this stream by the grouped key and the defined windows.
Count the number of records in this stream by the grouped key and the defined windows.
- named
a Named config used to name the processor in the topology
- materialized
an instance of
Materialized
used to materialize a state store.- returns
a KTable that contains "update" records with unmodified keys and
Long
values that represent the latest (rolling) count (i.e., number of records) for each key
- See also
org.apache.kafka.streams.kstream.TimeWindowedKStream#count
- def count()(implicit materialized: Materialized[K, Long, ByteArrayWindowStore]): KTable[Windowed[K], Long]
Count the number of records in this stream by the grouped key and the defined windows.
Count the number of records in this stream by the grouped key and the defined windows.
- materialized
an instance of
Materialized
used to materialize a state store.- returns
a KTable that contains "update" records with unmodified keys and
Long
values that represent the latest (rolling) count (i.e., number of records) for each key
- See also
org.apache.kafka.streams.kstream.TimeWindowedKStream#count
- final def eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def equals(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef → Any
- def finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.Throwable])
- final def getClass(): Class[_ <: AnyRef]
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
- def hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
- val inner: kstream.TimeWindowedKStream[K, V]
- final def isInstanceOf[T0]: Boolean
- Definition Classes
- Any
- final def ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- final def notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
- final def notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
- def reduce(reducer: (V, V) => V, named: Named)(implicit materialized: Materialized[K, V, ByteArrayWindowStore]): KTable[Windowed[K], V]
Combine the values of records in this stream by the grouped key.
Combine the values of records in this stream by the grouped key.
- reducer
a function that computes a new aggregate result
- named
a Named config used to name the processor in the topology
- materialized
an instance of
Materialized
used to materialize a state store.- returns
a KTable that contains "update" records with unmodified keys, and values that represent the latest (rolling) aggregate for each key
- See also
org.apache.kafka.streams.kstream.TimeWindowedKStream#reduce
- def reduce(reducer: (V, V) => V)(implicit materialized: Materialized[K, V, ByteArrayWindowStore]): KTable[Windowed[K], V]
Combine the values of records in this stream by the grouped key.
Combine the values of records in this stream by the grouped key.
- reducer
a function that computes a new aggregate result
- materialized
an instance of
Materialized
used to materialize a state store.- returns
a KTable that contains "update" records with unmodified keys, and values that represent the latest (rolling) aggregate for each key
- See also
org.apache.kafka.streams.kstream.TimeWindowedKStream#reduce
- final def synchronized[T0](arg0: => T0): T0
- Definition Classes
- AnyRef
- def toString(): String
- Definition Classes
- AnyRef → Any
- final def wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException]) @native()