Packages

class StreamsBuilder extends AnyRef

Wraps the Java class StreamsBuilder and delegates method calls to the underlying Java object.

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

Instance Constructors

  1. new StreamsBuilder(inner: streams.StreamsBuilder = new StreamsBuilderJ)

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 addGlobalStore[K, V](storeBuilder: StoreBuilder[_ <: StateStore], topic: String, consumed: Consumed[K, V], stateUpdateSupplier: ProcessorSupplier[K, V, Void, Void]): streams.StreamsBuilder

    Adds a global StateStore to the topology.

    Adds a global StateStore to the topology. Global stores should not be added to Processor, Transformer, or ValueTransformer (in contrast to regular stores).

    It is not required to connect a global store to Processor, Transformer, or ValueTransformer; those have read-only access to all global stores by default.

    See also

    org.apache.kafka.streams.StreamsBuilder#addGlobalStore

  5. def addStateStore(builder: StoreBuilder[_ <: StateStore]): streams.StreamsBuilder

    Adds a state store to the underlying Topology.

    Adds a state store to the underlying Topology. The store must still be "connected" to a Processor, Transformer, or ValueTransformer before it can be used.

    It is required to connect state stores to Processor, Transformer, or ValueTransformer before they can be used.

    builder

    the builder used to obtain this state store StateStore instance

    returns

    the underlying Java abstraction StreamsBuilder after adding the StateStore

    Exceptions thrown

    org.apache.kafka.streams.errors.TopologyException if state store supplier is already added

    See also

    org.apache.kafka.streams.StreamsBuilder#addStateStore

  6. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  7. def build(props: Properties): Topology

    Returns the Topology that represents the specified processing logic and accepts a Properties instance used to indicate whether to optimize topology or not.

    Returns the Topology that represents the specified processing logic and accepts a Properties instance used to indicate whether to optimize topology or not.

    props

    the Properties used for building possibly optimized topology

    returns

    the Topology that represents the specified processing logic

    See also

    org.apache.kafka.streams.StreamsBuilder#build

  8. def build(): Topology
  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 globalTable[K, V](topic: String, materialized: Materialized[K, V, ByteArrayKeyValueStore])(implicit consumed: Consumed[K, V]): GlobalKTable[K, V]

    Create a GlobalKTable from the specified topic.

    Create a GlobalKTable from the specified topic. The resulting GlobalKTable will be materialized in a local KeyValueStore configured with the provided instance of Materialized. The serializers from the implicit Consumed instance will be used.

    topic

    the topic name

    materialized

    the instance of Materialized used to materialize a state store

    returns

    a GlobalKTable for the specified topic

    See also

    org.apache.kafka.streams.StreamsBuilder#globalTable

  15. def globalTable[K, V](topic: String)(implicit consumed: Consumed[K, V]): GlobalKTable[K, V]

    Create a GlobalKTable from the specified topic.

    Create a GlobalKTable from the specified topic. The serializers from the implicit Consumed instance will be used. Input records with null key will be dropped.

    topic

    the topic name

    returns

    a GlobalKTable for the specified topic

    See also

    org.apache.kafka.streams.StreamsBuilder#globalTable

  16. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  17. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  18. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  19. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  20. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  21. def stream[K, V](topicPattern: Pattern)(implicit consumed: Consumed[K, V]): KStream[K, V]

    Create a kstream.KStream from the specified topic pattern.

    Create a kstream.KStream from the specified topic pattern.

    topicPattern

    the topic name pattern

    returns

    a kstream.KStream for the specified topics

    See also

    #stream(String)

    org.apache.kafka.streams.StreamsBuilder#stream

  22. def stream[K, V](topics: Set[String])(implicit consumed: Consumed[K, V]): KStream[K, V]

    Create a kstream.KStream from the specified topics.

    Create a kstream.KStream from the specified topics.

    topics

    the topic names

    returns

    a kstream.KStream for the specified topics

    See also

    #stream(String)

    org.apache.kafka.streams.StreamsBuilder#stream

  23. def stream[K, V](topic: String)(implicit consumed: Consumed[K, V]): KStream[K, V]

    Create a kstream.KStream from the specified topic.

    Create a kstream.KStream from the specified topic.

    The implicit Consumed instance provides the values of auto.offset.reset strategy, TimestampExtractor, key and value deserializers etc. If the implicit is not found in scope, compiler error will result.

    A convenient alternative is to have the necessary implicit serdes in scope, which will be implicitly converted to generate an instance of Consumed. @see ImplicitConversions.

    // Brings all implicit conversions in scope
    import ImplicitConversions._
    
    // Bring implicit default serdes in scope
    import Serdes._
    
    val builder = new StreamsBuilder()
    
    // stream function gets the implicit Consumed which is constructed automatically
    // from the serdes through the implicits in ImplicitConversions#consumedFromSerde
    val userClicksStream: KStream[String, Long] = builder.stream(userClicksTopic)
    topic

    the topic name

    returns

    a kstream.KStream for the specified topic

  24. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  25. def table[K, V](topic: String, materialized: Materialized[K, V, ByteArrayKeyValueStore])(implicit consumed: Consumed[K, V]): KTable[K, V]

    Create a kstream.KTable from the specified topic.

    Create a kstream.KTable from the specified topic.

    topic

    the topic name

    materialized

    the instance of Materialized used to materialize a state store

    returns

    a kstream.KTable for the specified topic

    See also

    #table(String)

    org.apache.kafka.streams.StreamsBuilder#table

  26. def table[K, V](topic: String)(implicit consumed: Consumed[K, V]): KTable[K, V]

    Create a kstream.KTable from the specified topic.

    Create a kstream.KTable from the specified topic.

    The implicit Consumed instance provides the values of auto.offset.reset strategy, TimestampExtractor, key and value deserializers etc. If the implicit is not found in scope, compiler error will result.

    A convenient alternative is to have the necessary implicit serdes in scope, which will be implicitly converted to generate an instance of Consumed. @see ImplicitConversions.

    // Brings all implicit conversions in scope
    import ImplicitConversions._
    
    // Bring implicit default serdes in scope
    import Serdes._
    
    val builder = new StreamsBuilder()
    
    // stream function gets the implicit Consumed which is constructed automatically
    // from the serdes through the implicits in ImplicitConversions#consumedFromSerde
    val userClicksStream: KTable[String, Long] = builder.table(userClicksTopic)
    topic

    the topic name

    returns

    a kstream.KTable for the specified topic

    See also

    org.apache.kafka.streams.StreamsBuilder#table

  27. def toString(): String
    Definition Classes
    AnyRef → Any
  28. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  29. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  30. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()

Deprecated Value Members

  1. def addGlobalStore[K, V](storeBuilder: StoreBuilder[_ <: StateStore], topic: String, consumed: Consumed[K, V], stateUpdateSupplier: ProcessorSupplier[K, V]): streams.StreamsBuilder

    Adds a global StateStore to the topology.

    Adds a global StateStore to the topology. Global stores should not be added to Processor, Transformer, or ValueTransformer (in contrast to regular stores).

    It is not required to connect a global store to Processor, Transformer, or ValueTransformer; those have read-only access to all global stores by default.

    Annotations
    @deprecated
    Deprecated

    (Since version 2.7.0) Use #addGlobalStore(StoreBuilder, String, Consumed, org.apache.kafka.streams.processor.api.ProcessorSupplier) instead.

    See also

    org.apache.kafka.streams.StreamsBuilder#addGlobalStore

Inherited from AnyRef

Inherited from Any

Ungrouped