Package | Description |
---|---|
org.apache.flink.streaming.api.functions.windowing | |
org.apache.flink.streaming.runtime.operators.windowing.functions |
Modifier and Type | Class and Description |
---|---|
class |
InternalProcessApplyWindowContext<IN,OUT,KEY,W extends Window>
Internal reusable context wrapper.
|
Modifier and Type | Method and Description |
---|---|
void |
ProcessWindowFunction.clear(ProcessWindowFunction.Context context)
Deletes any state in the
Context when the Window is purged. |
void |
FoldApplyProcessWindowFunction.clear(ProcessWindowFunction.Context context)
Deprecated.
|
void |
ReduceApplyProcessWindowFunction.clear(ProcessWindowFunction.Context context) |
abstract void |
ProcessWindowFunction.process(KEY key,
ProcessWindowFunction.Context context,
Iterable<IN> elements,
Collector<OUT> out)
Evaluates the window and outputs none or several elements.
|
void |
FoldApplyProcessWindowFunction.process(K key,
ProcessWindowFunction.Context context,
Iterable<T> values,
Collector<R> out)
Deprecated.
|
void |
ReduceApplyProcessWindowFunction.process(K k,
ProcessWindowFunction.Context context,
Iterable<T> input,
Collector<R> out) |
Modifier and Type | Class and Description |
---|---|
class |
InternalProcessWindowContext<IN,OUT,KEY,W extends Window>
Internal reusable context wrapper.
|
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.