Package | Description |
---|---|
org.apache.flink.sql.parser |
Flink sql parser.
|
org.apache.flink.sql.parser.ddl | |
org.apache.flink.sql.parser.impl |
Modifier and Type | Method and Description |
---|---|
static List<SqlTableConstraint> |
SqlConstraintValidator.getFullConstraints(List<SqlTableConstraint> tableConstraints,
org.apache.calcite.sql.SqlNodeList columnList)
Returns the column constraints plus the table constraints.
|
Modifier and Type | Method and Description |
---|---|
static void |
SqlConstraintValidator.validate(SqlTableConstraint constraint)
Check table constraint.
|
Modifier and Type | Method and Description |
---|---|
static List<SqlTableConstraint> |
SqlConstraintValidator.getFullConstraints(List<SqlTableConstraint> tableConstraints,
org.apache.calcite.sql.SqlNodeList columnList)
Returns the column constraints plus the table constraints.
|
static void |
SqlUnparseUtils.unparseTableSchema(org.apache.calcite.sql.SqlWriter writer,
int leftPrec,
int rightPrec,
org.apache.calcite.sql.SqlNodeList columnList,
List<SqlTableConstraint> constraints,
SqlWatermark watermark) |
static void |
SqlConstraintValidator.validateAndChangeColumnNullability(List<SqlTableConstraint> tableConstraints,
org.apache.calcite.sql.SqlNodeList columnList)
Check constraints and change the nullability of primary key columns.
|
Modifier and Type | Field and Description |
---|---|
List<SqlTableConstraint> |
SqlCreateTable.TableCreationContext.constraints |
protected List<SqlTableConstraint> |
SqlAlterTableSchema.constraints |
Modifier and Type | Method and Description |
---|---|
SqlTableConstraint |
SqlAlterTableAddConstraint.getConstraint() |
Modifier and Type | Method and Description |
---|---|
Optional<SqlTableConstraint> |
SqlTableColumn.SqlRegularColumn.getConstraint() |
List<SqlTableConstraint> |
SqlAlterTableSchema.getConstraints() |
Optional<SqlTableConstraint> |
SqlAlterTableSchema.getFullConstraint() |
List<SqlTableConstraint> |
SqlCreateTable.getFullConstraints()
Returns the column constraints plus the table constraints.
|
List<SqlTableConstraint> |
SqlReplaceTableAs.getFullConstraints()
Returns the column constraints plus the table constraints.
|
Optional<SqlTableConstraint> |
SqlCreateMaterializedTable.getTableConstraint() |
List<SqlTableConstraint> |
SqlCreateTable.getTableConstraints() |
List<SqlTableConstraint> |
SqlReplaceTableAs.getTableConstraints() |
Constructor and Description |
---|
SqlAlterTableAddConstraint(org.apache.calcite.sql.SqlIdentifier tableID,
SqlTableConstraint constraint,
org.apache.calcite.sql.parser.SqlParserPos pos,
boolean ifTableExists)
Creates a add table constraint node.
|
SqlCreateMaterializedTable(org.apache.calcite.sql.parser.SqlParserPos pos,
org.apache.calcite.sql.SqlIdentifier tableName,
org.apache.calcite.sql.SqlCharStringLiteral comment,
SqlTableConstraint tableConstraint,
org.apache.calcite.sql.SqlNodeList partitionKeyList,
org.apache.calcite.sql.SqlNodeList propertyList,
org.apache.calcite.sql.SqlIntervalLiteral freshness,
org.apache.calcite.sql.SqlLiteral refreshMode,
org.apache.calcite.sql.SqlNode asQuery) |
SqlRegularColumn(org.apache.calcite.sql.parser.SqlParserPos pos,
org.apache.calcite.sql.SqlIdentifier name,
org.apache.calcite.sql.SqlNode comment,
org.apache.calcite.sql.SqlDataTypeSpec type,
SqlTableConstraint constraint) |
Constructor and Description |
---|
SqlAlterTableAdd(org.apache.calcite.sql.parser.SqlParserPos pos,
org.apache.calcite.sql.SqlIdentifier tableName,
org.apache.calcite.sql.SqlNodeList addedColumns,
List<SqlTableConstraint> constraint,
SqlWatermark sqlWatermark,
SqlDistribution distribution,
boolean ifTableExists) |
SqlAlterTableModify(org.apache.calcite.sql.parser.SqlParserPos pos,
org.apache.calcite.sql.SqlIdentifier tableName,
org.apache.calcite.sql.SqlNodeList modifiedColumns,
List<SqlTableConstraint> constraints,
SqlWatermark watermark,
SqlDistribution distribution,
boolean ifTableExists) |
SqlAlterTableSchema(org.apache.calcite.sql.parser.SqlParserPos pos,
org.apache.calcite.sql.SqlIdentifier tableName,
org.apache.calcite.sql.SqlNodeList columnList,
List<SqlTableConstraint> constraints,
SqlWatermark sqlWatermark,
SqlDistribution distribution,
boolean ifTableExists) |
SqlCreateTable(org.apache.calcite.sql.parser.SqlParserPos pos,
org.apache.calcite.sql.SqlIdentifier tableName,
org.apache.calcite.sql.SqlNodeList columnList,
List<SqlTableConstraint> tableConstraints,
org.apache.calcite.sql.SqlNodeList propertyList,
SqlDistribution distribution,
org.apache.calcite.sql.SqlNodeList partitionKeyList,
SqlWatermark watermark,
org.apache.calcite.sql.SqlCharStringLiteral comment,
boolean isTemporary,
boolean ifNotExists) |
SqlCreateTable(org.apache.calcite.sql.SqlSpecialOperator operator,
org.apache.calcite.sql.parser.SqlParserPos pos,
org.apache.calcite.sql.SqlIdentifier tableName,
org.apache.calcite.sql.SqlNodeList columnList,
List<SqlTableConstraint> tableConstraints,
org.apache.calcite.sql.SqlNodeList propertyList,
SqlDistribution distribution,
org.apache.calcite.sql.SqlNodeList partitionKeyList,
SqlWatermark watermark,
org.apache.calcite.sql.SqlCharStringLiteral comment,
boolean isTemporary,
boolean ifNotExists) |
SqlCreateTableAs(org.apache.calcite.sql.parser.SqlParserPos pos,
org.apache.calcite.sql.SqlIdentifier tableName,
org.apache.calcite.sql.SqlNodeList columnList,
List<SqlTableConstraint> tableConstraints,
org.apache.calcite.sql.SqlNodeList propertyList,
SqlDistribution distribution,
org.apache.calcite.sql.SqlNodeList partitionKeyList,
SqlWatermark watermark,
org.apache.calcite.sql.SqlCharStringLiteral comment,
org.apache.calcite.sql.SqlNode asQuery,
boolean isTemporary,
boolean ifNotExists) |
SqlCreateTableLike(org.apache.calcite.sql.parser.SqlParserPos pos,
org.apache.calcite.sql.SqlIdentifier tableName,
org.apache.calcite.sql.SqlNodeList columnList,
List<SqlTableConstraint> tableConstraints,
org.apache.calcite.sql.SqlNodeList propertyList,
SqlDistribution distribution,
org.apache.calcite.sql.SqlNodeList partitionKeyList,
SqlWatermark watermark,
org.apache.calcite.sql.SqlCharStringLiteral comment,
SqlTableLike tableLike,
boolean isTemporary,
boolean ifNotExists) |
SqlReplaceTableAs(org.apache.calcite.sql.parser.SqlParserPos pos,
org.apache.calcite.sql.SqlIdentifier tableName,
org.apache.calcite.sql.SqlNodeList columnList,
List<SqlTableConstraint> tableConstraints,
org.apache.calcite.sql.SqlNodeList propertyList,
SqlDistribution distribution,
org.apache.calcite.sql.SqlNodeList partitionKeyList,
SqlWatermark watermark,
org.apache.calcite.sql.SqlCharStringLiteral comment,
org.apache.calcite.sql.SqlNode asQuery,
boolean isTemporary,
boolean ifNotExists,
boolean isCreateOrReplace) |
Modifier and Type | Method and Description |
---|---|
SqlTableConstraint |
FlinkSqlParserImpl.ColumnConstraint(org.apache.calcite.sql.SqlIdentifier column)
Parses a column constraint for CREATE TABLE.
|
SqlTableConstraint |
FlinkSqlParserImpl.TableConstraint()
Parses a table constraint for CREATE TABLE.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.