W
- The window typeT
- The type of the input to the AggregateFunctionACC
- The type of the AggregateFunction's accumulatorV
- The type of the AggregateFunction's result, and the input to the WindowFunctionR
- The result type of the WindowFunctionpublic final class InternalAggregateProcessAllWindowFunction<T,ACC,V,R,W extends Window> extends WrappingFunction<ProcessAllWindowFunction<V,R,W>> implements InternalWindowFunction<Iterable<T>,R,Byte,W>
ProcessAllWindowFunction
that takes an Iterable
and an AggregateFunction
.InternalWindowFunction.InternalWindowContext
wrappedFunction
Constructor and Description |
---|
InternalAggregateProcessAllWindowFunction(AggregateFunction<T,ACC,V> aggFunction,
ProcessAllWindowFunction<V,R,W> windowFunction) |
Modifier and Type | Method and Description |
---|---|
void |
clear(W window,
InternalWindowFunction.InternalWindowContext context)
Deletes any state in the
Context when the Window expires (the watermark passes its
maxTimestamp + allowedLateness ). |
IterationRuntimeContext |
getIterationRuntimeContext()
Gets a specialized version of the
RuntimeContext , which has additional information
about the iteration in which the function is executed. |
RuntimeContext |
getRuntimeContext()
Gets the context that contains information about the UDF's runtime, such as the parallelism
of the function, the subtask index of the function, or the name of the task that executes the
function.
|
void |
open(Configuration parameters)
Initialization method for the function.
|
void |
process(Byte key,
W window,
InternalWindowFunction.InternalWindowContext context,
Iterable<T> input,
Collector<R> out)
Evaluates the window and outputs none or several elements.
|
close, getWrappedFunction, setRuntimeContext
public InternalAggregateProcessAllWindowFunction(AggregateFunction<T,ACC,V> aggFunction, ProcessAllWindowFunction<V,R,W> windowFunction)
public void open(Configuration parameters) throws Exception
RichFunction
The configuration object passed to the function can be used for configuration and initialization. The configuration contains all parameters that were configured on the function in the program composition.
public class MyFilter extends RichFilterFunction<String> {
private String searchString;
public void open(Configuration parameters) {
this.searchString = parameters.getString("foo");
}
public boolean filter(String value) {
return value.equals(searchString);
}
}
By default, this method does nothing.
open
in interface RichFunction
open
in class WrappingFunction<ProcessAllWindowFunction<V,R,W extends Window>>
parameters
- The configuration containing the parameters attached to the contract.Exception
- Implementations may forward exceptions, which are caught by the runtime.
When the runtime catches an exception, it aborts the task and lets the fail-over logic
decide whether to retry the task execution.Configuration
public void process(Byte key, W window, InternalWindowFunction.InternalWindowContext context, Iterable<T> input, Collector<R> out) throws Exception
InternalWindowFunction
process
in interface InternalWindowFunction<Iterable<T>,R,Byte,W extends Window>
context
- The context in which the window is being evaluated.input
- The elements in the window being evaluated.out
- A collector for emitting elements.Exception
- The function may throw exceptions to fail the program and trigger recovery.public void clear(W window, InternalWindowFunction.InternalWindowContext context) throws Exception
InternalWindowFunction
Context
when the Window expires (the watermark passes its
maxTimestamp
+ allowedLateness
).public RuntimeContext getRuntimeContext()
RichFunction
The RuntimeContext also gives access to the Accumulator
s and the DistributedCache
.
getRuntimeContext
in interface RichFunction
getRuntimeContext
in class AbstractRichFunction
public IterationRuntimeContext getIterationRuntimeContext()
RichFunction
RuntimeContext
, which has additional information
about the iteration in which the function is executed. This IterationRuntimeContext is only
available if the function is part of an iteration. Otherwise, this method throws an
exception.getIterationRuntimeContext
in interface RichFunction
getIterationRuntimeContext
in class AbstractRichFunction
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.