I1
- The type of the first input DataSet of the CoGroup transformation.I2
- The type of the second input DataSet of the CoGroup transformation.OUT
- The type of the result of the CoGroup transformation.@Deprecated @Public public class CoGroupOperator<I1,I2,OUT> extends TwoInputUdfOperator<I1,I2,OUT,CoGroupOperator<I1,I2,OUT>>
DataSet
that is the result of a CoGroup transformation.Modifier and Type | Class and Description |
---|---|
static class |
CoGroupOperator.CoGroupOperatorSets<I1,I2>
Deprecated.
Intermediate step of a CoGroup transformation.
|
minResources, name, parallelism, preferredResources
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)
Deprecated.
|
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)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
protected CoGroupFunction<I1,I2,OUT> |
getFunction()
Deprecated.
|
protected Keys<I1> |
getKeys1()
Deprecated.
|
protected Keys<I2> |
getKeys2()
Deprecated.
|
Partitioner<?> |
getPartitioner()
Deprecated.
Gets the custom partitioner used by this join, or
null , if none is set. |
DualInputSemanticProperties |
getSemanticProperties()
Deprecated.
Gets the semantic properties that have been set for the user-defined functions (UDF).
|
protected CoGroupOperatorBase<?,?,OUT,?> |
translateToDataFlow(Operator<I1> input1,
Operator<I2> input2)
Deprecated.
Translates this java API operator into a common API operator with two inputs.
|
CoGroupOperator<I1,I2,OUT> |
withPartitioner(Partitioner<?> partitioner)
Deprecated.
Sets a custom partitioner for the CoGroup operation.
|
extractSemanticAnnotationsFromUdf, getAnalyzedUdfSemanticsFlag, getBroadcastSets, getParameters, returns, returns, returns, setAnalyzedUdfSemanticsFlag, setSemanticProperties, udfWithForwardedFieldsFirstAnnotation, udfWithForwardedFieldsSecondAnnotation, withBroadcastSet, withForwardedFieldsFirst, withForwardedFieldsSecond, withParameters
getInput1, getInput1Type, getInput2, getInput2Type
getMinResources, getName, getParallelism, getPreferredResources, getResultType, name, setParallelism
aggregate, checkSameExecutionContext, clean, coGroup, collect, combineGroup, count, cross, crossWithHuge, crossWithTiny, distinct, distinct, distinct, distinct, fillInType, filter, first, flatMap, fullOuterJoin, fullOuterJoin, getExecutionEnvironment, getType, groupBy, groupBy, groupBy, iterate, iterateDelta, join, join, joinWithHuge, joinWithTiny, leftOuterJoin, leftOuterJoin, map, mapPartition, max, maxBy, min, minBy, output, partitionByHash, partitionByHash, partitionByHash, partitionByRange, partitionByRange, partitionByRange, partitionCustom, partitionCustom, partitionCustom, print, print, printOnTaskManager, printToErr, printToErr, project, rebalance, reduce, reduceGroup, rightOuterJoin, rightOuterJoin, runOperation, sortPartition, sortPartition, sortPartition, sum, union, write, write, writeAsCsv, writeAsCsv, writeAsCsv, writeAsCsv, writeAsFormattedText, writeAsFormattedText, writeAsText, writeAsText
public 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)
public 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)
protected CoGroupFunction<I1,I2,OUT> getFunction()
getFunction
in class TwoInputUdfOperator<I1,I2,OUT,CoGroupOperator<I1,I2,OUT>>
public DualInputSemanticProperties getSemanticProperties()
UdfOperator
getSemanticProperties
in interface UdfOperator<CoGroupOperator<I1,I2,OUT>>
getSemanticProperties
in class TwoInputUdfOperator<I1,I2,OUT,CoGroupOperator<I1,I2,OUT>>
public CoGroupOperator<I1,I2,OUT> withPartitioner(Partitioner<?> partitioner)
NOTE: A custom partitioner can only be used with single-field CoGroup keys, not with composite CoGroup keys.
partitioner
- The custom partitioner to be used.public Partitioner<?> getPartitioner()
null
, if none is set.@Internal protected CoGroupOperatorBase<?,?,OUT,?> translateToDataFlow(Operator<I1> input1, Operator<I2> input2)
TwoInputOperator
translateToDataFlow
in class TwoInputOperator<I1,I2,OUT,CoGroupOperator<I1,I2,OUT>>
input1
- The first input of the operation, as a common API operator.input2
- The second input of the operation, as a common API operator.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.