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.
|
abstract void |
RichFlatJoinFunction.join(IN1 first,
IN2 second,
Collector<OUT> out) |
void |
FlatJoinFunction.join(IN1 first,
IN2 second,
Collector<OUT> out)
The join method, called once per joined pair of elements.
|
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>
A
Collector that collects deep copies of its elements in a list. |
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 |
---|---|
default void |
DeserializationSchema.deserialize(byte[] message,
Collector<T> out)
Deserializes the byte message.
|
Modifier and Type | Method and Description |
---|---|
void |
FirstReducer.combine(Iterable<T> values,
Collector<T> out) |
void |
FlatMapIterator.flatMap(IN value,
Collector<OUT> out)
Deprecated.
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)
Deprecated.
|
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 |
---|---|
abstract void |
RichPatternFlatSelectFunction.flatSelect(Map<String,List<IN>> pattern,
Collector<OUT> out) |
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 | Method and Description |
---|---|
abstract void |
PatternProcessFunction.processMatch(Map<String,List<IN>> match,
PatternProcessFunction.Context ctx,
Collector<OUT> out)
Generates resulting elements given a map of detected pattern events.
|
Modifier and Type | Method and Description |
---|---|
void |
PatternSelectAdapter.processMatch(Map<String,List<IN>> match,
PatternProcessFunction.Context ctx,
Collector<OUT> out) |
void |
PatternFlatSelectAdapter.processMatch(Map<String,List<IN>> match,
PatternProcessFunction.Context ctx,
Collector<OUT> out) |
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 |
DebeziumAvroDeserializationSchema.deserialize(byte[] message,
Collector<RowData> out) |
Modifier and Type | Method and Description |
---|---|
void |
CanalJsonDeserializationSchema.deserialize(byte[] message,
Collector<RowData> out) |
Modifier and Type | Method and Description |
---|---|
void |
DebeziumJsonDeserializationSchema.deserialize(byte[] message,
Collector<RowData> out) |
Modifier and Type | Method and Description |
---|---|
void |
MaxwellJsonDeserializationSchema.deserialize(byte[] message,
Collector<RowData> out) |
Modifier and Type | Method and Description |
---|---|
void |
OggJsonDeserializationSchema.deserialize(byte[] message,
Collector<RowData> 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 |
PythonConnectorUtils.RowRowMapper.processElement(Row row,
ProcessFunction.Context ctx,
Collector<RowData> out) |
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> |
TaskContext.getOutputCollector() |
Collector<OT> |
BatchTask.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,
UserCodeClassLoader 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 |
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,
UserCodeClassLoader 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 |
NonReusingBuildSecondHashJoinIterator.callWithNextKey(FlatJoinFunction<V1,V2,O> matchFunction,
Collector<O> collector) |
boolean |
ReusingBuildFirstHashJoinIterator.callWithNextKey(FlatJoinFunction<V1,V2,O> matchFunction,
Collector<O> collector) |
boolean |
ReusingBuildSecondHashJoinIterator.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 |
---|---|
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. |
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. |
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. |
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 |
---|---|
abstract void |
KeyedStateReaderFunction.readKey(K key,
KeyedStateReaderFunction.Context ctx,
Collector<OUT> out)
Process one key from the restored state backend.
|
abstract void |
WindowReaderFunction.readWindow(KEY key,
WindowReaderFunction.Context<W> context,
Iterable<IN> elements,
Collector<OUT> out)
Evaluates the window and outputs none or several elements.
|
Modifier and Type | Method and Description |
---|---|
abstract void |
StateReaderOperator.processElement(KEY key,
N namespace,
Collector<OUT> out) |
void |
KeyedStateReaderOperator.processElement(KEY key,
VoidNamespace namespace,
Collector<OUT> out) |
void |
WindowReaderOperator.processElement(KEY key,
W namespace,
Collector<OUT> out) |
Modifier and Type | Method and Description |
---|---|
void |
PassThroughReader.readWindow(KEY key,
WindowReaderFunction.Context<W> context,
Iterable<IN> elements,
Collector<IN> out) |
void |
EvictingWindowReaderFunction.readWindow(KEY key,
WindowReaderFunction.Context<W> context,
Iterable<StreamRecord<IN>> elements,
Collector<OUT> out) |
Modifier and Type | Method and Description |
---|---|
void |
StatePathExtractor.flatMap(OperatorState operatorState,
Collector<Path> out) |
void |
BoundedOneInputStreamTaskRunner.mapPartition(Iterable<IN> values,
Collector<TaggedOperatorSubtaskState> out)
Deprecated.
|
void |
MergeOperatorStates.reduce(Iterable<OperatorState> values,
Collector<CheckpointMetadata> out) |
void |
OperatorSubtaskStateReducer.reduce(Iterable<TaggedOperatorSubtaskState> values,
Collector<OperatorState> out) |
Modifier and Type | Method and Description |
---|---|
void |
KeyedProcessFunction.onTimer(long timestamp,
KeyedProcessFunction.OnTimerContext ctx,
Collector<O> out)
Called when a timer set using
TimerService fires. |
void |
ProcessFunction.onTimer(long timestamp,
ProcessFunction.OnTimerContext ctx,
Collector<O> out)
Called when a timer set using
TimerService fires. |
abstract void |
KeyedProcessFunction.processElement(I value,
KeyedProcessFunction.Context ctx,
Collector<O> out)
Process one element from the input stream.
|
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. |
void |
KeyedBroadcastProcessFunction.onTimer(long timestamp,
KeyedBroadcastProcessFunction.OnTimerContext ctx,
Collector<OUT> out)
Called when a timer set using
TimerService fires. |
void |
KeyedCoProcessFunction.onTimer(long timestamp,
KeyedCoProcessFunction.OnTimerContext ctx,
Collector<OUT> out)
Called when a timer set using
TimerService fires. |
abstract void |
BroadcastProcessFunction.processBroadcastElement(IN2 value,
BroadcastProcessFunction.Context ctx,
Collector<OUT> out)
This method is called for each element in the
broadcast stream . |
abstract void |
KeyedBroadcastProcessFunction.processBroadcastElement(IN2 value,
KeyedBroadcastProcessFunction.Context ctx,
Collector<OUT> out)
This method is called for each element in the
broadcast stream . |
abstract void |
BroadcastProcessFunction.processElement(IN1 value,
BroadcastProcessFunction.ReadOnlyContext ctx,
Collector<OUT> out)
This method is called for each element in the (non-broadcast)
data stream . |
abstract void |
ProcessJoinFunction.processElement(IN1 left,
IN2 right,
ProcessJoinFunction.Context ctx,
Collector<OUT> out)
This method is called for each joined pair of elements.
|
abstract void |
KeyedBroadcastProcessFunction.processElement(IN1 value,
KeyedBroadcastProcessFunction.ReadOnlyContext ctx,
Collector<OUT> out)
This method is called for each element in the (non-broadcast)
keyed stream . |
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 |
KeyedCoProcessFunction.processElement1(IN1 value,
KeyedCoProcessFunction.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.
|
abstract void |
KeyedCoProcessFunction.processElement2(IN2 value,
KeyedCoProcessFunction.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 |
AggregateApplyWindowFunction.apply(K key,
W window,
Iterable<T> values,
Collector<R> out) |
void |
ReduceApplyWindowFunction.apply(K k,
W window,
Iterable<T> input,
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 |
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 |
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 |
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 |
CountingOutput<OUT>
Wrapping
Output that updates metrics on the number of emitted elements. |
class |
TimestampedCollector<T>
|
Modifier and Type | Class and Description |
---|---|
class |
RunnerOutputCollector<OUT>
Output collector for Python UDF runner.
|
Modifier and Type | Method and Description |
---|---|
void |
IterateExample.Step.processElement(Tuple5<Integer,Integer,Integer,Integer,Integer> value,
ProcessFunction.Context ctx,
Collector<Tuple5<Integer,Integer,Integer,Integer,Integer>> 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 |
---|---|
static void |
StandaloneThreadedGenerator.runGenerator(Collector<Event>[] collectors) |
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 |
InternalSingleValueAllWindowFunction.process(Byte key,
W window,
InternalWindowFunction.InternalWindowContext context,
IN input,
Collector<OUT> out) |
void |
InternalSingleValueProcessAllWindowFunction.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 |
InternalSingleValueProcessWindowFunction.process(KEY key,
W window,
InternalWindowFunction.InternalWindowContext context,
IN input,
Collector<OUT> out) |
void |
InternalSingleValueWindowFunction.process(KEY key,
W window,
InternalWindowFunction.InternalWindowContext context,
IN input,
Collector<OUT> 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 |
InternalIterableWindowFunction.process(KEY key,
W window,
InternalWindowFunction.InternalWindowContext context,
Iterable<IN> input,
Collector<OUT> out) |
void |
InternalIterableProcessWindowFunction.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) |
Modifier and Type | Interface and Description |
---|---|
interface |
OutputWithChainingCheck<OUT>
This is a wrapper for outputs to check whether the collected record has been emitted to a
downstream subtask or to a chained operator.
|
interface |
WatermarkGaugeExposingOutput<T>
An
Output that measures the last emitted watermark with a WatermarkGauge . |
Modifier and Type | Class and Description |
---|---|
class |
FinishedOnRestoreMainOperatorOutput<OUT>
A fake main operator output that skips all the following operators for finished on restored
tasks.
|
Modifier and Type | Method and Description |
---|---|
void |
SemanticsCheckMapper.flatMap(Event event,
Collector<String> out) |
void |
SlidingWindowCheckMapper.flatMap(Tuple2<Integer,List<Event>> value,
Collector<String> out) |
Modifier and Type | Interface and Description |
---|---|
static interface |
TableAggregateFunction.RetractableCollector<T>
Collects a record and forwards it.
|
Modifier and Type | Method and Description |
---|---|
void |
TableFunction.setCollector(Collector<T> collector)
Internal use.
|
Modifier and Type | Class and Description |
---|---|
class |
ListenableCollector<T>
A listenable collector for lookup join that can be called when an original record was collected.
|
class |
TableFunctionCollector<T>
The basic implementation of collector for
TableFunction . |
class |
WrappingCollector<T>
A
Collector that wraps another collector. |
Modifier and Type | Method and Description |
---|---|
void |
TableFunctionCollector.setCollector(Collector<?> collector)
Sets the current collector, which used to emit the final row.
|
void |
WrappingCollector.setCollector(Collector<T> collector)
Sets the current collector which is used to emit the final result.
|
Modifier and Type | Class and Description |
---|---|
class |
GeneratedCollector<C extends Collector<?>>
Describes a generated
Collector . |
Modifier and Type | Method and Description |
---|---|
void |
TableAggsHandleFunction.emitValue(Collector<RowData> out,
RowData currentKey,
boolean isRetract)
Emit the result of the table aggregation through the collector.
|
void |
NamespaceTableAggsHandleFunction.emitValue(N namespace,
RowData key,
Collector<RowData> out)
Emits the result of the aggregation from the current accumulators and namespace properties
(like window start).
|
Modifier and Type | Method and Description |
---|---|
void |
MiniBatchGroupAggFunction.finishBundle(Map<RowData,List<RowData>> buffer,
Collector<RowData> out) |
void |
MiniBatchGlobalGroupAggFunction.finishBundle(Map<RowData,RowData> buffer,
Collector<RowData> out) |
void |
MiniBatchIncrementalGroupAggFunction.finishBundle(Map<RowData,RowData> buffer,
Collector<RowData> out) |
void |
MiniBatchLocalGroupAggFunction.finishBundle(Map<RowData,RowData> buffer,
Collector<RowData> out) |
void |
GroupAggFunction.processElement(RowData input,
KeyedProcessFunction.Context ctx,
Collector<RowData> out) |
void |
GroupTableAggFunction.processElement(RowData input,
KeyedProcessFunction.Context ctx,
Collector<RowData> out) |
Modifier and Type | Method and Description |
---|---|
WindowBuffer |
WindowBuffer.LocalFactory.create(Object operatorOwner,
MemoryManager memoryManager,
long memorySize,
RuntimeContext runtimeContext,
Collector<RowData> collector,
ZoneId shiftTimeZone)
Creates a
WindowBuffer for local window that buffers elements in memory before
flushing. |
WindowBuffer |
RecordsWindowBuffer.LocalFactory.create(Object operatorOwner,
MemoryManager memoryManager,
long memorySize,
RuntimeContext runtimeContext,
Collector<RowData> collector,
ZoneId shiftTimeZone) |
Modifier and Type | Method and Description |
---|---|
RecordsCombiner |
LocalAggCombiner.Factory.createRecordsCombiner(RuntimeContext runtimeContext,
Collector<RowData> collector) |
Constructor and Description |
---|
LocalAggCombiner(NamespaceAggsHandleFunction<Long> aggregator,
Collector<RowData> collector) |
Modifier and Type | Method and Description |
---|---|
abstract void |
MapBundleFunction.finishBundle(Map<K,V> buffer,
Collector<OUT> out)
Called when a bundle is finished.
|
Modifier and Type | Method and Description |
---|---|
static void |
RowTimeDeduplicateFunction.deduplicateOnRowTime(ValueState<RowData> state,
RowData currentRow,
Collector<RowData> out,
boolean generateUpdateBefore,
boolean generateInsert,
int rowtimeIndex,
boolean keepLastRow)
Processes element to deduplicate on keys with row time semantic, sends current element if it
is last or first row, retracts previous element if needed.
|
void |
RowTimeMiniBatchDeduplicateFunction.finishBundle(Map<RowData,List<RowData>> buffer,
Collector<RowData> out) |
void |
ProcTimeMiniBatchDeduplicateKeepFirstRowFunction.finishBundle(Map<RowData,RowData> buffer,
Collector<RowData> out) |
void |
RowTimeMiniBatchLatestChangeDeduplicateFunction.finishBundle(Map<RowData,RowData> buffer,
Collector<RowData> out) |
void |
ProcTimeMiniBatchDeduplicateKeepLastRowFunction.finishBundle(Map<RowData,RowData> buffer,
Collector<RowData> out) |
void |
RowTimeDeduplicateFunction.processElement(RowData input,
KeyedProcessFunction.Context ctx,
Collector<RowData> out) |
void |
ProcTimeDeduplicateKeepLastRowFunction.processElement(RowData input,
KeyedProcessFunction.Context ctx,
Collector<RowData> out) |
void |
ProcTimeDeduplicateKeepFirstRowFunction.processElement(RowData input,
KeyedProcessFunction.Context ctx,
Collector<RowData> out) |
Modifier and Type | Method and Description |
---|---|
void |
FilterAllFlatMapFunction.flatMap(RowData value,
Collector<RowData> out) |
void |
IntervalJoinFunction.join(RowData first,
RowData second,
Collector<RowData> out) |
Modifier and Type | Method and Description |
---|---|
Collector<RowData> |
LookupJoinRunner.getFetcherCollector() |
Collector<RowData> |
LookupJoinWithCalcRunner.getFetcherCollector() |
Modifier and Type | Method and Description |
---|---|
void |
LookupJoinRunner.padNullForLeftJoin(RowData in,
Collector<RowData> out) |
void |
LookupJoinRunner.prepareCollector(RowData in,
Collector<RowData> out) |
void |
KeyedLookupJoinWrapper.processElement(RowData in,
KeyedProcessFunction.Context ctx,
Collector<RowData> out) |
void |
LookupJoinRunner.processElement(RowData in,
ProcessFunction.Context ctx,
Collector<RowData> out) |
Modifier and Type | Method and Description |
---|---|
void |
PatternProcessFunctionRunner.processMatch(Map<String,List<RowData>> match,
PatternProcessFunction.Context ctx,
Collector<RowData> out) |
Modifier and Type | Class and Description |
---|---|
class |
BroadcastingOutput
An
Output that can be used to emit elements and other messages to multiple outputs. |
class |
CopyingBroadcastingOutput
Special version of
BroadcastingOutput that performs a shallow copy of the StreamRecord to ensure that multi-output works correctly. |
class |
CopyingFirstInputOfTwoInputStreamOperatorOutput
An
Output that can be used to emit copying elements and other messages for the first
input of TwoInputStreamOperator . |
class |
CopyingOneInputStreamOperatorOutput
An
Output that can be used to emit copying elements and other messages for OneInputStreamOperator . |
class |
CopyingSecondInputOfTwoInputStreamOperatorOutput
An
Output that can be used to emit copying elements and other messages for the second
input of TwoInputStreamOperator . |
class |
FirstInputOfTwoInputStreamOperatorOutput
An
Output that can be used to emit elements and other messages for the first input of
TwoInputStreamOperator . |
class |
OneInputStreamOperatorOutput
An
Output that can be used to emit elements and other messages for OneInputStreamOperator . |
class |
OutputBase
Base
Output that can be used to emit elements and other messages in MultipleInputStreamOperatorBase . |
class |
SecondInputOfTwoInputStreamOperatorOutput
An
Output that can be used to emit elements and other messages for the second input of
TwoInputStreamOperator . |
Modifier and Type | Method and Description |
---|---|
void |
RowTimeRowsBoundedPrecedingFunction.onTimer(long timestamp,
KeyedProcessFunction.OnTimerContext ctx,
Collector<RowData> out) |
void |
ProcTimeRangeBoundedPrecedingFunction.onTimer(long timestamp,
KeyedProcessFunction.OnTimerContext ctx,
Collector<RowData> out) |
void |
AbstractRowTimeUnboundedPrecedingOver.onTimer(long timestamp,
KeyedProcessFunction.OnTimerContext ctx,
Collector<RowData> out) |
void |
ProcTimeRowsBoundedPrecedingFunction.onTimer(long timestamp,
KeyedProcessFunction.OnTimerContext ctx,
Collector<RowData> out) |
void |
RowTimeRangeBoundedPrecedingFunction.onTimer(long timestamp,
KeyedProcessFunction.OnTimerContext ctx,
Collector<RowData> out) |
void |
ProcTimeUnboundedPrecedingFunction.processElement(RowData input,
KeyedProcessFunction.Context ctx,
Collector<RowData> out) |
void |
RowTimeRowsBoundedPrecedingFunction.processElement(RowData input,
KeyedProcessFunction.Context ctx,
Collector<RowData> out) |
void |
ProcTimeRangeBoundedPrecedingFunction.processElement(RowData input,
KeyedProcessFunction.Context ctx,
Collector<RowData> out) |
void |
AbstractRowTimeUnboundedPrecedingOver.processElement(RowData input,
KeyedProcessFunction.Context ctx,
Collector<RowData> out)
Puts an element from the input stream into state if it is not late.
|
void |
ProcTimeRowsBoundedPrecedingFunction.processElement(RowData input,
KeyedProcessFunction.Context ctx,
Collector<RowData> out) |
void |
RowTimeRangeBoundedPrecedingFunction.processElement(RowData input,
KeyedProcessFunction.Context ctx,
Collector<RowData> out) |
void |
RowTimeRowsUnboundedPrecedingFunction.processElementsWithSameTimestamp(List<RowData> curRowList,
Collector<RowData> out) |
protected abstract void |
AbstractRowTimeUnboundedPrecedingOver.processElementsWithSameTimestamp(List<RowData> curRowList,
Collector<RowData> out)
Process the same timestamp datas, the mechanism is different between rows and range window.
|
void |
RowTimeRangeUnboundedPrecedingFunction.processElementsWithSameTimestamp(List<RowData> curRowList,
Collector<RowData> out) |
Modifier and Type | Class and Description |
---|---|
class |
StreamRecordRowDataWrappingCollector
The collector is used to convert a
RowData to a StreamRecord . |
Constructor and Description |
---|
StreamRecordRowDataWrappingCollector(Collector<StreamRecord<RowData>> out) |
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractTopNFunction.collectDelete(Collector<RowData> out,
RowData inputRow) |
protected void |
AbstractTopNFunction.collectDelete(Collector<RowData> out,
RowData inputRow,
long rank) |
protected void |
AbstractTopNFunction.collectInsert(Collector<RowData> out,
RowData inputRow) |
protected void |
AbstractTopNFunction.collectInsert(Collector<RowData> out,
RowData inputRow,
long rank) |
protected void |
AbstractTopNFunction.collectUpdateAfter(Collector<RowData> out,
RowData inputRow) |
protected void |
AbstractTopNFunction.collectUpdateAfter(Collector<RowData> out,
RowData inputRow,
long rank) |
protected void |
AbstractTopNFunction.collectUpdateBefore(Collector<RowData> out,
RowData inputRow) |
protected void |
AbstractTopNFunction.collectUpdateBefore(Collector<RowData> out,
RowData inputRow,
long rank) |
void |
RetractableTopNFunction.processElement(RowData input,
KeyedProcessFunction.Context ctx,
Collector<RowData> out) |
void |
AppendOnlyFirstNFunction.processElement(RowData input,
KeyedProcessFunction.Context context,
Collector<RowData> out) |
void |
AppendOnlyTopNFunction.processElement(RowData input,
KeyedProcessFunction.Context context,
Collector<RowData> out) |
void |
UpdatableTopNFunction.processElement(RowData input,
KeyedProcessFunction.Context context,
Collector<RowData> out) |
void |
FastTop1Function.processElement(RowData input,
KeyedProcessFunction.Context ctx,
Collector<RowData> out) |
Modifier and Type | Method and Description |
---|---|
RecordsCombiner |
RecordsCombiner.LocalFactory.createRecordsCombiner(RuntimeContext runtimeContext,
Collector<RowData> collector) |
Modifier and Type | Class and Description |
---|---|
class |
StreamRecordCollector<T>
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.