Class 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.AbstractRichFunction
    Abstraction of code-generated calls to ProcessTableFunction to be used within AbstractProcessTableOperator.
    See Also:
    Serialized Form
    • Field Detail

      • stateHandles

        protected org.apache.flink.api.common.state.State[] stateHandles
      • 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 if stateCleared was true during conversion.
    • Constructor Detail

      • ProcessTableRunner

        public ProcessTableRunner()
    • Method Detail

      • 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()