I1
- The type of the first input DataSet of the Cross transformation.I2
- The type of the second input DataSet of the Cross transformation.OUT
- The type of the result of the Cross transformation.@Public public class CrossOperator<I1,I2,OUT> extends TwoInputUdfOperator<I1,I2,OUT,CrossOperator<I1,I2,OUT>>
DataSet
that is the result of a Cross transformation.DataSet
Modifier and Type | Class and Description |
---|---|
static class |
CrossOperator.CrossProjection<I1,I2> |
static class |
CrossOperator.DefaultCross<I1,I2>
A Cross transformation that wraps pairs of crossed elements into
Tuple2 . |
static class |
CrossOperator.ProjectCross<I1,I2,OUT extends Tuple>
|
static class |
CrossOperator.ProjectCrossFunction<T1,T2,R extends Tuple> |
minResources, name, parallelism, preferredResources
Constructor and Description |
---|
CrossOperator(DataSet<I1> input1,
DataSet<I2> input2,
CrossFunction<I1,I2,OUT> function,
TypeInformation<OUT> returnType,
CrossOperatorBase.CrossHint hint,
String defaultName) |
Modifier and Type | Method and Description |
---|---|
CrossOperatorBase.CrossHint |
getCrossHint() |
protected CrossFunction<I1,I2,OUT> |
getFunction() |
protected CrossOperatorBase<I1,I2,OUT,CrossFunction<I1,I2,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
public CrossOperator(DataSet<I1> input1, DataSet<I2> input2, CrossFunction<I1,I2,OUT> function, TypeInformation<OUT> returnType, CrossOperatorBase.CrossHint hint, String defaultName)
protected CrossFunction<I1,I2,OUT> getFunction()
getFunction
in class TwoInputUdfOperator<I1,I2,OUT,CrossOperator<I1,I2,OUT>>
@Internal public CrossOperatorBase.CrossHint getCrossHint()
protected CrossOperatorBase<I1,I2,OUT,CrossFunction<I1,I2,OUT>> translateToDataFlow(Operator<I1> input1, Operator<I2> input2)
TwoInputOperator
translateToDataFlow
in class TwoInputOperator<I1,I2,OUT,CrossOperator<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–2020 The Apache Software Foundation. All rights reserved.