Class SqlCreateTable

    • Field Summary

      Fields 
      Modifier and Type Field Description
      static org.apache.calcite.sql.SqlSpecialOperator OPERATOR  
      • Fields inherited from class org.apache.calcite.sql.SqlCreate

        ifNotExists
      • Fields inherited from class org.apache.calcite.sql.SqlDdl

        DDL_OPERATOR
      • Fields inherited from class org.apache.calcite.sql.SqlNode

        EMPTY_ARRAY, pos
    • Constructor Summary

      Constructors 
      Modifier Constructor Description
        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)  
      protected 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)  
    • Field Detail

      • OPERATOR

        public static final org.apache.calcite.sql.SqlSpecialOperator OPERATOR
    • Constructor Detail

      • SqlCreateTable

        public 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,
                              @Nullable
                              SqlWatermark watermark,
                              @Nullable
                              org.apache.calcite.sql.SqlCharStringLiteral comment,
                              boolean isTemporary,
                              boolean ifNotExists)
      • SqlCreateTable

        protected 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,
                                 @Nullable
                                 SqlDistribution distribution,
                                 org.apache.calcite.sql.SqlNodeList partitionKeyList,
                                 @Nullable
                                 SqlWatermark watermark,
                                 @Nullable
                                 org.apache.calcite.sql.SqlCharStringLiteral comment,
                                 boolean isTemporary,
                                 boolean ifNotExists)
    • Method Detail

      • getOperator

        @Nonnull
        public org.apache.calcite.sql.SqlOperator getOperator()
        Overrides:
        getOperator in class org.apache.calcite.sql.SqlDdl
      • getOperandList

        @Nonnull
        public List<org.apache.calcite.sql.SqlNode> getOperandList()
        Specified by:
        getOperandList in class org.apache.calcite.sql.SqlCall
      • getTableName

        public org.apache.calcite.sql.SqlIdentifier getTableName()
      • getColumnList

        public org.apache.calcite.sql.SqlNodeList getColumnList()
      • getPropertyList

        public org.apache.calcite.sql.SqlNodeList getPropertyList()
      • getPartitionKeyList

        public org.apache.calcite.sql.SqlNodeList getPartitionKeyList()
      • getComment

        public Optional<org.apache.calcite.sql.SqlCharStringLiteral> getComment()
      • isIfNotExists

        public boolean isIfNotExists()
      • isTemporary

        public boolean isTemporary()
      • hasRegularColumnsOnly

        public boolean hasRegularColumnsOnly()
      • getFullConstraints

        public List<SqlTableConstraint> getFullConstraints()
        Returns the column constraints plus the table constraints.
      • getColumnSqlString

        public String getColumnSqlString()
        Returns the projection format of the DDL columns(including computed columns). i.e. the following DDL:
           create table tbl1(
             col1 int,
             col2 varchar,
             col3 as to_timestamp(col2)
           ) with (
             'connector' = 'csv'
           )
         

        is equivalent with query "col1, col2, to_timestamp(col2) as col3", caution that the "computed column" operands have been reversed.

      • unparse

        public void unparse​(org.apache.calcite.sql.SqlWriter writer,
                            int leftPrec,
                            int rightPrec)
        Overrides:
        unparse in class org.apache.calcite.sql.SqlCall
      • fullTableName

        public String[] fullTableName()