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.@Internal public class CoGroupRawOperator<I1,I2,OUT> extends TwoInputUdfOperator<I1,I2,OUT,CoGroupRawOperator<I1,I2,OUT>>
DataSet
that is the result of a CoGroup transformation.DataSet
minResources, name, parallelism, preferredResources
Constructor and Description |
---|
CoGroupRawOperator(DataSet<I1> input1,
DataSet<I2> input2,
Keys<I1> keys1,
Keys<I2> keys2,
CoGroupFunction<I1,I2,OUT> function,
TypeInformation<OUT> returnType,
String defaultName) |
Modifier and Type | Method and Description |
---|---|
protected Function |
getFunction() |
protected Keys<I1> |
getKeys1() |
protected Keys<I2> |
getKeys2() |
protected CoGroupRawOperatorBase<?,?,OUT,?> |
translateToDataFlow(Operator<I1> input1,
Operator<I2> input2)
Translates this java API operator into a common API operator with two inputs.
|
extractSemanticAnnotationsFromUdf, getAnalyzedUdfSemanticsFlag, getBroadcastSets, getParameters, getSemanticProperties, 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
protected CoGroupRawOperatorBase<?,?,OUT,?> translateToDataFlow(Operator<I1> input1, Operator<I2> input2)
TwoInputOperator
translateToDataFlow
in class TwoInputOperator<I1,I2,OUT,CoGroupRawOperator<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.protected Function getFunction()
getFunction
in class TwoInputUdfOperator<I1,I2,OUT,CoGroupRawOperator<I1,I2,OUT>>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.