object Materialized

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. Materialized
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##: Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. def as[K, V](supplier: KeyValueBytesStoreSupplier)(implicit keySerde: Serde[K], valueSerde: Serde[V]): kstream.Materialized[K, V, ByteArrayKeyValueStore]

    Materialize a org.apache.kafka.streams.state.KeyValueStore using the provided KeyValueBytesStoreSupplier.

    Materialize a org.apache.kafka.streams.state.KeyValueStore using the provided KeyValueBytesStoreSupplier.

    K

    key type of the store

    V

    value type of the store

    supplier

    the KeyValueBytesStoreSupplier used to materialize the store

    keySerde

    the key serde to use.

    valueSerde

    the value serde to use.

    returns

    a new Materialized instance with the given supplier

  5. def as[K, V](supplier: SessionBytesStoreSupplier)(implicit keySerde: Serde[K], valueSerde: Serde[V]): kstream.Materialized[K, V, ByteArraySessionStore]

    Materialize a org.apache.kafka.streams.state.SessionStore using the provided SessionBytesStoreSupplier.

    Materialize a org.apache.kafka.streams.state.SessionStore using the provided SessionBytesStoreSupplier.

    Important: Custom subclasses are allowed here, but they should respect the retention contract: Session stores are required to retain windows at least as long as (session inactivity gap + session grace period). Stores constructed via org.apache.kafka.streams.state.Stores already satisfy this contract.

    K

    key type of the store

    V

    value type of the store

    supplier

    the SessionBytesStoreSupplier used to materialize the store

    keySerde

    the key serde to use.

    valueSerde

    the value serde to use.

    returns

    a new Materialized instance with the given supplier

  6. def as[K, V](supplier: WindowBytesStoreSupplier)(implicit keySerde: Serde[K], valueSerde: Serde[V]): kstream.Materialized[K, V, ByteArrayWindowStore]

    Materialize a org.apache.kafka.streams.state.WindowStore using the provided WindowBytesStoreSupplier.

    Materialize a org.apache.kafka.streams.state.WindowStore using the provided WindowBytesStoreSupplier.

    Important: Custom subclasses are allowed here, but they should respect the retention contract: Window stores are required to retain windows at least as long as (window size + window grace period). Stores constructed via org.apache.kafka.streams.state.Stores already satisfy this contract.

    K

    key type of the store

    V

    value type of the store

    supplier

    the WindowBytesStoreSupplier used to materialize the store

    keySerde

    the key serde to use.

    valueSerde

    the value serde to use.

    returns

    a new Materialized instance with the given supplier

  7. def as[K, V, S <: StateStore](storeName: String)(implicit keySerde: Serde[K], valueSerde: Serde[V]): kstream.Materialized[K, V, S]

    Materialize a StateStore with the given name.

    Materialize a StateStore with the given name.

    K

    key type of the store

    V

    value type of the store

    S

    type of the StateStore

    storeName

    the name of the underlying org.apache.kafka.streams.scala.kstream.KTable state store; valid characters are ASCII alphanumerics, '.', '_' and '-'.

    keySerde

    the key serde to use.

    valueSerde

    the value serde to use.

    returns

    a new Materialized instance with the given storeName

  8. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  9. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @native()
  10. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  11. def equals(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef → Any
  12. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable])
  13. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  14. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  15. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  16. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  17. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  18. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  19. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  20. def toString(): String
    Definition Classes
    AnyRef → Any
  21. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  22. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  23. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  24. def with[K, V, S <: StateStore](implicit keySerde: Serde[K], valueSerde: Serde[V]): kstream.Materialized[K, V, S]

    Materialize a StateStore with the provided key and value Serdes.

    Materialize a StateStore with the provided key and value Serdes. An internal name will be used for the store.

    K

    key type

    V

    value type

    S

    store type

    keySerde

    the key Serde to use.

    valueSerde

    the value Serde to use.

    returns

    a new Materialized instance with the given key and value serdes

Inherited from AnyRef

Inherited from Any

Ungrouped