Class TemporalTableFunctionImpl

  • All Implemented Interfaces:
    Serializable, org.apache.flink.table.functions.FunctionDefinition

    @Internal
    public final class TemporalTableFunctionImpl
    extends org.apache.flink.table.functions.TemporalTableFunction
    Class representing temporal table function over some history table. It takes one single argument, the timeAttribute, for which it returns matching version of the underlyingHistoryTable, from which this TemporalTableFunction was created.

    This function shouldn't be evaluated. Instead calls to it should be rewritten by the optimiser into other operators (like Temporal Table Join).

    See Also:
    Serialized Form
    • Method Summary

      All Methods Static Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      static org.apache.flink.table.functions.TemporalTableFunction create​(QueryOperation operationTree, org.apache.flink.table.expressions.Expression timeAttribute, org.apache.flink.table.expressions.Expression primaryKey)  
      void eval​(Timestamp t)  
      org.apache.flink.table.expressions.Expression getPrimaryKey()  
      org.apache.flink.api.java.typeutils.RowTypeInfo getResultType()  
      org.apache.flink.table.expressions.Expression getTimeAttribute()  
      org.apache.flink.table.types.inference.TypeInference getTypeInference​(org.apache.flink.table.catalog.DataTypeFactory typeFactory)  
      QueryOperation getUnderlyingHistoryTable()  
      • Methods inherited from class org.apache.flink.table.functions.TableFunction

        collect, finish, getKind, getParameterTypes, setCollector
      • Methods inherited from class org.apache.flink.table.functions.UserDefinedFunction

        close, functionIdentifier, open, toString
      • Methods inherited from interface org.apache.flink.table.functions.FunctionDefinition

        getRequirements, isDeterministic, supportsConstantFolding
    • Method Detail

      • getTimeAttribute

        public org.apache.flink.table.expressions.Expression getTimeAttribute()
      • getPrimaryKey

        public org.apache.flink.table.expressions.Expression getPrimaryKey()
      • getTypeInference

        public org.apache.flink.table.types.inference.TypeInference getTypeInference​(org.apache.flink.table.catalog.DataTypeFactory typeFactory)
        Specified by:
        getTypeInference in interface org.apache.flink.table.functions.FunctionDefinition
        Overrides:
        getTypeInference in class org.apache.flink.table.functions.TableFunction<org.apache.flink.types.Row>
      • getResultType

        public org.apache.flink.api.java.typeutils.RowTypeInfo getResultType()
        Overrides:
        getResultType in class org.apache.flink.table.functions.TableFunction<org.apache.flink.types.Row>
      • getUnderlyingHistoryTable

        public QueryOperation getUnderlyingHistoryTable()
      • create

        public static org.apache.flink.table.functions.TemporalTableFunction create​(QueryOperation operationTree,
                                                                                    org.apache.flink.table.expressions.Expression timeAttribute,
                                                                                    org.apache.flink.table.expressions.Expression primaryKey)