I1
- The type of the first input DataSet of the Join transformation.I2
- The type of the second input DataSet of the Join transformation.OUT
- The type of the result of the Join transformation.@Deprecated @Public public abstract class JoinOperator<I1,I2,OUT> extends TwoInputUdfOperator<I1,I2,OUT,JoinOperator<I1,I2,OUT>>
DataSet
that is the result of a Join transformation.Modifier and Type | Class and Description |
---|---|
static class |
JoinOperator.DefaultJoin<I1,I2>
Deprecated.
A Join transformation that wraps pairs of joining elements into
Tuple2 . |
static class |
JoinOperator.EquiJoin<I1,I2,OUT>
Deprecated.
A Join transformation that applies a
JoinFunction on each pair of joining elements. |
static class |
JoinOperator.JoinOperatorSets<I1,I2>
Deprecated.
Intermediate step of a Join transformation.
|
static class |
JoinOperator.ProjectJoin<I1,I2,OUT extends Tuple>
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
protected JoinType |
joinType
Deprecated.
|
protected Keys<I1> |
keys1
Deprecated.
|
protected Keys<I2> |
keys2
Deprecated.
|
minResources, name, parallelism, preferredResources
Modifier | Constructor and Description |
---|---|
protected |
JoinOperator(DataSet<I1> input1,
DataSet<I2> input2,
Keys<I1> keys1,
Keys<I2> keys2,
TypeInformation<OUT> returnType,
JoinOperatorBase.JoinHint hint,
JoinType type)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
JoinOperatorBase.JoinHint |
getJoinHint()
Deprecated.
Gets the JoinHint that describes how the join is executed.
|
JoinType |
getJoinType()
Deprecated.
Gets the JoinType that describes this join operation (e.g. inner, outer)
|
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. |
JoinOperator<I1,I2,OUT> |
withPartitioner(Partitioner<?> partitioner)
Deprecated.
Sets a custom partitioner for this join.
|
extractSemanticAnnotationsFromUdf, getAnalyzedUdfSemanticsFlag, getBroadcastSets, getFunction, getParameters, getSemanticProperties, returns, returns, returns, setAnalyzedUdfSemanticsFlag, setSemanticProperties, udfWithForwardedFieldsFirstAnnotation, udfWithForwardedFieldsSecondAnnotation, withBroadcastSet, withForwardedFieldsFirst, withForwardedFieldsSecond, withParameters
getInput1, getInput1Type, getInput2, getInput2Type, translateToDataFlow
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 final JoinType joinType
@Internal public JoinOperatorBase.JoinHint getJoinHint()
@Internal public JoinType getJoinType()
public JoinOperator<I1,I2,OUT> withPartitioner(Partitioner<?> partitioner)
NOTE: A custom partitioner can only be used with single-field join keys, not with composite join keys.
partitioner
- The custom partitioner to be used.@Internal public Partitioner<?> getPartitioner()
null
, if none is set.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.