Packages

object 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

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. Suppressed
  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. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  5. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @native()
  6. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  7. def equals(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef → Any
  8. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable])
  9. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  10. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  11. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  12. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  13. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  14. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  15. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  16. def toString(): String
    Definition Classes
    AnyRef → Any
  17. def untilTimeLimit[K](timeToWaitForMoreEvents: Duration, bufferConfig: BufferConfig[_]): kstream.Suppressed[K]

    Configure the suppression to wait timeToWaitForMoreEvents amount of time after receiving a record before emitting it further downstream.

    Configure the suppression to wait timeToWaitForMoreEvents amount of time after receiving a record before emitting it further downstream. If another record for the same key arrives in the mean time, it replaces the first record in the buffer but does not re-start the timer.

    K

    The key type for the KTable to apply this suppression to.

    timeToWaitForMoreEvents

    The amount of time to wait, per record, for new events.

    bufferConfig

    A configuration specifying how much space to use for buffering intermediate results.

    returns

    a suppression configuration

    See also

    org.apache.kafka.streams.kstream.Suppressed.untilTimeLimit

  18. def untilWindowCloses[K](bufferConfig: StrictBufferConfig): kstream.Suppressed[Windowed[K]]

    Configure the suppression to emit only the "final results" from the window.

    Configure the suppression to emit only the "final results" from the window.

    By default all Streams operators emit results whenever new results are available. This includes windowed operations.

    This configuration will instead emit just one result per key for each window, guaranteeing to deliver only the final result. This option is suitable for use cases in which the business logic requires a hard guarantee that only the final result is propagated. For example, sending alerts.

    To accomplish this, the operator will buffer events from the window until the window close (that is, until the end-time passes, and additionally until the grace period expires). Since windowed operators are required to reject late events for a window whose grace period is expired, there is an additional guarantee that the final results emitted from this suppression will match any queriable state upstream.

    K

    The Windowed key type for the KTable to apply this suppression to.

    bufferConfig

    A configuration specifying how much space to use for buffering intermediate results. This is required to be a "strict" config, since it would violate the "final results" property to emit early and then issue an update later.

    returns

    a "final results" mode suppression configuration

    See also

    org.apache.kafka.streams.kstream.Suppressed.untilTimeLimit

  19. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  20. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  21. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  22. object BufferConfig

    Duplicates the static factory methods inside the Java interface org.apache.kafka.streams.kstream.Suppressed.BufferConfig.

Inherited from AnyRef

Inherited from Any

Ungrouped