public class SqlNodeConvertContext extends Object implements SqlNodeConverter.ConvertContext
SqlNodeConverter.ConvertContext
.Constructor and Description |
---|
SqlNodeConvertContext(org.apache.flink.table.planner.calcite.FlinkPlannerImpl flinkPlanner,
CatalogManager catalogManager) |
Modifier and Type | Method and Description |
---|---|
String |
expandSqlIdentifiers(String originalSql)
Expands identifiers in a given SQL string.
|
CatalogManager |
getCatalogManager()
Returns the
CatalogManager in the convert context. |
org.apache.calcite.sql.validate.SqlValidator |
getSqlValidator()
Returns the
SqlValidator in the convert context. |
TableConfig |
getTableConfig()
Returns the
TableConfig defined in TableEnvironment . |
List<org.apache.calcite.rex.RexNode> |
reduceRexNodes(List<org.apache.calcite.rex.RexNode> rexNodes)
Reduce the given
RexNode s. |
String |
toQuotedSqlString(org.apache.calcite.sql.SqlNode sqlNode)
Convert the given into a quoted SQL string.
|
org.apache.calcite.rel.RelRoot |
toRelRoot(org.apache.calcite.sql.SqlNode sqlNode)
Converts the given validated
SqlNode into a RelRoot . |
org.apache.calcite.rex.RexNode |
toRexNode(org.apache.calcite.sql.SqlNode sqlNode,
org.apache.calcite.rel.type.RelDataType inputRowType,
DataType outputType)
Converts the given validated
SqlNode into a RexNode . |
public SqlNodeConvertContext(org.apache.flink.table.planner.calcite.FlinkPlannerImpl flinkPlanner, CatalogManager catalogManager)
public TableConfig getTableConfig()
SqlNodeConverter.ConvertContext
TableConfig
defined in TableEnvironment
.getTableConfig
in interface SqlNodeConverter.ConvertContext
public org.apache.calcite.sql.validate.SqlValidator getSqlValidator()
SqlNodeConverter.ConvertContext
SqlValidator
in the convert context.getSqlValidator
in interface SqlNodeConverter.ConvertContext
public CatalogManager getCatalogManager()
SqlNodeConverter.ConvertContext
CatalogManager
in the convert context.getCatalogManager
in interface SqlNodeConverter.ConvertContext
public org.apache.calcite.rel.RelRoot toRelRoot(org.apache.calcite.sql.SqlNode sqlNode)
SqlNodeConverter.ConvertContext
SqlNode
into a RelRoot
.toRelRoot
in interface SqlNodeConverter.ConvertContext
public org.apache.calcite.rex.RexNode toRexNode(org.apache.calcite.sql.SqlNode sqlNode, org.apache.calcite.rel.type.RelDataType inputRowType, @Nullable DataType outputType)
SqlNodeConverter.ConvertContext
SqlNode
into a RexNode
.toRexNode
in interface SqlNodeConverter.ConvertContext
public List<org.apache.calcite.rex.RexNode> reduceRexNodes(List<org.apache.calcite.rex.RexNode> rexNodes)
SqlNodeConverter.ConvertContext
RexNode
s.reduceRexNodes
in interface SqlNodeConverter.ConvertContext
public String toQuotedSqlString(org.apache.calcite.sql.SqlNode sqlNode)
SqlNodeConverter.ConvertContext
toQuotedSqlString
in interface SqlNodeConverter.ConvertContext
public String expandSqlIdentifiers(String originalSql)
SqlNodeConverter.ConvertContext
expandSqlIdentifiers
in interface SqlNodeConverter.ConvertContext
Expander
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.