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(ObjectIdentifier tableIdentifier,
CatalogManager.TableLookupResult lookupResult,
org.apache.flink.table.planner.plan.stats.FlinkStatistic statistic,
Catalog catalog,
boolean isStreaming)
Create a CatalogSchemaTable instance.
|
Modifier and Type | Method and Description |
---|---|
Catalog |
getCatalog() |
CatalogBaseTable |
getCatalogTable() |
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() |
ObjectIdentifier |
getTableIdentifier() |
boolean |
isStreamingMode() |
boolean |
isTemporary() |
getJdbcTableType, isRolledUp, rolledUpColumnValidInsideAgg, unwrap
public CatalogSchemaTable(ObjectIdentifier tableIdentifier, CatalogManager.TableLookupResult lookupResult, org.apache.flink.table.planner.plan.stats.FlinkStatistic statistic, Catalog catalog, boolean isStreaming)
tableIdentifier
- Table identifierlookupResult
- A result of catalog lookupstatistic
- Table statisticscatalog
- The catalog which the schema table belongs toisStreaming
- If the table is for streaming modepublic Catalog getCatalog()
public ObjectIdentifier getTableIdentifier()
public CatalogBaseTable getCatalogTable()
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–2021 The Apache Software Foundation. All rights reserved.