Modifier and Type | Method and Description |
---|---|
void |
CoGroupFunction.coGroup(Iterable<IN1> first,
Iterable<IN2> second,
Collector<O> out)
This method must be implemented to provide a user implementation of a
coGroup.
|
abstract void |
RichCoGroupFunction.coGroup(Iterable<IN1> first,
Iterable<IN2> second,
Collector<OUT> out) |
abstract void |
RichGroupCombineFunction.combine(Iterable<IN> values,
Collector<OUT> out) |
void |
GroupCombineFunction.combine(Iterable<IN> values,
Collector<OUT> out)
The combine method, called (potentially multiple timed) with subgroups of elements.
|
abstract void |
RichFlatMapFunction.flatMap(IN value,
Collector<OUT> out) |
void |
FlatMapFunction.flatMap(T value,
Collector<O> out)
The core method of the FlatMapFunction.
|
void |
FlatJoinFunction.join(IN1 first,
IN2 second,
Collector<OUT> out)
The join method, called once per joined pair of elements.
|
abstract void |
RichFlatJoinFunction.join(IN1 first,
IN2 second,
Collector<OUT> out) |
abstract void |
RichMapPartitionFunction.mapPartition(Iterable<I> values,
Collector<O> out) |
void |
MapPartitionFunction.mapPartition(Iterable<T> values,
Collector<O> out)
A user-implemented function that modifies or transforms an incoming object.
|
abstract void |
RichGroupReduceFunction.reduce(Iterable<IN> values,
Collector<OUT> out) |
void |
GroupReduceFunction.reduce(Iterable<T> values,
Collector<O> out)
The reduce method.
|
Modifier and Type | Class and Description |
---|---|
class |
CopyingListCollector<T> |
class |
ListCollector<T>
A
Collector that puts the collected elements into a given list. |
Modifier and Type | Method and Description |
---|---|
void |
BulkIterationBase.TerminationCriterionMapper.flatMap(X in,
Collector<X> out) |
Modifier and Type | Method and Description |
---|---|
void |
FirstReducer.combine(Iterable<T> values,
Collector<T> out) |
void |
FlatMapIterator.flatMap(IN value,
Collector<OUT> out)
Delegates calls to the
FlatMapIterator.flatMap(Object) method. |
void |
SampleInPartition.mapPartition(Iterable<T> values,
Collector<IntermediateSampleData<T>> out) |
void |
SampleWithFraction.mapPartition(Iterable<T> values,
Collector<T> out) |
void |
GroupReduceIterator.reduce(Iterable<IN> values,
Collector<OUT> out) |
void |
SampleInCoordinator.reduce(Iterable<IntermediateSampleData<T>> values,
Collector<T> out) |
void |
FirstReducer.reduce(Iterable<T> values,
Collector<T> out) |
Modifier and Type | Method and Description |
---|---|
void |
JoinOperator.DefaultJoin.WrappingFlatJoinFunction.join(IN1 left,
IN2 right,
Collector<OUT> out) |
Modifier and Type | Class and Description |
---|---|
class |
Tuple3WrappingCollector<IN,K1,K2>
Needed to wrap tuples to
Tuple3<groupKey, sortKey, value> for combine method of group reduce with key selector sorting. |
class |
TupleWrappingCollector<IN,K>
Needed to wrap tuples to
Tuple2<key, value> pairs for combine method of group reduce with key selector function. |
Modifier and Type | Method and Description |
---|---|
void |
CombineToGroupCombineWrapper.combine(Iterable<IN> values,
Collector<IN> out) |
void |
RichCombineToGroupCombineWrapper.combine(Iterable<IN> values,
Collector<IN> out) |
void |
PlanFilterOperator.FlatMapFilter.flatMap(T value,
Collector<T> out) |
void |
TupleRightUnwrappingJoiner.join(I1 value1,
Tuple2<K,I2> value2,
Collector<OUT> collector) |
void |
TupleLeftUnwrappingJoiner.join(Tuple2<K,I1> value1,
I2 value2,
Collector<OUT> collector) |
void |
TupleUnwrappingJoiner.join(Tuple2<K,I1> value1,
Tuple2<K,I2> value2,
Collector<OUT> collector) |
void |
CombineToGroupCombineWrapper.reduce(Iterable<IN> values,
Collector<OUT> out) |
void |
RichCombineToGroupCombineWrapper.reduce(Iterable<IN> values,
Collector<OUT> out) |
void |
TupleWrappingCollector.set(Collector<Tuple2<K,IN>> wrappedCollector) |
void |
Tuple3WrappingCollector.set(Collector<Tuple3<K1,K2,IN>> wrappedCollector) |
Modifier and Type | Method and Description |
---|---|
void |
PatternFlatSelectFunction.flatSelect(Map<String,List<IN>> pattern,
Collector<OUT> out)
Generates zero or more resulting elements given a map of detected pattern events.
|
void |
PatternFlatTimeoutFunction.timeout(Map<String,List<IN>> pattern,
long timeoutTimestamp,
Collector<OUT> out)
Generates zero or more resulting timeout elements given a map of partial pattern events and
the timestamp of the timeout.
|
Modifier and Type | Class and Description |
---|---|
class |
TimestampedSideOutputCollector<T>
|
Modifier and Type | Method and Description |
---|---|
void |
ConnectedComponents.UndirectEdge.flatMap(Tuple2<Long,Long> edge,
Collector<Tuple2<Long,Long>> out) |
void |
PageRank.JoinVertexWithEdgesMatch.flatMap(Tuple2<Tuple2<Long,Double>,Tuple2<Long,Long[]>> value,
Collector<Tuple2<Long,Double>> out) |
void |
ConnectedComponents.ComponentIdFilter.join(Tuple2<Long,Long> candidate,
Tuple2<Long,Long> old,
Collector<Tuple2<Long,Long>> out) |
void |
PageRank.BuildOutgoingEdgeList.reduce(Iterable<Tuple2<Long,Long>> values,
Collector<Tuple2<Long,Long[]>> out) |
Modifier and Type | Method and Description |
---|---|
void |
WebLogAnalysis.AntiJoinVisits.coGroup(Iterable<Tuple3<Integer,String,Integer>> ranks,
Iterable<Tuple1<String>> visits,
Collector<Tuple3<Integer,String,Integer>> out)
If the visit iterator is empty, all pairs of the rank iterator are emitted.
|
Modifier and Type | Method and Description |
---|---|
void |
WordCount.Tokenizer.flatMap(String value,
Collector<Tuple2<String,Integer>> out) |
void |
WordCountPojo.Tokenizer.flatMap(String value,
Collector<WordCountPojo.Word> out) |
Modifier and Type | Method and Description |
---|---|
void |
EdgesFunction.iterateEdges(Iterable<Tuple2<K,Edge<K,EV>>> edges,
Collector<O> out)
This method is called per vertex and can iterate over all of its neighboring edges
with the specified direction.
|
void |
EdgesFunctionWithVertexValue.iterateEdges(Vertex<K,VV> vertex,
Iterable<Edge<K,EV>> edges,
Collector<O> out)
This method is called per vertex and can iterate over all of its neighboring edges
with the specified direction.
|
void |
NeighborsFunction.iterateNeighbors(Iterable<Tuple3<K,Edge<K,EV>,Vertex<K,VV>>> neighbors,
Collector<O> out)
This method is called per vertex and can iterate over all of its neighbors
with the specified direction.
|
void |
NeighborsFunctionWithVertexValue.iterateNeighbors(Vertex<K,VV> vertex,
Iterable<Tuple2<Edge<K,EV>,Vertex<K,VV>>> neighbors,
Collector<O> out)
This method is called per vertex and can iterate over all of its neighbors
with the specified direction.
|
Modifier and Type | Method and Description |
---|---|
void |
BinaryResult.MirrorResult.flatMap(RT value,
Collector<RT> out) |
<T> TranslatableResult<T> |
TranslatableResult.translate(TranslateFunction<K,T> translator,
TranslatableResult<T> reuse,
Collector<TranslatableResult<T>> out)
Output the result after transforming the vertex ID type.
|
<T> TranslatableResult<T> |
BinaryResultBase.translate(TranslateFunction<K,T> translator,
TranslatableResult<T> reuse,
Collector<TranslatableResult<T>> out) |
<T> TranslatableResult<T> |
TertiaryResultBase.translate(TranslateFunction<K,T> translator,
TranslatableResult<T> reuse,
Collector<TranslatableResult<T>> out) |
<T> TranslatableResult<T> |
UnaryResultBase.translate(TranslateFunction<K,T> translator,
TranslatableResult<T> reuse,
Collector<TranslatableResult<T>> out) |
Modifier and Type | Method and Description |
---|---|
void |
ApplyFunction.setOutput(Vertex<K,VV> vertex,
Collector<Vertex<K,VV>> out) |
Modifier and Type | Method and Description |
---|---|
void |
HadoopReduceCombineFunction.combine(Iterable<Tuple2<KEYIN,VALUEIN>> values,
Collector<Tuple2<KEYIN,VALUEIN>> out) |
void |
HadoopMapFunction.flatMap(Tuple2<KEYIN,VALUEIN> value,
Collector<Tuple2<KEYOUT,VALUEOUT>> out) |
void |
HadoopReduceCombineFunction.reduce(Iterable<Tuple2<KEYIN,VALUEIN>> values,
Collector<Tuple2<KEYOUT,VALUEOUT>> out) |
void |
HadoopReduceFunction.reduce(Iterable<Tuple2<KEYIN,VALUEIN>> values,
Collector<Tuple2<KEYOUT,VALUEOUT>> out) |
Modifier and Type | Method and Description |
---|---|
void |
HadoopOutputCollector.setFlinkCollector(Collector<Tuple2<KEY,VALUE>> flinkCollector)
Set the wrapped Flink collector.
|
Modifier and Type | Method and Description |
---|---|
void |
PythonCoGroup.coGroup(Iterable<IN1> first,
Iterable<IN2> second,
Collector<OUT> out)
Calls the external python function.
|
void |
PythonMapPartition.mapPartition(Iterable<IN> values,
Collector<OUT> out) |
Modifier and Type | Method and Description |
---|---|
void |
IdentityGroupReduce.reduce(Iterable<IN> values,
Collector<IN> out) |
Modifier and Type | Method and Description |
---|---|
void |
PythonReceiver.collectBuffer(Collector<OUT> c,
int bufferSize)
Reads a buffer of the given size from the memory-mapped file, and collects all records contained.
|
void |
PythonDualInputStreamer.streamBufferWithGroups(Iterator<IN1> iterator1,
Iterator<IN2> iterator2,
Collector<OUT> c)
Sends all values contained in both iterators to the external process and collects all results.
|
void |
PythonSingleInputStreamer.streamBufferWithoutGroups(Iterator<IN> iterator,
Collector<OUT> c)
Sends all values contained in the iterator to the external process and collects all results.
|
Modifier and Type | Class and Description |
---|---|
class |
SolutionSetFastUpdateOutputCollector<T>
A
Collector to update the solution set of a workset iteration. |
class |
SolutionSetObjectsUpdateOutputCollector<T>
A
Collector to update the solution set of a workset iteration. |
class |
SolutionSetUpdateOutputCollector<T>
A
Collector to update the solution set of a workset iteration. |
class |
WorksetUpdateOutputCollector<T>
A
Collector to update the iteration workset (partial solution for bulk iterations). |
Constructor and Description |
---|
SolutionSetFastUpdateOutputCollector(CompactingHashTable<T> solutionSet,
Collector<T> delegate) |
SolutionSetObjectsUpdateOutputCollector(JoinHashMap<T> hashMap,
Collector<T> delegate) |
SolutionSetUpdateOutputCollector(CompactingHashTable<T> solutionSet,
Collector<T> delegate) |
WorksetUpdateOutputCollector(DataOutputView outputView,
TypeSerializer<T> serializer,
Collector<T> delegate) |
Modifier and Type | Method and Description |
---|---|
protected Collector<OT> |
AbstractIterativeTask.createSolutionSetUpdateOutputCollector(Collector<OT> delegate)
Creates a new solution set update output collector.
|
protected Collector<OT> |
AbstractIterativeTask.createWorksetUpdateOutputCollector() |
protected Collector<OT> |
AbstractIterativeTask.createWorksetUpdateOutputCollector(Collector<OT> delegate)
Creates a new
WorksetUpdateOutputCollector . |
Modifier and Type | Method and Description |
---|---|
protected Collector<OT> |
AbstractIterativeTask.createSolutionSetUpdateOutputCollector(Collector<OT> delegate)
Creates a new solution set update output collector.
|
protected Collector<OT> |
AbstractIterativeTask.createWorksetUpdateOutputCollector(Collector<OT> delegate)
Creates a new
WorksetUpdateOutputCollector . |
Modifier and Type | Class and Description |
---|---|
class |
NoOpChainedDriver<IT>
A chained driver that just passes on the input as the output
|
Modifier and Type | Field and Description |
---|---|
protected Collector<OT> |
BatchTask.output
The collector that forwards the user code's results.
|
Modifier and Type | Method and Description |
---|---|
protected Collector<OT> |
BatchTask.getLastOutputCollector() |
Collector<OT> |
BatchTask.getOutputCollector() |
Collector<OT> |
TaskContext.getOutputCollector() |
static <T> Collector<T> |
BatchTask.getOutputCollector(AbstractInvokable task,
TaskConfig config,
ClassLoader cl,
List<RecordWriter<?>> eventualOutputs,
int outputOffset,
int numOutputs)
Creates the
Collector for the given task, as described by the given configuration. |
static <T> Collector<T> |
BatchTask.initOutputs(AbstractInvokable containingTask,
ClassLoader cl,
TaskConfig config,
List<ChainedDriver<?,?>> chainedTasksTarget,
List<RecordWriter<?>> eventualOutputs,
ExecutionConfig executionConfig,
Map<String,Accumulator<?,?>> accumulatorMap)
Creates a writer for each output.
|
Modifier and Type | Method and Description |
---|---|
protected void |
BatchTask.setLastOutputCollector(Collector<OT> newOutputCollector)
|
Modifier and Type | Class and Description |
---|---|
class |
ChainedAllReduceDriver<IT> |
class |
ChainedDriver<IT,OT>
The interface to be implemented by drivers that do not run in an own task context, but are chained to other
tasks.
|
class |
ChainedFlatMapDriver<IT,OT> |
class |
ChainedMapDriver<IT,OT> |
class |
ChainedReduceCombineDriver<T>
Chained version of ReduceCombineDriver.
|
class |
ChainedTerminationCriterionDriver<IT,OT> |
class |
GroupCombineChainedDriver<IN,OUT>
Chained variant of the GroupReduceCombineDriver
Acts like a combiner with a custom output type OUT.
|
class |
SynchronousChainedCombineDriver<IN,OUT>
The chained variant of the combine driver which is also implemented in GroupReduceCombineDriver.
|
Modifier and Type | Field and Description |
---|---|
protected Collector<OT> |
ChainedDriver.outputCollector |
Modifier and Type | Method and Description |
---|---|
Collector<OT> |
ChainedDriver.getOutputCollector() |
Modifier and Type | Method and Description |
---|---|
void |
ChainedDriver.setOutputCollector(Collector<?> outputCollector) |
void |
ChainedDriver.setup(TaskConfig config,
String taskName,
Collector<OT> outputCollector,
AbstractInvokable parent,
ClassLoader userCodeClassLoader,
ExecutionConfig executionConfig,
Map<String,Accumulator<?,?>> accumulatorMap) |
Modifier and Type | Method and Description |
---|---|
boolean |
NonReusingBuildFirstHashJoinIterator.callWithNextKey(FlatJoinFunction<V1,V2,O> matchFunction,
Collector<O> collector) |
boolean |
ReusingBuildSecondHashJoinIterator.callWithNextKey(FlatJoinFunction<V1,V2,O> matchFunction,
Collector<O> collector) |
boolean |
ReusingBuildFirstHashJoinIterator.callWithNextKey(FlatJoinFunction<V1,V2,O> matchFunction,
Collector<O> collector) |
boolean |
NonReusingBuildSecondHashJoinIterator.callWithNextKey(FlatJoinFunction<V1,V2,O> matchFunction,
Collector<O> collector) |
Constructor and Description |
---|
ReduceFacade(ReduceFunction<T> reducer,
Collector<T> outputCollector,
boolean objectReuseEnabled) |
Modifier and Type | Class and Description |
---|---|
class |
OutputCollector<T>
The OutputCollector collects records, and emits them to the
RecordWriter s. |
Modifier and Type | Method and Description |
---|---|
abstract boolean |
AbstractMergeIterator.callWithNextKey(FlatJoinFunction<T1,T2,O> joinFunction,
Collector<O> collector)
Calls the
JoinFunction#join() method for all two key-value pairs that share the same key and come
from different inputs. |
boolean |
AbstractMergeInnerJoinIterator.callWithNextKey(FlatJoinFunction<T1,T2,O> joinFunction,
Collector<O> collector)
Calls the
JoinFunction#join() method for all two key-value pairs that share the same key and come
from different inputs. |
boolean |
AbstractMergeOuterJoinIterator.callWithNextKey(FlatJoinFunction<T1,T2,O> joinFunction,
Collector<O> collector)
Calls the
JoinFunction#join() method for all two key-value pairs that share the same key and come
from different inputs. |
protected void |
AbstractMergeIterator.crossMatchingGroup(Iterator<T1> values1,
Iterator<T2> values2,
FlatJoinFunction<T1,T2,O> joinFunction,
Collector<O> collector) |
Modifier and Type | Method and Description |
---|---|
void |
AssignRangeIndex.mapPartition(Iterable<IN> values,
Collector<Tuple2<Integer,IN>> out) |
void |
RangeBoundaryBuilder.mapPartition(Iterable<T> values,
Collector<Object[][]> out) |
Modifier and Type | Method and Description |
---|---|
boolean |
JoinTaskIterator.callWithNextKey(FlatJoinFunction<V1,V2,O> matchFunction,
Collector<O> collector)
Moves the internal pointer to the next key that both inputs share.
|
Modifier and Type | Class and Description |
---|---|
class |
CountingCollector<OUT> |
Constructor and Description |
---|
CountingCollector(Collector<OUT> collector,
Counter numRecordsOut) |
Modifier and Type | Method and Description |
---|---|
void |
SpoutSourceWordCount.Tokenizer.flatMap(String value,
Collector<Tuple2<String,Integer>> out) |
Modifier and Type | Class and Description |
---|---|
class |
CopyingDirectedOutput<OUT>
Special version of
DirectedOutput that performs a shallow copy of the
StreamRecord to ensure that multi-chaining works correctly. |
class |
DirectedOutput<OUT>
|
Modifier and Type | Method and Description |
---|---|
void |
ProcessFunction.onTimer(long timestamp,
ProcessFunction.OnTimerContext ctx,
Collector<O> out)
Called when a timer set using
TimerService fires. |
abstract void |
ProcessFunction.processElement(I value,
ProcessFunction.Context ctx,
Collector<O> out)
Process one element from the input stream.
|
Modifier and Type | Method and Description |
---|---|
void |
CoFlatMapFunction.flatMap1(IN1 value,
Collector<OUT> out)
This method is called for each element in the first of the connected streams.
|
void |
CoFlatMapFunction.flatMap2(IN2 value,
Collector<OUT> out)
This method is called for each element in the second of the connected streams.
|
void |
CoProcessFunction.onTimer(long timestamp,
CoProcessFunction.OnTimerContext ctx,
Collector<OUT> out)
Called when a timer set using
TimerService fires. |
abstract void |
CoProcessFunction.processElement1(IN1 value,
CoProcessFunction.Context ctx,
Collector<OUT> out)
This method is called for each element in the first of the connected streams.
|
abstract void |
CoProcessFunction.processElement2(IN2 value,
CoProcessFunction.Context ctx,
Collector<OUT> out)
This method is called for each element in the second of the connected streams.
|
Modifier and Type | Method and Description |
---|---|
void |
FileReadFunction.flatMap(Tuple3<String,Long,Long> value,
Collector<String> out)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
WindowFunction.apply(KEY key,
W window,
Iterable<IN> input,
Collector<OUT> out)
Evaluates the window and outputs none or several elements.
|
void |
FoldApplyWindowFunction.apply(K key,
W window,
Iterable<T> values,
Collector<R> out)
Deprecated.
|
void |
ReduceApplyWindowFunction.apply(K k,
W window,
Iterable<T> input,
Collector<R> out) |
void |
AggregateApplyWindowFunction.apply(K key,
W window,
Iterable<T> values,
Collector<R> out) |
void |
PassThroughWindowFunction.apply(K k,
W window,
Iterable<T> input,
Collector<T> out) |
void |
AllWindowFunction.apply(W window,
Iterable<IN> values,
Collector<OUT> out)
Evaluates the window and outputs none or several elements.
|
void |
ReduceApplyAllWindowFunction.apply(W window,
Iterable<T> input,
Collector<R> out) |
void |
FoldApplyAllWindowFunction.apply(W window,
Iterable<T> values,
Collector<R> out)
Deprecated.
|
void |
AggregateApplyAllWindowFunction.apply(W window,
Iterable<T> values,
Collector<R> out) |
void |
PassThroughAllWindowFunction.apply(W window,
Iterable<T> input,
Collector<T> out) |
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) |
abstract void |
ProcessAllWindowFunction.process(ProcessAllWindowFunction.Context context,
Iterable<IN> elements,
Collector<OUT> out)
Evaluates the window and outputs none or several elements.
|
void |
FoldApplyProcessAllWindowFunction.process(ProcessAllWindowFunction.Context context,
Iterable<T> values,
Collector<R> out)
Deprecated.
|
void |
ReduceApplyProcessAllWindowFunction.process(ProcessAllWindowFunction.Context context,
Iterable<T> input,
Collector<R> out) |
Modifier and Type | Interface and Description |
---|---|
interface |
Output<T>
A
StreamOperator is supplied with an object
of this interface that can be used to emit elements and other messages, such as barriers
and watermarks, from an operator. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractStreamOperator.CountingOutput
Wrapping
Output that updates metrics on the number of emitted elements. |
class |
TimestampedCollector<T>
|
Modifier and Type | Method and Description |
---|---|
void |
IncrementalLearningSkeleton.PartialModelBuilder.apply(TimeWindow window,
Iterable<Integer> values,
Collector<Double[]> out) |
Modifier and Type | Method and Description |
---|---|
void |
SideOutputExample.Tokenizer.processElement(String value,
ProcessFunction.Context ctx,
Collector<Tuple2<String,Integer>> out) |
Modifier and Type | Method and Description |
---|---|
void |
TwitterExample.SelectEnglishAndTokenizeFlatMap.flatMap(String value,
Collector<Tuple2<String,Integer>> out)
Select the language from the incoming JSON text.
|
Modifier and Type | Method and Description |
---|---|
void |
WordCount.Tokenizer.flatMap(String value,
Collector<Tuple2<String,Integer>> out) |
Modifier and Type | Class and Description |
---|---|
class |
RecordWriterOutput<OUT>
Implementation of
Output that sends data using a RecordWriter . |
Modifier and Type | Method and Description |
---|---|
void |
InternalSingleValueProcessAllWindowFunction.process(Byte key,
W window,
InternalWindowFunction.InternalWindowContext context,
IN input,
Collector<OUT> out) |
void |
InternalSingleValueAllWindowFunction.process(Byte key,
W window,
InternalWindowFunction.InternalWindowContext context,
IN input,
Collector<OUT> out) |
void |
InternalIterableProcessAllWindowFunction.process(Byte key,
W window,
InternalWindowFunction.InternalWindowContext context,
Iterable<IN> input,
Collector<OUT> out) |
void |
InternalIterableAllWindowFunction.process(Byte key,
W window,
InternalWindowFunction.InternalWindowContext context,
Iterable<IN> input,
Collector<OUT> out) |
void |
InternalAggregateProcessAllWindowFunction.process(Byte key,
W window,
InternalWindowFunction.InternalWindowContext context,
Iterable<T> input,
Collector<R> out) |
void |
InternalWindowFunction.process(KEY key,
W window,
InternalWindowFunction.InternalWindowContext context,
IN input,
Collector<OUT> out)
Evaluates the window and outputs none or several elements.
|
void |
InternalSingleValueWindowFunction.process(KEY key,
W window,
InternalWindowFunction.InternalWindowContext context,
IN input,
Collector<OUT> out) |
void |
InternalSingleValueProcessWindowFunction.process(KEY key,
W window,
InternalWindowFunction.InternalWindowContext context,
IN input,
Collector<OUT> out) |
void |
InternalIterableProcessWindowFunction.process(KEY key,
W window,
InternalWindowFunction.InternalWindowContext context,
Iterable<IN> input,
Collector<OUT> out) |
void |
InternalIterableWindowFunction.process(KEY key,
W window,
InternalWindowFunction.InternalWindowContext context,
Iterable<IN> input,
Collector<OUT> out) |
void |
InternalAggregateProcessWindowFunction.process(K key,
W window,
InternalWindowFunction.InternalWindowContext context,
Iterable<T> input,
Collector<R> out) |
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.