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>
LOG, running, taskContext
限定符 | 构造器和说明 |
---|---|
protected |
AbstractCachedBuildSideJoinDriver(int buildSideIndex,
int probeSideIndex) |
限定符和类型 | 方法和说明 |
---|---|
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.
|
void |
initialize() |
boolean |
isInputResettable(int inputNum) |
void |
prepare()
This method is called before the user code is opened.
|
void |
reset() |
void |
run()
The main operation method of the task.
|
void |
teardown() |
getNumberOfDriverComparators, getNumberOfInputs, getStubType, setup
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
getNumberOfDriverComparators, getNumberOfInputs, getStubType, setup
protected AbstractCachedBuildSideJoinDriver(int buildSideIndex, int probeSideIndex)
public boolean isInputResettable(int inputNum)
isInputResettable
在接口中 ResettableDriver<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT>
public void initialize() throws Exception
initialize
在接口中 ResettableDriver<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT>
Exception
public void prepare() throws Exception
Driver
public void run() throws Exception
Driver
run
在接口中 Driver<org.apache.flink.api.common.functions.FlatJoinFunction<IT1,IT2,OT>,OT>
run
在类中 JoinDriver<IT1,IT2,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
Driver
public void reset() throws Exception
public void teardown()
public void cancel()
Driver
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.