public class SourceAbilityContext extends Object implements org.apache.flink.table.planner.calcite.FlinkContext
FlinkContext
which contains the information for SourceAbilitySpec
to apply the following abilities to DynamicTableSource
.
Constructor and Description |
---|
SourceAbilityContext(org.apache.flink.table.planner.calcite.FlinkContext context,
org.apache.flink.table.planner.calcite.FlinkTypeFactory typeFactory,
RowType sourceRowType) |
Modifier and Type | Method and Description |
---|---|
static SourceAbilityContext |
from(org.apache.calcite.rel.core.TableScan scan) |
CatalogManager |
getCatalogManager() |
ClassLoader |
getClassLoader() |
FunctionCatalog |
getFunctionCatalog() |
ModuleManager |
getModuleManager() |
RexFactory |
getRexFactory() |
RowType |
getSourceRowType() |
TableConfig |
getTableConfig() |
org.apache.flink.table.planner.calcite.FlinkTypeFactory |
getTypeFactory() |
boolean |
isBatchMode() |
<C> C |
unwrap(Class<C> clazz) |
public SourceAbilityContext(org.apache.flink.table.planner.calcite.FlinkContext context, org.apache.flink.table.planner.calcite.FlinkTypeFactory typeFactory, RowType sourceRowType)
public boolean isBatchMode()
isBatchMode
in interface org.apache.flink.table.planner.calcite.FlinkContext
public ClassLoader getClassLoader()
getClassLoader
in interface org.apache.flink.table.planner.calcite.FlinkContext
public TableConfig getTableConfig()
getTableConfig
in interface org.apache.flink.table.planner.calcite.FlinkContext
public FunctionCatalog getFunctionCatalog()
getFunctionCatalog
in interface org.apache.flink.table.planner.calcite.FlinkContext
public CatalogManager getCatalogManager()
getCatalogManager
in interface org.apache.flink.table.planner.calcite.FlinkContext
public ModuleManager getModuleManager()
getModuleManager
in interface org.apache.flink.table.planner.calcite.FlinkContext
public RexFactory getRexFactory()
getRexFactory
in interface org.apache.flink.table.planner.calcite.FlinkContext
public org.apache.flink.table.planner.calcite.FlinkTypeFactory getTypeFactory()
public <C> C unwrap(Class<C> clazz)
unwrap
in interface org.apache.calcite.schema.Wrapper
unwrap
in interface org.apache.flink.table.planner.calcite.FlinkContext
public RowType getSourceRowType()
public static SourceAbilityContext from(org.apache.calcite.rel.core.TableScan scan)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.