public abstract class AbstractOuterJoinDriver<IT1,IT2,OT> extends Object implements Driver<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT>
FlatJoinFunction| Modifier and Type | Field and Description |
|---|---|
protected static org.slf4j.Logger |
LOG |
protected JoinTaskIterator<IT1,IT2,OT> |
outerJoinIterator |
protected boolean |
running |
protected TaskContext<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT> |
taskContext |
| Constructor and Description |
|---|
AbstractOuterJoinDriver() |
| Modifier and Type | Method and Description |
|---|---|
void |
cancel()
This method is invoked when the driver must aborted in mid processing.
|
void |
cleanup()
This method is invoked in any case (clean termination and exception) at the end of the tasks operation.
|
protected abstract 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) |
int |
getNumberOfDriverComparators()
Gets the number of comparators required for this driver.
|
int |
getNumberOfInputs()
Gets the number of inputs that the task has.
|
protected abstract 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) |
Class<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>> |
getStubType()
Gets the class of the stub type that is run by this task.
|
void |
prepare()
This method is called before the user code is opened.
|
void |
run()
The main operation method of the task.
|
void |
setup(TaskContext<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT> context) |
protected static final org.slf4j.Logger LOG
protected TaskContext<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT> taskContext
protected volatile JoinTaskIterator<IT1,IT2,OT> outerJoinIterator
protected volatile boolean running
public void setup(TaskContext<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT> context)
public int getNumberOfInputs()
Driverpublic Class<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>> getStubType()
DriverMapFunction.class.public int getNumberOfDriverComparators()
Driverpublic void prepare()
throws Exception
Driverpublic void run()
throws Exception
Driverrun in interface Driver<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT>Exception - Any exception thrown by this method signals task failure. Because exceptions in the user
code typically signal situations where this instance in unable to proceed, exceptions
from the user code should be forwarded.public void cleanup()
throws Exception
Driverpublic void cancel()
Driverprotected abstract 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
Exceptionprotected abstract 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
ExceptionCopyright © 2014–2019 The Apache Software Foundation. All rights reserved.