Class

org.apache.flink.streaming.api.scala.function

ProcessAllWindowFunction

Related Doc: package function

Permalink

abstract class ProcessAllWindowFunction[IN, OUT, W <: Window] extends AbstractRichFunction

Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information.

IN

The type of the input value.

OUT

The type of the output value.

W

The type of the window.

Annotations
@PublicEvolving()
Linear Supertypes
AbstractRichFunction, RichFunction, Function, Serializable, AnyRef, Any
Known Subclasses
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ProcessAllWindowFunction
  2. AbstractRichFunction
  3. RichFunction
  4. Function
  5. Serializable
  6. AnyRef
  7. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new ProcessAllWindowFunction()

    Permalink

Type Members

  1. abstract class Context extends AnyRef

    Permalink

    The context holding window metadata

Abstract Value Members

  1. abstract def process(context: Context, elements: Iterable[IN], out: Collector[OUT]): Unit

    Permalink

    Evaluates the window and outputs none or several elements.

    Evaluates the window and outputs none or several elements.

    context

    The context in which the window is being evaluated.

    elements

    The elements in the window being evaluated.

    out

    A collector for emitting elements.

    Annotations
    @throws( ... )
    Exceptions thrown

    Exception The function may throw exceptions to fail the program and trigger recovery.

Concrete Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  5. def clear(context: Context): Unit

    Permalink

    Deletes any state in the Context when the Window is purged.

    Deletes any state in the Context when the Window is purged.

    context

    The context to which the window is being evaluated

    Annotations
    @throws( ... )
    Exceptions thrown

    Exception The function may throw exceptions to fail the program and trigger recovery.

  6. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  7. def close(): Unit

    Permalink
    Definition Classes
    AbstractRichFunction → RichFunction
    Annotations
    @throws( classOf[java.lang.Exception] )
  8. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  9. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  10. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  11. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  12. def getIterationRuntimeContext(): IterationRuntimeContext

    Permalink
    Definition Classes
    AbstractRichFunction → RichFunction
  13. def getRuntimeContext(): RuntimeContext

    Permalink
    Definition Classes
    AbstractRichFunction → RichFunction
  14. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  15. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  16. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  17. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  18. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  19. def open(arg0: Configuration): Unit

    Permalink
    Definition Classes
    AbstractRichFunction → RichFunction
    Annotations
    @throws( classOf[java.lang.Exception] )
  20. def setRuntimeContext(arg0: RuntimeContext): Unit

    Permalink
    Definition Classes
    AbstractRichFunction → RichFunction
  21. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  22. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  23. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  24. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  25. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from AbstractRichFunction

Inherited from RichFunction

Inherited from Function

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped