All Downloads are FREE. Search and download functionalities are using the official Maven repository.

com.hazelcast.org.apache.calcite.rel.rel2sql.RelToSqlConverter Maven / Gradle / Ivy

There is a newer version: 5.5.0
Show newest version
/*
 * Licensed to the Apache Software Foundation (ASF) under one or more
 * contributor license agreements.  See the NOTICE file distributed with
 * this work for additional information regarding copyright ownership.
 * The ASF licenses this file to you under the Apache License, Version 2.0
 * (the "License"); you may not use this file except in compliance with
 * the License.  You may obtain a copy of the License at
 *
 * http://www.apache.org/licenses/LICENSE-2.0
 *
 * Unless required by applicable law or agreed to in writing, software
 * distributed under the License is distributed on an "AS IS" BASIS,
 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */
package com.hazelcast.org.apache.calcite.rel.rel2sql;

import com.hazelcast.org.apache.calcite.adapter.jdbc.JdbcTable;
import com.hazelcast.org.apache.calcite.linq4j.Ord;
import com.hazelcast.org.apache.calcite.linq4j.tree.Expressions;
import com.hazelcast.org.apache.calcite.rel.RelCollation;
import com.hazelcast.org.apache.calcite.rel.RelCollations;
import com.hazelcast.org.apache.calcite.rel.RelFieldCollation;
import com.hazelcast.org.apache.calcite.rel.RelNode;
import com.hazelcast.org.apache.calcite.rel.core.Aggregate;
import com.hazelcast.org.apache.calcite.rel.core.AggregateCall;
import com.hazelcast.org.apache.calcite.rel.core.Calc;
import com.hazelcast.org.apache.calcite.rel.core.Correlate;
import com.hazelcast.org.apache.calcite.rel.core.CorrelationId;
import com.hazelcast.org.apache.calcite.rel.core.Filter;
import com.hazelcast.org.apache.calcite.rel.core.Intersect;
import com.hazelcast.org.apache.calcite.rel.core.Join;
import com.hazelcast.org.apache.calcite.rel.core.JoinRelType;
import com.hazelcast.org.apache.calcite.rel.core.Match;
import com.hazelcast.org.apache.calcite.rel.core.Minus;
import com.hazelcast.org.apache.calcite.rel.core.Project;
import com.hazelcast.org.apache.calcite.rel.core.Sort;
import com.hazelcast.org.apache.calcite.rel.core.TableFunctionScan;
import com.hazelcast.org.apache.calcite.rel.core.TableModify;
import com.hazelcast.org.apache.calcite.rel.core.TableScan;
import com.hazelcast.org.apache.calcite.rel.core.Uncollect;
import com.hazelcast.org.apache.calcite.rel.core.Union;
import com.hazelcast.org.apache.calcite.rel.core.Values;
import com.hazelcast.org.apache.calcite.rel.core.Window;
import com.hazelcast.org.apache.calcite.rel.logical.LogicalProject;
import com.hazelcast.org.apache.calcite.rel.logical.LogicalSort;
import com.hazelcast.org.apache.calcite.rel.type.RelDataType;
import com.hazelcast.org.apache.calcite.rel.type.RelDataTypeField;
import com.hazelcast.org.apache.calcite.rex.RexBuilder;
import com.hazelcast.org.apache.calcite.rex.RexCall;
import com.hazelcast.org.apache.calcite.rex.RexInputRef;
import com.hazelcast.org.apache.calcite.rex.RexLiteral;
import com.hazelcast.org.apache.calcite.rex.RexLocalRef;
import com.hazelcast.org.apache.calcite.rex.RexNode;
import com.hazelcast.org.apache.calcite.rex.RexProgram;
import com.hazelcast.org.apache.calcite.sql.JoinConditionType;
import com.hazelcast.org.apache.calcite.sql.JoinType;
import com.hazelcast.org.apache.calcite.sql.SqlBasicCall;
import com.hazelcast.org.apache.calcite.sql.SqlCall;
import com.hazelcast.org.apache.calcite.sql.SqlDelete;
import com.hazelcast.org.apache.calcite.sql.SqlDialect;
import com.hazelcast.org.apache.calcite.sql.SqlIdentifier;
import com.hazelcast.org.apache.calcite.sql.SqlInsert;
import com.hazelcast.org.apache.calcite.sql.SqlIntervalLiteral;
import com.hazelcast.org.apache.calcite.sql.SqlJoin;
import com.hazelcast.org.apache.calcite.sql.SqlKind;
import com.hazelcast.org.apache.calcite.sql.SqlLiteral;
import com.hazelcast.org.apache.calcite.sql.SqlMatchRecognize;
import com.hazelcast.org.apache.calcite.sql.SqlNode;
import com.hazelcast.org.apache.calcite.sql.SqlNodeList;
import com.hazelcast.org.apache.calcite.sql.SqlSelect;
import com.hazelcast.org.apache.calcite.sql.SqlUpdate;
import com.hazelcast.org.apache.calcite.sql.SqlUtil;
import com.hazelcast.org.apache.calcite.sql.fun.SqlRowOperator;
import com.hazelcast.org.apache.calcite.sql.fun.SqlSingleValueAggFunction;
import com.hazelcast.org.apache.calcite.sql.fun.SqlStdOperatorTable;
import com.hazelcast.org.apache.calcite.sql.parser.SqlParserPos;
import com.hazelcast.org.apache.calcite.sql.util.SqlShuttle;
import com.hazelcast.org.apache.calcite.sql.util.SqlVisitor;
import com.hazelcast.org.apache.calcite.sql.validate.SqlValidatorUtil;
import com.hazelcast.org.apache.calcite.util.ImmutableBitSet;
import com.hazelcast.org.apache.calcite.util.Pair;
import com.hazelcast.org.apache.calcite.util.Permutation;
import com.hazelcast.org.apache.calcite.util.ReflectUtil;
import com.hazelcast.org.apache.calcite.util.ReflectiveVisitor;

import com.hazelcast.com.google.common.collect.ImmutableList;
import com.hazelcast.com.google.common.collect.ImmutableMap;
import com.hazelcast.com.google.common.collect.Iterables;
import com.hazelcast.com.google.common.collect.Lists;
import com.hazelcast.com.google.common.collect.Ordering;

import java.util.ArrayDeque;
import java.util.ArrayList;
import java.util.Deque;
import java.util.LinkedHashSet;
import java.util.List;
import java.util.Locale;
import java.util.Map;
import java.util.Objects;
import java.util.Set;
import java.util.SortedSet;
import java.util.stream.Collectors;
import java.util.stream.IntStream;

/**
 * Utility to convert relational expressions to SQL abstract syntax tree.
 */
public class RelToSqlConverter extends SqlImplementor
    implements ReflectiveVisitor {
  /** Similar to {@link SqlStdOperatorTable#ROW}, but does not print "ROW". */
  private static final SqlRowOperator ANONYMOUS_ROW = new SqlRowOperator(" ");

  private final ReflectUtil.MethodDispatcher dispatcher;

  private final Deque stack = new ArrayDeque<>();

  /** Creates a RelToSqlConverter. */
  public RelToSqlConverter(SqlDialect dialect) {
    super(dialect);
    dispatcher = ReflectUtil.createMethodDispatcher(Result.class, this, "visit",
        RelNode.class);
  }

  /** Dispatches a call to the {@code visit(Xxx e)} method where {@code Xxx}
   * most closely matches the runtime type of the argument. */
  protected Result dispatch(RelNode e) {
    return dispatcher.invoke(e);
  }

  public Result visitChild(int i, RelNode e, boolean anon) {
    try {
      stack.push(new Frame(i, e, anon));
      return dispatch(e);
    } finally {
      stack.pop();
    }
  }

  @Override protected boolean isAnon() {
    return stack.isEmpty() || stack.peek().anon;
  }

  /** @see #dispatch */
  public Result visit(RelNode e) {
    throw new AssertionError("Need to implement " + e.getClass().getName());
  }

  /**
   * A SqlShuttle to replace references to a column of a table alias with the expression
   * from the select item that is the source of that column.
   * ANTI- and SEMI-joins generate an alias for right hand side relation which
   * is used in the ON condition. But that alias is never created, so we have to inline references.
   */
  private static class AliasReplacementShuttle extends SqlShuttle {
    private final String tableAlias;
    private final RelDataType tableType;
    private final SqlNodeList replaceSource;

    AliasReplacementShuttle(String tableAlias, RelDataType tableType, SqlNodeList replaceSource) {
      this.tableAlias = tableAlias;
      this.tableType = tableType;
      this.replaceSource = replaceSource;
    }

    @Override public SqlNode visit(SqlIdentifier id) {
      if (tableAlias.equals(id.names.get(0))) {
        int index = tableType.getField(
            id.names.get(1), false, false).getIndex();
        SqlNode selectItem = replaceSource.get(index);
        if (selectItem.getKind() == SqlKind.AS) {
          selectItem = ((SqlCall) selectItem).operand(0);
        }
        return selectItem.clone(id.getParserPosition());
      }
      return id;
    }
  }

  /** @see #dispatch */
  public Result visit(Join e) {
    if (e.getJoinType() == JoinRelType.ANTI || e.getJoinType() == JoinRelType.SEMI) {
      return visitAntiOrSemiJoin(e);
    }
    final Result leftResult = visitChild(0, e.getLeft()).resetAlias();
    final Result rightResult = visitChild(1, e.getRight()).resetAlias();
    final Context leftContext = leftResult.qualifiedContext();
    final Context rightContext = rightResult.qualifiedContext();
    SqlNode sqlCondition = null;
    SqlLiteral condType = JoinConditionType.ON.symbol(POS);
    JoinType joinType = joinType(e.getJoinType());
    if (isCrossJoin(e)) {
      joinType = dialect.emulateJoinTypeForCrossJoin();
      condType = JoinConditionType.NONE.symbol(POS);
    } else {
      sqlCondition = convertConditionToSqlNode(e.getCondition(),
          leftContext,
          rightContext,
          e.getLeft().getRowType().getFieldCount(),
          dialect);
    }
    SqlNode join =
        new SqlJoin(POS,
            leftResult.asFrom(),
            SqlLiteral.createBoolean(false, POS),
            joinType.symbol(POS),
            rightResult.asFrom(),
            condType,
            sqlCondition);
    return result(join, leftResult, rightResult);
  }

  protected Result visitAntiOrSemiJoin(Join e) {
    final Result leftResult = visitChild(0, e.getLeft()).resetAlias();
    final Result rightResult = visitChild(1, e.getRight()).resetAlias();
    final Context leftContext = leftResult.qualifiedContext();
    final Context rightContext = rightResult.qualifiedContext();
    SqlNode sqlCondition = null;

    SqlSelect sqlSelect = leftResult.asSelect();
    sqlCondition = convertConditionToSqlNode(e.getCondition(),
        leftContext,
        rightContext,
        e.getLeft().getRowType().getFieldCount(),
        dialect);
    if (leftResult.neededAlias != null) {
      SqlVisitor visitor = new AliasReplacementShuttle(leftResult.neededAlias,
          e.getLeft().getRowType(), sqlSelect.getSelectList());
      sqlCondition = sqlCondition.accept(visitor);
    }
    SqlNode fromPart = rightResult.asFrom();
    SqlSelect existsSqlSelect;
    if (fromPart.getKind() == SqlKind.SELECT) {
      existsSqlSelect = (SqlSelect) fromPart;
      existsSqlSelect.setSelectList(
          new SqlNodeList(ImmutableList.of(SqlLiteral.createExactNumeric("1", POS)), POS));
      if (existsSqlSelect.getWhere() != null) {
        sqlCondition = SqlStdOperatorTable.AND.createCall(POS,
            existsSqlSelect.getWhere(),
            sqlCondition);
      }
      existsSqlSelect.setWhere(sqlCondition);
    } else {
      existsSqlSelect =
          new SqlSelect(POS, null,
              new SqlNodeList(
                  ImmutableList.of(SqlLiteral.createExactNumeric("1", POS)), POS),
              fromPart, sqlCondition, null,
              null, null, null, null, null, null);
    }
    sqlCondition = SqlStdOperatorTable.EXISTS.createCall(POS, existsSqlSelect);
    if (e.getJoinType() == JoinRelType.ANTI) {
      sqlCondition = SqlStdOperatorTable.NOT.createCall(POS, sqlCondition);
    }
    if (sqlSelect.getWhere() != null) {
      sqlCondition = SqlStdOperatorTable.AND.createCall(POS,
          sqlSelect.getWhere(),
          sqlCondition);
    }
    sqlSelect.setWhere(sqlCondition);
    SqlNode resultNode;
    if (leftResult.neededAlias != null) {
      resultNode = SqlStdOperatorTable.AS.createCall(
          new SqlNodeList(
              ImmutableList.of(sqlSelect,
                  new SqlIdentifier(leftResult.neededAlias, POS)), POS));
    } else {
      resultNode = sqlSelect;
    }
    return result(resultNode, leftResult, rightResult);
  }

  private boolean isCrossJoin(final Join e) {
    return e.getJoinType() == JoinRelType.INNER && e.getCondition().isAlwaysTrue();
  }

  /** @see #dispatch */
  public Result visit(Correlate e) {
    final Result leftResult =
        visitChild(0, e.getLeft())
            .resetAlias(e.getCorrelVariable(), e.getRowType());
    parseCorrelTable(e, leftResult);
    final Result rightResult = visitChild(1, e.getRight());
    final SqlNode rightLateral =
        SqlStdOperatorTable.LATERAL.createCall(POS, rightResult.node);
    final SqlNode rightLateralAs =
        SqlStdOperatorTable.AS.createCall(POS, rightLateral,
            new SqlIdentifier(rightResult.neededAlias, POS));

    final SqlNode join =
        new SqlJoin(POS,
            leftResult.asFrom(),
            SqlLiteral.createBoolean(false, POS),
            JoinType.COMMA.symbol(POS),
            rightLateralAs,
            JoinConditionType.NONE.symbol(POS),
            null);
    return result(join, leftResult, rightResult);
  }

  /** @see #dispatch */
  public Result visit(Filter e) {
    final RelNode input = e.getInput();
    Result x = visitChild(0, input);
    parseCorrelTable(e, x);
    if (input instanceof Aggregate) {
      final Builder builder;
      if (((Aggregate) input).getInput() instanceof Project) {
        builder = x.builder(e);
        builder.clauses.add(Clause.HAVING);
      } else {
        builder = x.builder(e, Clause.HAVING);
      }
      builder.setHaving(builder.context.toSql(null, e.getCondition()));
      return builder.result();
    } else {
      final Builder builder = x.builder(e, Clause.WHERE);
      builder.setWhere(builder.context.toSql(null, e.getCondition()));
      return builder.result();
    }
  }

  /** @see #dispatch */
  public Result visit(Project e) {
    e.getVariablesSet();
    Result x = visitChild(0, e.getInput());
    parseCorrelTable(e, x);
    if (isStar(e.getChildExps(), e.getInput().getRowType(), e.getRowType())) {
      return x;
    }
    final Builder builder =
        x.builder(e, Clause.SELECT);
    final List selectList = new ArrayList<>();
    for (RexNode ref : e.getChildExps()) {
      SqlNode sqlExpr = builder.context.toSql(null, ref);
      if (SqlUtil.isNullLiteral(sqlExpr, false)) {
        sqlExpr = castNullType(sqlExpr, e.getRowType().getFieldList().get(selectList.size()));
      }
      addSelect(selectList, sqlExpr, e.getRowType());
    }

    builder.setSelect(new SqlNodeList(selectList, POS));
    return builder.result();
  }

  /**
   * Wrap the {@code sqlNodeNull} in a CAST operator with target type as {@code field}.
   * @param sqlNodeNull NULL literal
   * @param field field description of {@code sqlNodeNull}
   * @return null literal wrapped in CAST call.
   */
  private SqlNode castNullType(SqlNode sqlNodeNull, RelDataTypeField field) {
    return SqlStdOperatorTable.CAST.createCall(POS,
            sqlNodeNull, dialect.getCastSpec(field.getType()));
  }

  /** @see #dispatch */
  public Result visit(Window e) {
    Result x = visitChild(0, e.getInput());
    Builder builder = x.builder(e);
    RelNode input = e.getInput();
    int inputFieldCount = input.getRowType().getFieldCount();
    final List rexOvers = new ArrayList<>();
    for (Window.Group group: e.groups) {
      rexOvers.addAll(builder.context.toSql(group, e.constants, inputFieldCount));
    }
    final List selectList = new ArrayList<>();

    for (RelDataTypeField field: input.getRowType().getFieldList()) {
      addSelect(selectList, builder.context.field(field.getIndex()), e.getRowType());
    }

    for (SqlNode rexOver: rexOvers) {
      addSelect(selectList, rexOver, e.getRowType());
    }

    builder.setSelect(new SqlNodeList(selectList, POS));
    return builder.result();
  }

  /** @see #dispatch */
  public Result visit(Aggregate e) {
    return visitAggregate(e, e.getGroupSet().toList());
  }

  private Result visitAggregate(Aggregate e, List groupKeyList) {
    // "select a, b, sum(x) from ( ... ) group by a, b"
    final Result x = visitChild(0, e.getInput());
    final Builder builder;
    if (e.getInput() instanceof Project) {
      builder = x.builder(e);
      builder.clauses.add(Clause.GROUP_BY);
    } else {
      builder = x.builder(e, Clause.GROUP_BY);
    }
    final List selectList = new ArrayList<>();
    final List groupByList =
        generateGroupList(builder, selectList, e, groupKeyList);
    return buildAggregate(e, builder, selectList, groupByList);
  }

  /**
   * Gets the {@link com.hazelcast.org.apache.calcite.rel.rel2sql.SqlImplementor.Builder} for
   * the given {@link Aggregate} node.
   *
   * @param e Aggregate node
   * @param inputResult Result from the input
   * @param inputIsProject Whether the input is a Project
   * @return A SQL builder
   */
  protected Builder getAggregateBuilder(Aggregate e, Result inputResult,
      boolean inputIsProject) {
    if (inputIsProject) {
      final Builder builder = inputResult.builder(e);
      builder.clauses.add(Clause.GROUP_BY);
      return builder;
    } else {
      return inputResult.builder(e, Clause.GROUP_BY);
    }
  }

  /**
   * Builds the group list for an Aggregate node.
   *
   * @param e The Aggregate node
   * @param builder The SQL builder
   * @param groupByList output group list
   * @param selectList output select list
   */
  protected void buildAggGroupList(Aggregate e, Builder builder,
      List groupByList, List selectList) {
    for (int group : e.getGroupSet()) {
      final SqlNode field = builder.context.field(group);
      addSelect(selectList, field, e.getRowType());
      groupByList.add(field);
    }
  }

  /**
   * Builds an aggregate query.
   *
   * @param e The Aggregate node
   * @param builder The SQL builder
   * @param selectList The precomputed group list
   * @param groupByList The precomputed select list
   * @return The aggregate query result
   */
  protected Result buildAggregate(Aggregate e, Builder builder,
      List selectList, List groupByList) {
    for (AggregateCall aggCall : e.getAggCallList()) {
      SqlNode aggCallSqlNode = builder.context.toSql(aggCall);
      if (aggCall.getAggregation() instanceof SqlSingleValueAggFunction) {
        aggCallSqlNode = dialect.rewriteSingleValueExpr(aggCallSqlNode);
      }
      addSelect(selectList, aggCallSqlNode, e.getRowType());
    }
    builder.setSelect(new SqlNodeList(selectList, POS));
    if (!groupByList.isEmpty() || e.getAggCallList().isEmpty()) {
      // Some databases don't support "GROUP BY ()". We can omit it as long
      // as there is at least one aggregate function.
      builder.setGroupBy(new SqlNodeList(groupByList, POS));
    }
    return builder.result();
  }

  /** Generates the GROUP BY items, for example {@code GROUP BY x, y},
   * {@code GROUP BY CUBE (x, y)} or {@code GROUP BY ROLLUP (x, y)}.
   *
   * 

Also populates the SELECT clause. If the GROUP BY list is simple, the * SELECT will be identical; if the GROUP BY list contains GROUPING SETS, * CUBE or ROLLUP, the SELECT clause will contain the distinct leaf * expressions. */ private List generateGroupList(Builder builder, List selectList, Aggregate aggregate, List groupList) { final List sortedGroupList = Ordering.natural().sortedCopy(groupList); assert aggregate.getGroupSet().asList().equals(sortedGroupList) : "groupList " + groupList + " must be equal to groupSet " + aggregate.getGroupSet() + ", just possibly a different order"; final List groupKeys = new ArrayList<>(); for (int key : groupList) { final SqlNode field = builder.context.field(key); groupKeys.add(field); } for (int key : sortedGroupList) { final SqlNode field = builder.context.field(key); addSelect(selectList, field, aggregate.getRowType()); } switch (aggregate.getGroupType()) { case SIMPLE: return ImmutableList.copyOf(groupKeys); case CUBE: if (aggregate.getGroupSet().cardinality() > 1) { return ImmutableList.of( SqlStdOperatorTable.CUBE.createCall(SqlParserPos.ZERO, groupKeys)); } // a singleton CUBE and ROLLUP are the same but we prefer ROLLUP; // fall through case ROLLUP: return ImmutableList.of( SqlStdOperatorTable.ROLLUP.createCall(SqlParserPos.ZERO, groupKeys)); default: case OTHER: return ImmutableList.of( SqlStdOperatorTable.GROUPING_SETS.createCall(SqlParserPos.ZERO, aggregate.getGroupSets().stream() .map(groupSet -> groupItem(groupKeys, groupSet, aggregate.getGroupSet())) .collect(Collectors.toList()))); } } private SqlNode groupItem(List groupKeys, ImmutableBitSet groupSet, ImmutableBitSet wholeGroupSet) { final List nodes = groupSet.asList().stream() .map(key -> groupKeys.get(wholeGroupSet.indexOf(key))) .collect(Collectors.toList()); switch (nodes.size()) { case 1: return nodes.get(0); default: return SqlStdOperatorTable.ROW.createCall(SqlParserPos.ZERO, nodes); } } /** @see #dispatch */ public Result visit(TableScan e) { final SqlIdentifier identifier = getSqlTargetTable(e); return result(identifier, ImmutableList.of(Clause.FROM), e, null); } /** @see #dispatch */ public Result visit(Union e) { return setOpToSql(e.all ? SqlStdOperatorTable.UNION_ALL : SqlStdOperatorTable.UNION, e); } /** @see #dispatch */ public Result visit(Intersect e) { return setOpToSql(e.all ? SqlStdOperatorTable.INTERSECT_ALL : SqlStdOperatorTable.INTERSECT, e); } /** @see #dispatch */ public Result visit(Minus e) { return setOpToSql(e.all ? SqlStdOperatorTable.EXCEPT_ALL : SqlStdOperatorTable.EXCEPT, e); } /** @see #dispatch */ public Result visit(Calc e) { Result x = visitChild(0, e.getInput()); parseCorrelTable(e, x); final RexProgram program = e.getProgram(); Builder builder = program.getCondition() != null ? x.builder(e, Clause.WHERE) : x.builder(e); if (!isStar(program)) { final List selectList = new ArrayList<>(program.getProjectList().size()); for (RexLocalRef ref : program.getProjectList()) { SqlNode sqlExpr = builder.context.toSql(program, ref); addSelect(selectList, sqlExpr, e.getRowType()); } builder.setSelect(new SqlNodeList(selectList, POS)); } if (program.getCondition() != null) { builder.setWhere( builder.context.toSql(program, program.getCondition())); } return builder.result(); } /** @see #dispatch */ public Result visit(Values e) { final List clauses = ImmutableList.of(Clause.SELECT); final Map pairs = ImmutableMap.of(); final Context context = aliasContext(pairs, false); SqlNode query; final boolean rename = stack.size() <= 1 || !(Iterables.get(stack, 1).r instanceof TableModify); final List fieldNames = e.getRowType().getFieldNames(); if (!dialect.supportsAliasedValues() && rename) { // Oracle does not support "AS t (c1, c2)". So instead of // (VALUES (v0, v1), (v2, v3)) AS t (c0, c1) // we generate // SELECT v0 AS c0, v1 AS c1 FROM DUAL // UNION ALL // SELECT v2 AS c0, v3 AS c1 FROM DUAL List list = new ArrayList<>(); for (List tuple : e.getTuples()) { final List values2 = new ArrayList<>(); final SqlNodeList exprList = exprList(context, tuple); for (Pair value : Pair.zip(exprList, fieldNames)) { values2.add(as(value.left, value.right)); } list.add( new SqlSelect(POS, null, new SqlNodeList(values2, POS), getDual(), null, null, null, null, null, null, null, null)); } if (list.isEmpty()) { // In this case we need to construct the following query: // SELECT NULL as C0, NULL as C1, NULL as C2 ... FROM DUAL WHERE FALSE // This would return an empty result set with the same number of columns as the field names. final List nullColumnNames = new ArrayList<>(fieldNames.size()); for (String fieldName : fieldNames) { SqlCall nullColumnName = as(SqlLiteral.createNull(POS), fieldName); nullColumnNames.add(nullColumnName); } final SqlIdentifier dual = getDual(); if (dual == null) { query = new SqlSelect(POS, null, new SqlNodeList(nullColumnNames, POS), null, null, null, null, null, null, null, null, null); // Wrap "SELECT 1 AS x" // as "SELECT * FROM (SELECT 1 AS x) AS t WHERE false" query = new SqlSelect(POS, null, SqlNodeList.SINGLETON_STAR, as(query, "t"), createAlwaysFalseCondition(), null, null, null, null, null, null, null); } else { query = new SqlSelect(POS, null, new SqlNodeList(nullColumnNames, POS), dual, createAlwaysFalseCondition(), null, null, null, null, null, null, null); } } else if (list.size() == 1) { query = list.get(0); } else { query = SqlStdOperatorTable.UNION_ALL.createCall( new SqlNodeList(list, POS)); } } else { // Generate ANSI syntax // (VALUES (v0, v1), (v2, v3)) // or, if rename is required // (VALUES (v0, v1), (v2, v3)) AS t (c0, c1) final SqlNodeList selects = new SqlNodeList(POS); final boolean isEmpty = Values.isEmpty(e); if (isEmpty) { // In case of empty values, we need to build: // select * from VALUES(NULL, NULL ...) as T (C1, C2 ...) // where 1=0. List nulls = IntStream.range(0, fieldNames.size()) .mapToObj(i -> SqlLiteral.createNull(POS)).collect(Collectors.toList()); selects.add(ANONYMOUS_ROW.createCall(new SqlNodeList(nulls, POS))); } else { for (List tuple : e.getTuples()) { selects.add(ANONYMOUS_ROW.createCall(exprList(context, tuple))); } } query = SqlStdOperatorTable.VALUES.createCall(selects); if (rename) { query = as(query, "t", fieldNames.toArray(new String[0])); } if (isEmpty) { if (!rename) { query = as(query, "t"); } query = new SqlSelect(POS, null, null, query, createAlwaysFalseCondition(), null, null, null, null, null, null, null); } } return result(query, clauses, e, null); } private SqlIdentifier getDual() { final List names = dialect.getSingleRowTableName(); if (names == null) { return null; } return new SqlIdentifier(names, POS); } private SqlNode createAlwaysFalseCondition() { // Building the select query in the form: // select * from VALUES(NULL,NULL ...) where 1=0 // Use condition 1=0 since "where false" does not seem to be supported // on some DB vendors. return SqlStdOperatorTable.EQUALS.createCall(POS, ImmutableList.of(SqlLiteral.createExactNumeric("1", POS), SqlLiteral.createExactNumeric("0", POS))); } /** @see #dispatch */ public Result visit(Sort e) { if (e.getInput() instanceof Aggregate) { final Aggregate aggregate = (Aggregate) e.getInput(); if (hasTrickyRollup(e, aggregate)) { // MySQL 5 does not support standard "GROUP BY ROLLUP(x, y)", only // the non-standard "GROUP BY x, y WITH ROLLUP". // It does not allow "WITH ROLLUP" in combination with "ORDER BY", // but "GROUP BY x, y WITH ROLLUP" implicitly sorts by x, y, // so skip the ORDER BY. final Set groupList = new LinkedHashSet<>(); for (RelFieldCollation fc : e.collation.getFieldCollations()) { groupList.add(aggregate.getGroupSet().nth(fc.getFieldIndex())); } groupList.addAll(Aggregate.Group.getRollup(aggregate.getGroupSets())); return offsetFetch(e, visitAggregate(aggregate, ImmutableList.copyOf(groupList))); } } if (e.getInput() instanceof Project) { // Deal with the case Sort(Project(Aggregate ...)) // by converting it to Project(Sort(Aggregate ...)). final Project project = (Project) e.getInput(); final Permutation permutation = project.getPermutation(); if (permutation != null && project.getInput() instanceof Aggregate) { final Aggregate aggregate = (Aggregate) project.getInput(); if (hasTrickyRollup(e, aggregate)) { final RelCollation collation = RelCollations.permute(e.collation, permutation); final Sort sort2 = LogicalSort.create(aggregate, collation, e.offset, e.fetch); final Project project2 = LogicalProject.create( sort2, ImmutableList.of(), project.getProjects(), project.getRowType()); return visit(project2); } } } Result x = visitChild(0, e.getInput()); Builder builder = x.builder(e, Clause.ORDER_BY); if (stack.size() != 1 && builder.select.getSelectList() == null) { // Generates explicit column names instead of start(*) for // non-root order by to avoid ambiguity. final List selectList = Expressions.list(); for (RelDataTypeField field : e.getRowType().getFieldList()) { addSelect(selectList, builder.context.field(field.getIndex()), e.getRowType()); } builder.select.setSelectList(new SqlNodeList(selectList, POS)); } List orderByList = Expressions.list(); for (RelFieldCollation field : e.getCollation().getFieldCollations()) { builder.addOrderItem(orderByList, field); } if (!orderByList.isEmpty()) { builder.setOrderBy(new SqlNodeList(orderByList, POS)); x = builder.result(); } x = offsetFetch(e, x); return x; } Result offsetFetch(Sort e, Result x) { if (e.fetch != null) { final Builder builder = x.builder(e, Clause.FETCH); builder.setFetch(builder.context.toSql(null, e.fetch)); x = builder.result(); } if (e.offset != null) { final Builder builder = x.builder(e, Clause.OFFSET); builder.setOffset(builder.context.toSql(null, e.offset)); x = builder.result(); } return x; } public boolean hasTrickyRollup(Sort e, Aggregate aggregate) { return !dialect.supportsAggregateFunction(SqlKind.ROLLUP) && dialect.supportsGroupByWithRollup() && (aggregate.getGroupType() == Aggregate.Group.ROLLUP || aggregate.getGroupType() == Aggregate.Group.CUBE && aggregate.getGroupSet().cardinality() == 1) && e.collation.getFieldCollations().stream().allMatch(fc -> fc.getFieldIndex() < aggregate.getGroupSet().cardinality()); } private SqlIdentifier getSqlTargetTable(RelNode e) { final SqlIdentifier sqlTargetTable; final JdbcTable jdbcTable = e.getTable().unwrap(JdbcTable.class); if (jdbcTable != null) { // Use the foreign catalog, schema and table names, if they exist, // rather than the qualified name of the shadow table in Calcite. sqlTargetTable = jdbcTable.tableName(); } else { final List qualifiedName = e.getTable().getQualifiedName(); sqlTargetTable = new SqlIdentifier(qualifiedName, SqlParserPos.ZERO); } return sqlTargetTable; } /** @see #dispatch */ public Result visit(TableModify modify) { final Map pairs = ImmutableMap.of(); final Context context = aliasContext(pairs, false); // Target Table Name final SqlIdentifier sqlTargetTable = getSqlTargetTable(modify); switch (modify.getOperation()) { case INSERT: { // Convert the input to a SELECT query or keep as VALUES. Not all // dialects support naked VALUES, but all support VALUES inside INSERT. final SqlNode sqlSource = visitChild(0, modify.getInput()).asQueryOrValues(); final SqlInsert sqlInsert = new SqlInsert(POS, SqlNodeList.EMPTY, sqlTargetTable, sqlSource, identifierList(modify.getTable().getRowType().getFieldNames())); return result(sqlInsert, ImmutableList.of(), modify, null); } case UPDATE: { final Result input = visitChild(0, modify.getInput()); final SqlUpdate sqlUpdate = new SqlUpdate(POS, sqlTargetTable, identifierList(modify.getUpdateColumnList()), exprList(context, modify.getSourceExpressionList()), ((SqlSelect) input.node).getWhere(), input.asSelect(), null); return result(sqlUpdate, input.clauses, modify, null); } case DELETE: { final Result input = visitChild(0, modify.getInput()); final SqlDelete sqlDelete = new SqlDelete(POS, sqlTargetTable, input.asSelect().getWhere(), input.asSelect(), null); return result(sqlDelete, input.clauses, modify, null); } case MERGE: default: throw new AssertionError("not implemented: " + modify); } } /** Converts a list of {@link RexNode} expressions to {@link SqlNode} * expressions. */ private SqlNodeList exprList(final Context context, List exprs) { return new SqlNodeList( Lists.transform(exprs, e -> context.toSql(null, e)), POS); } /** Converts a list of names expressions to a list of single-part * {@link SqlIdentifier}s. */ private SqlNodeList identifierList(List names) { return new SqlNodeList( Lists.transform(names, name -> new SqlIdentifier(name, POS)), POS); } /** @see #dispatch */ public Result visit(Match e) { final RelNode input = e.getInput(); final Result x = visitChild(0, input); final Context context = matchRecognizeContext(x.qualifiedContext()); SqlNode tableRef = x.asQueryOrValues(); final RexBuilder rexBuilder = input.getCluster().getRexBuilder(); final List partitionSqlList = new ArrayList<>(); for (int key : e.getPartitionKeys()) { final RexInputRef ref = rexBuilder.makeInputRef(input, key); SqlNode sqlNode = context.toSql(null, ref); partitionSqlList.add(sqlNode); } final SqlNodeList partitionList = new SqlNodeList(partitionSqlList, POS); final List orderBySqlList = new ArrayList<>(); if (e.getOrderKeys() != null) { for (RelFieldCollation fc : e.getOrderKeys().getFieldCollations()) { if (fc.nullDirection != RelFieldCollation.NullDirection.UNSPECIFIED) { boolean first = fc.nullDirection == RelFieldCollation.NullDirection.FIRST; SqlNode nullDirectionNode = dialect.emulateNullDirection(context.field(fc.getFieldIndex()), first, fc.direction.isDescending()); if (nullDirectionNode != null) { orderBySqlList.add(nullDirectionNode); fc = new RelFieldCollation(fc.getFieldIndex(), fc.getDirection(), RelFieldCollation.NullDirection.UNSPECIFIED); } } orderBySqlList.add(context.toSql(fc)); } } final SqlNodeList orderByList = new SqlNodeList(orderBySqlList, SqlParserPos.ZERO); final SqlLiteral rowsPerMatch = e.isAllRows() ? SqlMatchRecognize.RowsPerMatchOption.ALL_ROWS.symbol(POS) : SqlMatchRecognize.RowsPerMatchOption.ONE_ROW.symbol(POS); final SqlNode after; if (e.getAfter() instanceof RexLiteral) { SqlMatchRecognize.AfterOption value = (SqlMatchRecognize.AfterOption) ((RexLiteral) e.getAfter()).getValue2(); after = SqlLiteral.createSymbol(value, POS); } else { RexCall call = (RexCall) e.getAfter(); String operand = RexLiteral.stringValue(call.getOperands().get(0)); after = call.getOperator().createCall(POS, new SqlIdentifier(operand, POS)); } RexNode rexPattern = e.getPattern(); final SqlNode pattern = context.toSql(null, rexPattern); final SqlLiteral strictStart = SqlLiteral.createBoolean(e.isStrictStart(), POS); final SqlLiteral strictEnd = SqlLiteral.createBoolean(e.isStrictEnd(), POS); RexLiteral rexInterval = (RexLiteral) e.getInterval(); SqlIntervalLiteral interval = null; if (rexInterval != null) { interval = (SqlIntervalLiteral) context.toSql(null, rexInterval); } final SqlNodeList subsetList = new SqlNodeList(POS); for (Map.Entry> entry : e.getSubsets().entrySet()) { SqlNode left = new SqlIdentifier(entry.getKey(), POS); List rhl = new ArrayList<>(); for (String right : entry.getValue()) { rhl.add(new SqlIdentifier(right, POS)); } subsetList.add( SqlStdOperatorTable.EQUALS.createCall(POS, left, new SqlNodeList(rhl, POS))); } final SqlNodeList measureList = new SqlNodeList(POS); for (Map.Entry entry : e.getMeasures().entrySet()) { final String alias = entry.getKey(); final SqlNode sqlNode = context.toSql(null, entry.getValue()); measureList.add(as(sqlNode, alias)); } final SqlNodeList patternDefList = new SqlNodeList(POS); for (Map.Entry entry : e.getPatternDefinitions().entrySet()) { final String alias = entry.getKey(); final SqlNode sqlNode = context.toSql(null, entry.getValue()); patternDefList.add(as(sqlNode, alias)); } final SqlNode matchRecognize = new SqlMatchRecognize(POS, tableRef, pattern, strictStart, strictEnd, patternDefList, measureList, after, subsetList, rowsPerMatch, partitionList, orderByList, interval); return result(matchRecognize, Expressions.list(Clause.FROM), e, null); } private SqlCall as(SqlNode e, String alias) { return SqlStdOperatorTable.AS.createCall(POS, e, new SqlIdentifier(alias, POS)); } public Result visit(Uncollect e) { final Result x = visitChild(0, e.getInput()); final SqlNode unnestNode = SqlStdOperatorTable.UNNEST.createCall(POS, x.asStatement()); final List operands = createAsFullOperands(e.getRowType(), unnestNode, x.neededAlias); final SqlNode asNode = SqlStdOperatorTable.AS.createCall(POS, operands); return result(asNode, ImmutableList.of(Clause.FROM), e, null); } public Result visit(TableFunctionScan e) { final List inputSqlNodes = new ArrayList<>(); final int inputSize = e.getInputs().size(); for (int i = 0; i < inputSize; i++) { Result child = visitChild(i, e.getInput(i)); inputSqlNodes.add(child.asStatement()); } final Context context = tableFunctionScanContext(inputSqlNodes); SqlNode callNode = context.toSql(null, e.getCall()); // Convert to table function call, "TABLE($function_name(xxx))" SqlNode tableCall = new SqlBasicCall( SqlStdOperatorTable.COLLECTION_TABLE, new SqlNode[]{callNode}, SqlParserPos.ZERO); SqlNode select = new SqlSelect( SqlParserPos.ZERO, null, null, tableCall, null, null, null, null, null, null, null, SqlNodeList.EMPTY); return result(select, ImmutableList.of(Clause.SELECT), e, null); } /** * Creates operands for a full AS operator. Format SqlNode AS alias(col_1, col_2,... ,col_n). * * @param rowType Row type of the SqlNode * @param leftOperand SqlNode * @param alias alias */ public List createAsFullOperands(RelDataType rowType, SqlNode leftOperand, String alias) { final List result = new ArrayList<>(); result.add(leftOperand); result.add(new SqlIdentifier(alias, POS)); Ord.forEach(rowType.getFieldNames(), (fieldName, i) -> { if (fieldName.toLowerCase(Locale.ROOT).startsWith("expr$")) { fieldName = "col_" + i; } result.add(new SqlIdentifier(fieldName, POS)); }); return result; } @Override public void addSelect(List selectList, SqlNode node, RelDataType rowType) { String name = rowType.getFieldNames().get(selectList.size()); String alias = SqlValidatorUtil.getAlias(node, -1); if (alias == null || !alias.equals(name)) { node = as(node, name); } selectList.add(node); } private void parseCorrelTable(RelNode relNode, Result x) { for (CorrelationId id : relNode.getVariablesSet()) { correlTableMap.put(id, x.qualifiedContext()); } } /** Stack frame. */ private static class Frame { private final int ordinalInParent; private final RelNode r; private final boolean anon; Frame(int ordinalInParent, RelNode r, boolean anon) { this.ordinalInParent = ordinalInParent; this.r = Objects.requireNonNull(r); this.anon = anon; } } }





© 2015 - 2024 Weber Informatics LLC | Privacy Policy