public abstract class AbstractMergeOuterJoinIterator<T1,T2,O> extends AbstractMergeIterator<T1,T2,O>
JoinTaskIterator
that
realizes the outer join through a sort-merge join strategy.blockHeadCopy, copy1, copy2, iterator1, iterator2, pairComparator, serializer1, serializer2, spillHeadCopy
Constructor and Description |
---|
AbstractMergeOuterJoinIterator(OuterJoinOperatorBase.OuterJoinType outerJoinType,
MutableObjectIterator<T1> input1,
MutableObjectIterator<T2> input2,
TypeSerializer<T1> serializer1,
TypeComparator<T1> comparator1,
TypeSerializer<T2> serializer2,
TypeComparator<T2> comparator2,
TypePairComparator<T1,T2> pairComparator,
MemoryManager memoryManager,
IOManager ioManager,
int numMemoryPages,
AbstractInvokable parentTask) |
Modifier and Type | Method and Description |
---|---|
boolean |
callWithNextKey(FlatJoinFunction<T1,T2,O> joinFunction,
Collector<O> collector)
Calls the
JoinFunction#join() method for all two key-value pairs that share the
same key and come from different inputs. |
abort, close, createCopy, createKeyGroupedIterator, crossMatchingGroup, open
public AbstractMergeOuterJoinIterator(OuterJoinOperatorBase.OuterJoinType outerJoinType, MutableObjectIterator<T1> input1, MutableObjectIterator<T2> input2, TypeSerializer<T1> serializer1, TypeComparator<T1> comparator1, TypeSerializer<T2> serializer2, TypeComparator<T2> comparator2, TypePairComparator<T1,T2> pairComparator, MemoryManager memoryManager, IOManager ioManager, int numMemoryPages, AbstractInvokable parentTask) throws MemoryAllocationException
MemoryAllocationException
public boolean callWithNextKey(FlatJoinFunction<T1,T2,O> joinFunction, Collector<O> collector) throws Exception
JoinFunction#join()
method for all two key-value pairs that share the
same key and come from different inputs. Furthermore, depending on the outer join type (LEFT,
RIGHT, FULL), all key-value pairs where no matching partner from the other input exists are
joined with null. The output of the join()
method is forwarded.callWithNextKey
in interface JoinTaskIterator<T1,T2,O>
callWithNextKey
in class AbstractMergeIterator<T1,T2,O>
joinFunction
- The match stub containing the match function which is called with the
keys.collector
- The collector to pass the match function.Exception
- Forwards all exceptions from the user code and the I/O system.JoinTaskIterator.callWithNextKey(org.apache.flink.api.common.functions.FlatJoinFunction,
org.apache.flink.util.Collector)
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.