Class LeftOuterJoinDriver<IT1,​IT2,​OT>

  • All Implemented Interfaces:
    Driver<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,​IT2,​OT>,​OT>

    public class LeftOuterJoinDriver<IT1,​IT2,​OT>
    extends AbstractOuterJoinDriver<IT1,​IT2,​OT>
    The left outer join driver implements the logic of an outer join operator at runtime. It instantiates a sort-merge based strategy to find joining pairs of records or joins records from the left side with null if no match is found.
    • Constructor Detail

      • LeftOuterJoinDriver

        public LeftOuterJoinDriver()
    • Method Detail

      • getReusingOuterJoinIterator

        protected JoinTaskIterator<IT1,​IT2,​OT> getReusingOuterJoinIterator​(DriverStrategy driverStrategy,
                                                                                       org.apache.flink.util.MutableObjectIterator<IT1> in1,
                                                                                       org.apache.flink.util.MutableObjectIterator<IT2> in2,
                                                                                       org.apache.flink.api.common.typeutils.TypeSerializer<IT1> serializer1,
                                                                                       org.apache.flink.api.common.typeutils.TypeComparator<IT1> comparator1,
                                                                                       org.apache.flink.api.common.typeutils.TypeSerializer<IT2> serializer2,
                                                                                       org.apache.flink.api.common.typeutils.TypeComparator<IT2> comparator2,
                                                                                       org.apache.flink.api.common.typeutils.TypePairComparatorFactory<IT1,​IT2> pairComparatorFactory,
                                                                                       MemoryManager memoryManager,
                                                                                       IOManager ioManager,
                                                                                       double driverMemFraction)
                                                                                throws Exception
        Specified by:
        getReusingOuterJoinIterator in class AbstractOuterJoinDriver<IT1,​IT2,​OT>
        Throws:
        Exception
      • getNonReusingOuterJoinIterator

        protected JoinTaskIterator<IT1,​IT2,​OT> getNonReusingOuterJoinIterator​(DriverStrategy driverStrategy,
                                                                                          org.apache.flink.util.MutableObjectIterator<IT1> in1,
                                                                                          org.apache.flink.util.MutableObjectIterator<IT2> in2,
                                                                                          org.apache.flink.api.common.typeutils.TypeSerializer<IT1> serializer1,
                                                                                          org.apache.flink.api.common.typeutils.TypeComparator<IT1> comparator1,
                                                                                          org.apache.flink.api.common.typeutils.TypeSerializer<IT2> serializer2,
                                                                                          org.apache.flink.api.common.typeutils.TypeComparator<IT2> comparator2,
                                                                                          org.apache.flink.api.common.typeutils.TypePairComparatorFactory<IT1,​IT2> pairComparatorFactory,
                                                                                          MemoryManager memoryManager,
                                                                                          IOManager ioManager,
                                                                                          double driverMemFraction)
                                                                                   throws Exception
        Specified by:
        getNonReusingOuterJoinIterator in class AbstractOuterJoinDriver<IT1,​IT2,​OT>
        Throws:
        Exception