Class ProcessTableRunner
- java.lang.Object
-
- org.apache.flink.api.common.functions.AbstractRichFunction
-
- org.apache.flink.table.runtime.generated.ProcessTableRunner
-
- All Implemented Interfaces:
Serializable,org.apache.flink.api.common.functions.Function,org.apache.flink.api.common.functions.RichFunction
@Internal public abstract class ProcessTableRunner extends org.apache.flink.api.common.functions.AbstractRichFunctionAbstraction of code-generated calls toProcessTableFunctionto be used withinAbstractProcessTableOperator.- See Also:
- Serialized Form
-
-
Field Summary
Fields Modifier and Type Field Description protected PassThroughCollectorBaseevalCollectorprotected intinputIndexprotected org.apache.flink.table.data.RowDatainputRowprotected PassAllCollectoronTimerCollectorprotected AbstractProcessTableOperator.RunnerContextrunnerContextprotected AbstractProcessTableOperator.RunnerOnTimerContextrunnerOnTimerContextprotected boolean[]stateClearedReference to whether the state has been cleared within the function; if yes, a conversion from external to internal data structure is not necessary anymore.protected org.apache.flink.api.common.state.State[]stateHandlesprotected org.apache.flink.table.data.RowData[]valueStateFromFunctionState ready for persistence; null ifstateClearedwas true during conversion.protected org.apache.flink.table.data.RowData[]valueStateToFunctionState entries to be converted into external data structure; null if state is empty.
-
Constructor Summary
Constructors Constructor Description ProcessTableRunner()
-
Method Summary
All Methods Instance Methods Abstract Methods Concrete Methods Modifier and Type Method Description abstract voidcallEval()abstract voidcallOnTimer()voidclearAllState()voidclearState(int statePos)longgetCurrentWatermark()LonggetTime()org.apache.flink.table.data.StringDatagetTimerName()voidingestTableEvent(int pos, org.apache.flink.table.data.RowData row, int timeColumn)voidingestTimerEvent(org.apache.flink.table.data.RowData key, org.apache.flink.table.data.StringData name, long timerTime)voidingestWatermarkEvent(long watermarkTime)voidinitialize(org.apache.flink.api.common.state.State[] stateHandles, HashFunction[] stateHashCode, RecordEqualiser[] stateEquals, boolean emitRowtime, AbstractProcessTableOperator.RunnerContext runnerContext, AbstractProcessTableOperator.RunnerOnTimerContext runnerOnTimerContext, PassThroughCollectorBase evalCollector, PassAllCollector onTimerCollector)voidprocessEval()voidprocessOnTimer()
-
-
-
Field Detail
-
stateHandles
protected org.apache.flink.api.common.state.State[] stateHandles
-
runnerContext
protected AbstractProcessTableOperator.RunnerContext runnerContext
-
runnerOnTimerContext
protected AbstractProcessTableOperator.RunnerOnTimerContext runnerOnTimerContext
-
evalCollector
protected PassThroughCollectorBase evalCollector
-
onTimerCollector
protected PassAllCollector onTimerCollector
-
inputIndex
protected int inputIndex
-
inputRow
protected org.apache.flink.table.data.RowData inputRow
-
valueStateToFunction
protected org.apache.flink.table.data.RowData[] valueStateToFunction
State entries to be converted into external data structure; null if state is empty.
-
stateCleared
protected boolean[] stateCleared
Reference to whether the state has been cleared within the function; if yes, a conversion from external to internal data structure is not necessary anymore.
-
valueStateFromFunction
protected org.apache.flink.table.data.RowData[] valueStateFromFunction
State ready for persistence; null ifstateClearedwas true during conversion.
-
-
Method Detail
-
initialize
public void initialize(org.apache.flink.api.common.state.State[] stateHandles, HashFunction[] stateHashCode, RecordEqualiser[] stateEquals, boolean emitRowtime, AbstractProcessTableOperator.RunnerContext runnerContext, AbstractProcessTableOperator.RunnerOnTimerContext runnerOnTimerContext, PassThroughCollectorBase evalCollector, PassAllCollector onTimerCollector)
-
ingestTableEvent
public void ingestTableEvent(int pos, org.apache.flink.table.data.RowData row, int timeColumn)
-
ingestTimerEvent
public void ingestTimerEvent(org.apache.flink.table.data.RowData key, @Nullable org.apache.flink.table.data.StringData name, long timerTime)
-
ingestWatermarkEvent
public void ingestWatermarkEvent(long watermarkTime)
-
clearAllState
public void clearAllState()
-
clearState
public void clearState(int statePos)
-
getCurrentWatermark
public long getCurrentWatermark()
-
getTime
@Nullable public Long getTime()
-
getTimerName
@Nullable public org.apache.flink.table.data.StringData getTimerName()
-
-