public class CatalogSchemaTable
extends org.apache.calcite.schema.impl.AbstractTable
implements org.apache.calcite.schema.TemporalTable
CatalogBaseTable
in Schema
.
This table would be converted to FlinkPreparingTableBase
based on its internal source
type during sql-to-rel conversion.
See FlinkCalciteCatalogReader.getTable(List)
for
details.
Constructor and Description |
---|
CatalogSchemaTable(ContextResolvedTable contextResolvedTable,
org.apache.flink.table.planner.plan.stats.FlinkStatistic statistic,
boolean isStreaming)
Create a CatalogSchemaTable instance.
|
Modifier and Type | Method and Description |
---|---|
ContextResolvedTable |
getContextResolvedTable() |
org.apache.calcite.rel.type.RelDataType |
getRowType(org.apache.calcite.rel.type.RelDataTypeFactory typeFactory) |
org.apache.flink.table.planner.plan.stats.FlinkStatistic |
getStatistic() |
String |
getSysEndFieldName() |
String |
getSysStartFieldName() |
boolean |
isStreamingMode() |
boolean |
isTemporary() |
getJdbcTableType, isRolledUp, rolledUpColumnValidInsideAgg, unwrap
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
public CatalogSchemaTable(ContextResolvedTable contextResolvedTable, org.apache.flink.table.planner.plan.stats.FlinkStatistic statistic, boolean isStreaming)
contextResolvedTable
- A result of catalog lookupstatistic
- Table statisticsisStreaming
- If the table is for streaming modepublic ContextResolvedTable getContextResolvedTable()
public boolean isTemporary()
public boolean isStreamingMode()
public org.apache.calcite.rel.type.RelDataType getRowType(org.apache.calcite.rel.type.RelDataTypeFactory typeFactory)
getRowType
in interface org.apache.calcite.schema.Table
public org.apache.flink.table.planner.plan.stats.FlinkStatistic getStatistic()
getStatistic
in interface org.apache.calcite.schema.Table
getStatistic
in class org.apache.calcite.schema.impl.AbstractTable
public String getSysStartFieldName()
getSysStartFieldName
in interface org.apache.calcite.schema.TemporalTable
public String getSysEndFieldName()
getSysEndFieldName
in interface org.apache.calcite.schema.TemporalTable
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.