Modifier and Type | Class and Description |
---|---|
class |
RichCoGroupFunction<IN1,IN2,OUT>
Rich variant of the
CoGroupFunction . |
Modifier and Type | Class and Description |
---|---|
class |
CoGroupOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> |
class |
CoGroupRawOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> |
Modifier and Type | Method and Description |
---|---|
protected CoGroupFunction<I1,I2,OUT> |
CoGroupOperator.getFunction() |
Modifier and Type | Method and Description |
---|---|
<R> CoGroupOperator<I1,I2,R> |
CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction.with(CoGroupFunction<I1,I2,R> function)
Finalizes a CoGroup transformation by applying a
RichCoGroupFunction to groups of elements
with identical keys. |
Constructor and Description |
---|
CoGroupOperator(DataSet<I1> input1,
DataSet<I2> input2,
Keys<I1> keys1,
Keys<I2> keys2,
CoGroupFunction<I1,I2,OUT> function,
TypeInformation<OUT> returnType,
List<org.apache.commons.lang3.tuple.Pair<Integer,Order>> groupSortKeyOrderFirst,
List<org.apache.commons.lang3.tuple.Pair<Integer,Order>> groupSortKeyOrderSecond,
Partitioner<?> customPartitioner,
String defaultName) |
CoGroupOperator(DataSet<I1> input1,
DataSet<I2> input2,
Keys<I1> keys1,
Keys<I2> keys2,
CoGroupFunction<I1,I2,OUT> function,
TypeInformation<OUT> returnType,
Partitioner<?> customPartitioner,
String defaultName) |
CoGroupRawOperator(DataSet<I1> input1,
DataSet<I2> input2,
Keys<I1> keys1,
Keys<I2> keys2,
CoGroupFunction<I1,I2,OUT> function,
TypeInformation<OUT> returnType,
String defaultName) |
Constructor and Description |
---|
PlanBothUnwrappingCoGroupOperator(CoGroupFunction<I1,I2,OUT> udf,
Keys.SelectorFunctionKeys<I1,K> key1,
Keys.SelectorFunctionKeys<I2,K> key2,
String name,
TypeInformation<OUT> type,
TypeInformation<Tuple2<K,I1>> typeInfoWithKey1,
TypeInformation<Tuple2<K,I2>> typeInfoWithKey2) |
PlanLeftUnwrappingCoGroupOperator(CoGroupFunction<I1,I2,OUT> udf,
Keys.SelectorFunctionKeys<I1,K> key1,
int[] key2,
String name,
TypeInformation<OUT> resultType,
TypeInformation<Tuple2<K,I1>> typeInfoWithKey1,
TypeInformation<I2> typeInfo2) |
PlanRightUnwrappingCoGroupOperator(CoGroupFunction<I1,I2,OUT> udf,
int[] key1,
Keys.SelectorFunctionKeys<I2,K> key2,
String name,
TypeInformation<OUT> resultType,
TypeInformation<I1> typeInfo1,
TypeInformation<Tuple2<K,I2>> typeInfoWithKey2) |
Modifier and Type | Method and Description |
---|---|
static <IN1,IN2,OUT> |
TypeExtractor.getCoGroupReturnTypes(CoGroupFunction<IN1,IN2,OUT> coGroupInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type) |
static <IN1,IN2,OUT> |
TypeExtractor.getCoGroupReturnTypes(CoGroupFunction<IN1,IN2,OUT> coGroupInterface,
TypeInformation<IN1> in1Type,
TypeInformation<IN2> in2Type,
String functionName,
boolean allowMissing) |
Modifier and Type | Class and Description |
---|---|
static class |
WebLogAnalysis.AntiJoinVisits
CoGroupFunction that realizes an anti-join.
|
Modifier and Type | Method and Description |
---|---|
Class<CoGroupFunction<IT1,IT2,OT>> |
CoGroupWithSolutionSetSecondDriver.getStubType() |
Class<CoGroupFunction<IT1,IT2,OT>> |
CoGroupDriver.getStubType() |
Class<CoGroupFunction<IT1,IT2,OT>> |
CoGroupRawDriver.getStubType() |
Class<CoGroupFunction<IT1,IT2,OT>> |
CoGroupWithSolutionSetFirstDriver.getStubType() |
Modifier and Type | Method and Description |
---|---|
void |
CoGroupWithSolutionSetSecondDriver.setup(TaskContext<CoGroupFunction<IT1,IT2,OT>,OT> context) |
void |
CoGroupDriver.setup(TaskContext<CoGroupFunction<IT1,IT2,OT>,OT> context) |
void |
CoGroupRawDriver.setup(TaskContext<CoGroupFunction<IT1,IT2,OT>,OT> context) |
void |
CoGroupWithSolutionSetFirstDriver.setup(TaskContext<CoGroupFunction<IT1,IT2,OT>,OT> context) |
Modifier and Type | Method and Description |
---|---|
<T> DataStream<T> |
CoGroupedStreams.WithWindow.apply(CoGroupFunction<T1,T2,T> function)
Completes the co-group operation with the user function that is executed for windowed
groups.
|
<T> DataStream<T> |
CoGroupedStreams.WithWindow.apply(CoGroupFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Completes the co-group operation with the user function that is executed for windowed
groups.
|
<T> SingleOutputStreamOperator<T> |
CoGroupedStreams.WithWindow.with(CoGroupFunction<T1,T2,T> function)
Deprecated.
This method will be removed once the
CoGroupedStreams.WithWindow.apply(CoGroupFunction) method
is fixed in the next major version of Flink (2.0). |
<T> SingleOutputStreamOperator<T> |
CoGroupedStreams.WithWindow.with(CoGroupFunction<T1,T2,T> function,
TypeInformation<T> resultType)
Deprecated.
This method will be removed once the
CoGroupedStreams.WithWindow.apply(CoGroupFunction,
TypeInformation) method is fixed in the next major version of Flink (2.0). |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.