@Internal
public final class TemporalTableFunctionImpl
extends org.apache.flink.table.functions.TemporalTableFunction
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).
Modifier and Type | Method and 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() |
collect, getKind, getParameterTypes, setCollector
close, functionIdentifier, open, toString
public void eval(Timestamp t)
public org.apache.flink.table.expressions.Expression getTimeAttribute()
public org.apache.flink.table.expressions.Expression getPrimaryKey()
public org.apache.flink.table.types.inference.TypeInference getTypeInference(org.apache.flink.table.catalog.DataTypeFactory typeFactory)
getTypeInference
in interface org.apache.flink.table.functions.FunctionDefinition
getTypeInference
in class org.apache.flink.table.functions.TableFunction<org.apache.flink.types.Row>
public org.apache.flink.api.java.typeutils.RowTypeInfo getResultType()
getResultType
in class org.apache.flink.table.functions.TableFunction<org.apache.flink.types.Row>
public QueryOperation getUnderlyingHistoryTable()
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)
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.