Class AbstractCachedBuildSideJoinDriver<IT1,IT2,OT>
- java.lang.Object
-
- org.apache.flink.runtime.operators.JoinDriver<IT1,IT2,OT>
-
- org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver<IT1,IT2,OT>
-
- All Implemented Interfaces:
Driver<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT>,ResettableDriver<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT>
- Direct Known Subclasses:
BuildFirstCachedJoinDriver,BuildSecondCachedJoinDriver
public abstract class AbstractCachedBuildSideJoinDriver<IT1,IT2,OT> extends JoinDriver<IT1,IT2,OT> implements ResettableDriver<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT>
-
-
Field Summary
-
Fields inherited from class org.apache.flink.runtime.operators.JoinDriver
LOG, running, taskContext
-
-
Constructor Summary
Constructors Modifier Constructor Description protectedAbstractCachedBuildSideJoinDriver(int buildSideIndex, int probeSideIndex)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description voidcancel()This method is invoked when the driver must aborted in mid processing.voidcleanup()This method is invoked in any case (clean termination and exception) at the end of the tasks operation.voidinitialize()booleanisInputResettable(int inputNum)voidprepare()This method is called before the user code is opened.voidreset()voidrun()The main operation method of the task.voidteardown()-
Methods inherited from class org.apache.flink.runtime.operators.JoinDriver
getNumberOfDriverComparators, getNumberOfInputs, getStubType, setup
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface org.apache.flink.runtime.operators.Driver
getNumberOfDriverComparators, getNumberOfInputs, getStubType, setup
-
-
-
-
Method Detail
-
isInputResettable
public boolean isInputResettable(int inputNum)
- Specified by:
isInputResettablein interfaceResettableDriver<IT1,IT2>
-
initialize
public void initialize() throws Exception- Specified by:
initializein interfaceResettableDriver<IT1,IT2>- Throws:
Exception
-
prepare
public void prepare() throws ExceptionDescription copied from interface:DriverThis method is called before the user code is opened. An exception thrown by this method signals failure of the task.
-
run
public void run() throws ExceptionDescription copied from interface:DriverThe main operation method of the task. It should call the user code with the data subsets until the input is depleted.- Specified by:
runin interfaceDriver<IT1,IT2>- Overrides:
runin classJoinDriver<IT1,IT2,OT>- Throws:
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.
-
cleanup
public void cleanup() throws ExceptionDescription copied from interface:DriverThis method is invoked in any case (clean termination and exception) at the end of the tasks operation.
-
reset
public void reset() throws Exception- Specified by:
resetin interfaceResettableDriver<IT1,IT2>- Throws:
Exception
-
teardown
public void teardown()
- Specified by:
teardownin interfaceResettableDriver<IT1,IT2>
-
-