org.apache.calcite.tools.Planner Java Examples
The following examples show how to use
org.apache.calcite.tools.Planner.
You can vote up the ones you like or vote down the ones you don't like,
and go to the original project or source file by following the links above each example. You may check out the related API usage on the sidebar.
Example #1
Source File: LexEscapeTest.java From calcite with Apache License 2.0 | 6 votes |
private static void runProjectQueryWithLex(Lex lex, String sql) throws SqlParseException, ValidationException, RelConversionException { Config javaLex = SqlParser.configBuilder().setLex(lex).build(); Planner planner = getPlanner(null, javaLex, Programs.ofRules(Programs.RULE_SET)); SqlNode parse = planner.parse(sql); SqlNode validate = planner.validate(parse); RelNode convert = planner.rel(validate).rel; assertThat(convert, instanceOf(LogicalProject.class)); List<RelDataTypeField> fields = convert.getRowType().getFieldList(); // Get field type from sql text and validate we parsed it after validation. assertThat(fields.size(), is(4)); assertThat(fields.get(0).getType().getSqlTypeName(), is(SqlTypeName.VARCHAR)); assertThat(fields.get(1).getType().getSqlTypeName(), is(SqlTypeName.TIME)); assertThat(fields.get(2).getType().getSqlTypeName(), is(SqlTypeName.INTEGER)); assertThat(fields.get(3).getType().getSqlTypeName(), is(SqlTypeName.TIMESTAMP)); }
Example #2
Source File: SQLExecEnvironment.java From attic-apex-malhar with Apache License 2.0 | 6 votes |
/** * This is the main method takes SQL statement as input and contructs a DAG using contructs registered with this * {@link SQLExecEnvironment}. * * @param sql SQL statement that should be converted to a DAG. */ public void executeSQL(DAG dag, String sql) { FrameworkConfig config = buildFrameWorkConfig(); Planner planner = Frameworks.getPlanner(config); try { logger.info("Parsing SQL statement: {}", sql); SqlNode parsedTree = planner.parse(sql); SqlNode validatedTree = planner.validate(parsedTree); RelNode relationalTree = planner.rel(validatedTree).rel; logger.info("RelNode relationalTree generate from SQL statement is:\n {}", Util.toLinux(RelOptUtil.toString(relationalTree))); RelNodeVisitor visitor = new RelNodeVisitor(dag, typeFactory); visitor.traverse(relationalTree); } catch (Exception e) { throw Throwables.propagate(e); } finally { planner.close(); } }
Example #3
Source File: RuleParser.java From streamline with Apache License 2.0 | 6 votes |
public void parse() { try { SchemaPlus schema = Frameworks.createRootSchema(true); FrameworkConfig config = Frameworks.newConfigBuilder().defaultSchema(schema).build(); Planner planner = Frameworks.getPlanner(config); SqlSelect sqlSelect = (SqlSelect) planner.parse(sql); // FROM streams = parseStreams(sqlSelect); // SELECT projection = parseProjection(sqlSelect); // WHERE condition = parseCondition(sqlSelect); // GROUP BY groupBy = parseGroupBy(sqlSelect); // HAVING having = parseHaving(sqlSelect); } catch (Exception ex) { LOG.error("Got Exception while parsing rule {}", sql); throw new RuntimeException(ex); } }
Example #4
Source File: StreamlineSqlImpl.java From streamline with Apache License 2.0 | 6 votes |
@Override public void execute( Iterable<String> statements, ChannelHandler result) throws Exception { Map<String, DataSource> dataSources = new HashMap<>(); for (String sql : statements) { StreamlineParser parser = new StreamlineParser(sql); SqlNode node = parser.impl().parseSqlStmtEof(); if (node instanceof SqlCreateTable) { handleCreateTable((SqlCreateTable) node, dataSources); } else if (node instanceof SqlCreateFunction) { handleCreateFunction((SqlCreateFunction) node); } else { FrameworkConfig config = buildFrameWorkConfig(); Planner planner = Frameworks.getPlanner(config); SqlNode parse = planner.parse(sql); SqlNode validate = planner.validate(parse); RelNode tree = planner.convert(validate); PlanCompiler compiler = new PlanCompiler(typeFactory); AbstractValuesProcessor proc = compiler.compile(tree); proc.initialize(dataSources, result); } } }
Example #5
Source File: LexEscapeTest.java From calcite with Apache License 2.0 | 6 votes |
private static Planner getPlanner(List<RelTraitDef> traitDefs, Config parserConfig, Program... programs) { final SchemaPlus rootSchema = Frameworks.createRootSchema(true); rootSchema.add("TMP", new AbstractTable() { @Override public RelDataType getRowType(RelDataTypeFactory typeFactory) { return typeFactory.createStructType( ImmutableList.of(typeFactory.createSqlType(SqlTypeName.VARCHAR), typeFactory.createSqlType(SqlTypeName.INTEGER)), ImmutableList.of("localtime", "current_timestamp")); } }); final FrameworkConfig config = Frameworks.newConfigBuilder() .parserConfig(parserConfig) .defaultSchema(rootSchema) .traitDefs(traitDefs) .programs(programs) .operatorTable(SqlStdOperatorTable.instance()) .build(); return Frameworks.getPlanner(config); }
Example #6
Source File: LexCaseSensitiveTest.java From calcite with Apache License 2.0 | 6 votes |
private static void runProjectQueryWithLex(Lex lex, String sql) throws SqlParseException, ValidationException, RelConversionException { Config javaLex = SqlParser.configBuilder().setLex(lex).build(); Planner planner = getPlanner(null, javaLex, Programs.ofRules(Programs.RULE_SET)); SqlNode parse = planner.parse(sql); SqlNode validate = planner.validate(parse); RelNode convert = planner.rel(validate).rel; RelTraitSet traitSet = convert.getTraitSet().replace(EnumerableConvention.INSTANCE); RelNode transform = planner.transform(0, traitSet, convert); assertThat(transform, instanceOf(EnumerableProject.class)); List<String> fieldNames = transform.getRowType().getFieldNames(); assertThat(fieldNames.size(), is(2)); if (lex.caseSensitive) { assertThat(fieldNames.get(0), is("EMPID")); assertThat(fieldNames.get(1), is("empid")); } else { assertThat(fieldNames.get(0) + "-" + fieldNames.get(1), anyOf(is("EMPID-empid0"), is("EMPID0-empid"))); } }
Example #7
Source File: SortRemoveRuleTest.java From calcite with Apache License 2.0 | 6 votes |
/** * The default schema that is used in these tests provides tables sorted on the primary key. Due * to this scan operators always come with a {@link org.apache.calcite.rel.RelCollation} trait. */ private RelNode transform(String sql, RuleSet prepareRules) throws Exception { final SchemaPlus rootSchema = Frameworks.createRootSchema(true); final SchemaPlus defSchema = rootSchema.add("hr", new HrClusteredSchema()); final FrameworkConfig config = Frameworks.newConfigBuilder() .parserConfig(SqlParser.Config.DEFAULT) .defaultSchema(defSchema) .traitDefs(ConventionTraitDef.INSTANCE, RelCollationTraitDef.INSTANCE) .programs( Programs.of(prepareRules), Programs.ofRules(SortRemoveRule.INSTANCE)) .build(); Planner planner = Frameworks.getPlanner(config); SqlNode parse = planner.parse(sql); SqlNode validate = planner.validate(parse); RelRoot planRoot = planner.rel(validate); RelNode planBefore = planRoot.rel; RelTraitSet desiredTraits = planBefore.getTraitSet() .replace(EnumerableConvention.INSTANCE); RelNode planAfter = planner.transform(0, desiredTraits, planBefore); return planner.transform(1, desiredTraits, planAfter); }
Example #8
Source File: SqlWorker.java From quark with Apache License 2.0 | 6 votes |
private Planner buildPlanner(QueryContext context) { final List<RelTraitDef> traitDefs = new ArrayList<RelTraitDef>(); traitDefs.add(ConventionTraitDef.INSTANCE); traitDefs.add(RelCollationTraitDef.INSTANCE); final ChainedSqlOperatorTable opTab = new ChainedSqlOperatorTable( ImmutableList.of(SqlStdOperatorTable.instance(), HiveSqlOperatorTable.instance(), catalogReader)); FrameworkConfig config = Frameworks.newConfigBuilder() // .parserConfig(SqlParser.configBuilder() .setQuotedCasing(Casing.UNCHANGED) .setUnquotedCasing(Casing.TO_UPPER) .setQuoting(Quoting.DOUBLE_QUOTE) .build()) // .defaultSchema(context.getDefaultSchema()) // .operatorTable(opTab) // .traitDefs(traitDefs) // .convertletTable(StandardConvertletTable.INSTANCE)// .programs(getPrograms()) // .typeSystem(RelDataTypeSystem.DEFAULT) // .build(); return Frameworks.getPlanner(config); }
Example #9
Source File: TableEnv.java From marble with Apache License 2.0 | 6 votes |
protected RelRoot getSqlPlanRel(String sql) throws Throwable { try (Planner planner = Frameworks.getPlanner(frameworkConfig)) { RelRoot root; final SqlNode parsedSqlNode = planner.parse(sql); final Pair<SqlNode, RelDataType> validatedSqlNodeAndType = planner .validateAndGetType( parsedSqlNode); root = planner.rel(validatedSqlNodeAndType.getKey()); final Program program = createProgram(); //getDesiredTraits final RelTraitSet desiredTraits = root.rel.getTraitSet() .replace(EnumerableConvention.INSTANCE) .replace(root.collation) .simplify(); RelNode logicalRelNode = root.rel; final RelNode optimizedRelNode = program.run( root.rel.getCluster().getPlanner(), logicalRelNode, desiredTraits, Collections.emptyList(), Collections.emptyList()); root = root.withRel(optimizedRelNode); return root; } }
Example #10
Source File: TpcdsLatticeSuggesterTest.java From calcite with Apache License 2.0 | 5 votes |
List<Lattice> addQuery(String q) throws SqlParseException, ValidationException, RelConversionException { final Planner planner = new PlannerImpl(config); final SqlNode node = planner.parse(q); final SqlNode node2 = planner.validate(node); final RelRoot root = planner.rel(node2); return suggester.addQuery(root.project()); }
Example #11
Source File: RexSqlStandardConvertletTableTest.java From calcite with Apache License 2.0 | 5 votes |
private RelNode convertSqlToRel(String sql, boolean simplifyRex) { final FrameworkConfig config = Frameworks.newConfigBuilder() .defaultSchema(CalciteSchema.createRootSchema(false).plus()) .parserConfig(SqlParser.configBuilder().build()) .build(); final Planner planner = Frameworks.getPlanner(config); try (Closer closer = new Closer()) { closer.add(Hook.REL_BUILDER_SIMPLIFY.addThread(Hook.propertyJ(simplifyRex))); final SqlNode parsed = planner.parse(sql); final SqlNode validated = planner.validate(parsed); return planner.rel(validated).rel; } catch (SqlParseException | RelConversionException | ValidationException e) { throw TestUtil.rethrow(e); } }
Example #12
Source File: InterpreterTest.java From calcite with Apache License 2.0 | 5 votes |
Sql(String sql, MyDataContext dataContext, Planner planner, boolean project) { this.sql = sql; this.dataContext = dataContext; this.planner = planner; this.project = project; }
Example #13
Source File: ExtensionDdlExecutor.java From calcite with Apache License 2.0 | 5 votes |
/** Populates the table called {@code name} by executing {@code query}. */ protected static void populate(SqlIdentifier name, SqlNode query, CalcitePrepare.Context context) { // Generate, prepare and execute an "INSERT INTO table query" statement. // (It's a bit inefficient that we convert from SqlNode to SQL and back // again.) final FrameworkConfig config = Frameworks.newConfigBuilder() .defaultSchema( Objects.requireNonNull( Schemas.subSchema(context.getRootSchema(), context.getDefaultSchemaPath())).plus()) .build(); final Planner planner = Frameworks.getPlanner(config); try { final StringBuilder buf = new StringBuilder(); final SqlPrettyWriter w = new SqlPrettyWriter( SqlPrettyWriter.config() .withDialect(CalciteSqlDialect.DEFAULT) .withAlwaysUseParentheses(false), buf); buf.append("INSERT INTO "); name.unparse(w, 0, 0); buf.append(" "); query.unparse(w, 0, 0); final String sql = buf.toString(); final SqlNode query1 = planner.parse(sql); final SqlNode query2 = planner.validate(query1); final RelRoot r = planner.rel(query2); final PreparedStatement prepare = context.getRelRunner().prepare(r.rel); int rowCount = prepare.executeUpdate(); Util.discard(rowCount); prepare.close(); } catch (SqlParseException | ValidationException | RelConversionException | SQLException e) { throw new RuntimeException(e); } }
Example #14
Source File: LexCaseSensitiveTest.java From calcite with Apache License 2.0 | 5 votes |
private static Planner getPlanner(List<RelTraitDef> traitDefs, SqlParser.Config parserConfig, Program... programs) { final SchemaPlus rootSchema = Frameworks.createRootSchema(true); final FrameworkConfig config = Frameworks.newConfigBuilder() .parserConfig(parserConfig) .defaultSchema(CalciteAssert.addSchema(rootSchema, CalciteAssert.SchemaSpec.HR)) .traitDefs(traitDefs) .programs(programs) .build(); return Frameworks.getPlanner(config); }
Example #15
Source File: ToLogicalConverterTest.java From calcite with Apache License 2.0 | 5 votes |
private static RelNode rel(String sql) { final Planner planner = Frameworks.getPlanner(frameworkConfig()); try { SqlNode parse = planner.parse(sql); SqlNode validate = planner.validate(parse); return planner.rel(validate).rel; } catch (Exception e) { throw TestUtil.rethrow(e); } }
Example #16
Source File: LatticeSuggesterTest.java From calcite with Apache License 2.0 | 5 votes |
List<Lattice> addQuery(String q) throws SqlParseException, ValidationException, RelConversionException { final Planner planner = new PlannerImpl(config); final SqlNode node = planner.parse(q); final SqlNode node2 = planner.validate(node); final RelRoot root = planner.rel(node2); return s.addQuery(root.project()); }
Example #17
Source File: ServerDdlExecutor.java From calcite with Apache License 2.0 | 5 votes |
/** Populates the table called {@code name} by executing {@code query}. */ static void populate(SqlIdentifier name, SqlNode query, CalcitePrepare.Context context) { // Generate, prepare and execute an "INSERT INTO table query" statement. // (It's a bit inefficient that we convert from SqlNode to SQL and back // again.) final FrameworkConfig config = Frameworks.newConfigBuilder() .defaultSchema(context.getRootSchema().plus()) .build(); final Planner planner = Frameworks.getPlanner(config); try { final StringBuilder buf = new StringBuilder(); final SqlWriterConfig writerConfig = SqlPrettyWriter.config().withAlwaysUseParentheses(false); final SqlPrettyWriter w = new SqlPrettyWriter(writerConfig, buf); buf.append("INSERT INTO "); name.unparse(w, 0, 0); buf.append(' '); query.unparse(w, 0, 0); final String sql = buf.toString(); final SqlNode query1 = planner.parse(sql); final SqlNode query2 = planner.validate(query1); final RelRoot r = planner.rel(query2); final PreparedStatement prepare = context.getRelRunner().prepare(r.rel); int rowCount = prepare.executeUpdate(); Util.discard(rowCount); prepare.close(); } catch (SqlParseException | ValidationException | RelConversionException | SQLException e) { throw new RuntimeException(e); } }
Example #18
Source File: TestCompilerUtils.java From streamline with Apache License 2.0 | 5 votes |
public static CalciteState sqlOverDummyTable(String sql) throws RelConversionException, ValidationException, SqlParseException { SchemaPlus schema = Frameworks.createRootSchema(true); JavaTypeFactory typeFactory = new JavaTypeFactoryImpl (RelDataTypeSystem.DEFAULT); StreamableTable streamableTable = new CompilerUtil.TableBuilderInfo(typeFactory) .field("ID", SqlTypeName.INTEGER) .field("NAME", typeFactory.createType(String.class)) .field("ADDR", typeFactory.createType(String.class)) .build(); Table table = streamableTable.stream(); schema.add("FOO", table); schema.add("BAR", table); schema.add("MYPLUS", ScalarFunctionImpl.create(MyPlus.class, "eval")); List<SqlOperatorTable> sqlOperatorTables = new ArrayList<>(); sqlOperatorTables.add(SqlStdOperatorTable.instance()); sqlOperatorTables.add(new CalciteCatalogReader(CalciteSchema.from(schema), false, Collections.<String>emptyList(), typeFactory)); SqlOperatorTable chainedSqlOperatorTable = new ChainedSqlOperatorTable(sqlOperatorTables); FrameworkConfig config = Frameworks.newConfigBuilder().defaultSchema( schema).operatorTable(chainedSqlOperatorTable).build(); Planner planner = Frameworks.getPlanner(config); SqlNode parse = planner.parse(sql); SqlNode validate = planner.validate(parse); RelNode tree = planner.convert(validate); System.out.println(RelOptUtil.toString(tree, SqlExplainLevel.ALL_ATTRIBUTES)); return new CalciteState(schema, tree); }
Example #19
Source File: SamzaSqlQueryParser.java From samza with Apache License 2.0 | 5 votes |
private static Planner createPlanner() { Connection connection; SchemaPlus rootSchema; try { JavaTypeFactory typeFactory = new SamzaSqlJavaTypeFactoryImpl(); SamzaSqlDriver driver = new SamzaSqlDriver(typeFactory); DriverManager.deregisterDriver(DriverManager.getDriver("jdbc:calcite:")); DriverManager.registerDriver(driver); connection = driver.connect("jdbc:calcite:", new Properties()); CalciteConnection calciteConnection = connection.unwrap(CalciteConnection.class); rootSchema = calciteConnection.getRootSchema(); } catch (SQLException e) { throw new SamzaException(e); } final List<RelTraitDef> traitDefs = new ArrayList<>(); traitDefs.add(ConventionTraitDef.INSTANCE); traitDefs.add(RelCollationTraitDef.INSTANCE); FrameworkConfig frameworkConfig = Frameworks.newConfigBuilder() .parserConfig(SqlParser.configBuilder().setLex(Lex.JAVA).build()) .defaultSchema(rootSchema) .operatorTable(SqlStdOperatorTable.instance()) .traitDefs(traitDefs) .context(Contexts.EMPTY_CONTEXT) .costFactory(null) .build(); return Frameworks.getPlanner(frameworkConfig); }
Example #20
Source File: SqlHandlerConfig.java From quark with Apache License 2.0 | 4 votes |
public Planner getPlanner() { return planner; }
Example #21
Source File: SqlHandlerConfig.java From quark with Apache License 2.0 | 4 votes |
public SqlHandlerConfig(Planner planner) { this.planner = planner; }
Example #22
Source File: TestCompilerUtils.java From streamline with Apache License 2.0 | 4 votes |
public static CalciteState sqlOverNestedTable(String sql) throws RelConversionException, ValidationException, SqlParseException { SchemaPlus schema = Frameworks.createRootSchema(true); JavaTypeFactory typeFactory = new JavaTypeFactoryImpl (RelDataTypeSystem.DEFAULT); StreamableTable streamableTable = new CompilerUtil.TableBuilderInfo(typeFactory) .field("ID", SqlTypeName.INTEGER) .field("MAPFIELD", typeFactory.createTypeWithNullability( typeFactory.createMapType( typeFactory.createTypeWithNullability( typeFactory.createSqlType(SqlTypeName.VARCHAR), true), typeFactory.createTypeWithNullability( typeFactory.createSqlType(SqlTypeName.INTEGER), true)) , true)) .field("NESTEDMAPFIELD", typeFactory.createTypeWithNullability( typeFactory.createMapType( typeFactory.createTypeWithNullability( typeFactory.createSqlType(SqlTypeName.VARCHAR), true), typeFactory.createTypeWithNullability( typeFactory.createMapType( typeFactory.createTypeWithNullability( typeFactory.createSqlType(SqlTypeName.VARCHAR), true), typeFactory.createTypeWithNullability( typeFactory.createSqlType(SqlTypeName.INTEGER), true)) , true)) , true)) .field("ARRAYFIELD", typeFactory.createTypeWithNullability( typeFactory.createArrayType( typeFactory.createTypeWithNullability( typeFactory.createSqlType(SqlTypeName.INTEGER), true), -1L) , true)) .build(); Table table = streamableTable.stream(); schema.add("FOO", table); schema.add("BAR", table); schema.add("MYPLUS", ScalarFunctionImpl.create(MyPlus.class, "eval")); List<SqlOperatorTable> sqlOperatorTables = new ArrayList<>(); sqlOperatorTables.add(SqlStdOperatorTable.instance()); sqlOperatorTables.add(new CalciteCatalogReader(CalciteSchema.from(schema), false, Collections.<String>emptyList(), typeFactory)); SqlOperatorTable chainedSqlOperatorTable = new ChainedSqlOperatorTable(sqlOperatorTables); FrameworkConfig config = Frameworks.newConfigBuilder().defaultSchema( schema).operatorTable(chainedSqlOperatorTable).build(); Planner planner = Frameworks.getPlanner(config); SqlNode parse = planner.parse(sql); SqlNode validate = planner.validate(parse); RelNode tree = planner.convert(validate); System.out.println(RelOptUtil.toString(tree, SqlExplainLevel.ALL_ATTRIBUTES)); return new CalciteState(schema, tree); }
Example #23
Source File: QueryPlanner.java From samza with Apache License 2.0 | 4 votes |
public RelRoot plan(String query) { try { Connection connection = DriverManager.getConnection("jdbc:calcite:"); CalciteConnection calciteConnection = connection.unwrap(CalciteConnection.class); SchemaPlus rootSchema = calciteConnection.getRootSchema(); registerSourceSchemas(rootSchema); List<SamzaSqlScalarFunctionImpl> samzaSqlFunctions = udfMetadata.stream() .map(x -> new SamzaSqlScalarFunctionImpl(x)) .collect(Collectors.toList()); final List<RelTraitDef> traitDefs = new ArrayList<>(); traitDefs.add(ConventionTraitDef.INSTANCE); traitDefs.add(RelCollationTraitDef.INSTANCE); List<SqlOperatorTable> sqlOperatorTables = new ArrayList<>(); sqlOperatorTables.add(new SamzaSqlOperatorTable()); sqlOperatorTables.add(new SamzaSqlUdfOperatorTable(samzaSqlFunctions)); // Using lenient so that !=,%,- are allowed. FrameworkConfig frameworkConfig = Frameworks.newConfigBuilder() .parserConfig(SqlParser.configBuilder() .setLex(Lex.JAVA) .setConformance(SqlConformanceEnum.LENIENT) .setCaseSensitive(false) // Make Udfs case insensitive .build()) .defaultSchema(rootSchema) .operatorTable(new ChainedSqlOperatorTable(sqlOperatorTables)) .sqlToRelConverterConfig(SqlToRelConverter.Config.DEFAULT) .traitDefs(traitDefs) .context(Contexts.EMPTY_CONTEXT) .costFactory(null) .build(); Planner planner = Frameworks.getPlanner(frameworkConfig); SqlNode sql = planner.parse(query); SqlNode validatedSql = planner.validate(sql); RelRoot relRoot = planner.rel(validatedSql); LOG.info("query plan:\n" + RelOptUtil.toString(relRoot.rel, SqlExplainLevel.ALL_ATTRIBUTES)); return relRoot; } catch (Exception e) { String errorMsg = SamzaSqlValidator.formatErrorString(query, e); LOG.error(errorMsg, e); throw new SamzaException(errorMsg, e); } }
Example #24
Source File: InterpreterTest.java From calcite with Apache License 2.0 | 4 votes |
MyDataContext(Planner planner) { this.planner = planner; }
Example #25
Source File: CalcitePlanner.java From herddb with Apache License 2.0 | 4 votes |
private PlannerResult runPlanner(String defaultTableSpace, String query) throws RelConversionException, SqlParseException, ValidationException, MetadataStorageManagerException, StatementExecutionException { SchemaPlus subSchema = getSchemaForTableSpace(defaultTableSpace); if (subSchema == null) { clearCache(); throw new StatementExecutionException("tablespace " + defaultTableSpace + " is not available"); } Properties props = new Properties(); props.put(CalciteConnectionProperty.TIME_ZONE.camelName(), TimeZone.getDefault().getID()); props.put(CalciteConnectionProperty.LOCALE.camelName(), Locale.ROOT.toString()); final CalciteConnectionConfigImpl calciteRuntimeContextConfig = new CalciteConnectionConfigImpl(props); final FrameworkConfig config = Frameworks.newConfigBuilder() .parserConfig(SQL_PARSER_CONFIG) .defaultSchema(subSchema) .traitDefs(TRAITS) .context(new Context() { @Override public <C> C unwrap(Class<C> aClass) { if (aClass == CalciteConnectionConfigImpl.class || aClass == CalciteConnectionConfig.class) { return (C) calciteRuntimeContextConfig; } return null; } }) // define the rules you want to apply .programs(Programs.ofRules(Programs.RULE_SET)) .build(); Planner planner = Frameworks.getPlanner(config); if (LOG.isLoggable(Level.FINER)) { LOG.log(Level.FINER, "Query: {0}", query); } try { SqlNode n = planner.parse(query); n = planner.validate(n); RelNode logicalPlan = planner.rel(n).project(); if (LOG.isLoggable(DUMP_QUERY_LEVEL)) { LOG.log(DUMP_QUERY_LEVEL, "Query: {0} {1}", new Object[]{query, RelOptUtil.dumpPlan("-- Logical Plan", logicalPlan, SqlExplainFormat.TEXT, SqlExplainLevel.ALL_ATTRIBUTES)}); } RelDataType originalRowType = logicalPlan.getRowType(); RelOptCluster cluster = logicalPlan.getCluster(); final RelOptPlanner optPlanner = cluster.getPlanner(); optPlanner.addRule(ReduceExpressionsRule.FILTER_INSTANCE); RelTraitSet desiredTraits = cluster.traitSet() .replace(EnumerableConvention.INSTANCE); final RelCollation collation = logicalPlan instanceof Sort ? ((Sort) logicalPlan).collation : null; if (collation != null) { desiredTraits = desiredTraits.replace(collation); } final RelNode newRoot = optPlanner.changeTraits(logicalPlan, desiredTraits); optPlanner.setRoot(newRoot); RelNode bestExp = optPlanner.findBestExp(); if (LOG.isLoggable(DUMP_QUERY_LEVEL)) { LOG.log(DUMP_QUERY_LEVEL, "Query: {0} {1}", new Object[]{query, RelOptUtil.dumpPlan("-- Best Plan", bestExp, SqlExplainFormat.TEXT, SqlExplainLevel.ALL_ATTRIBUTES)}); } return new PlannerResult(bestExp, originalRowType, logicalPlan, n); } catch (AssertionError err) { throw new StatementExecutionException("Internal Calcite error " + err, err); } }
Example #26
Source File: TestSqlBracketlessSyntax.java From dremio-oss with Apache License 2.0 | 4 votes |
@Test public void checkComplexExpressionParsing() throws Exception{ FrameworkConfig config = Frameworks.newConfigBuilder() .parserConfig(SqlParser.configBuilder() .setLex(Lex.MYSQL) .setIdentifierMaxLength(PlannerSettings.DEFAULT_IDENTIFIER_MAX_LENGTH) .setParserFactory(ParserImpl.FACTORY) .build()) .defaultSchema(CalciteSchema.createRootSchema(false /* addMetadata */, false /* cache */).plus()) .convertletTable(new ConvertletTable(new ContextInformation() { @Override public String getQueryUser() { return null; } @Override public String getCurrentDefaultSchema() { return null; } @Override public long getQueryStartTime() { return 0; } @Override public int getRootFragmentTimeZone() { return 0; } @Override public QueryId getLastQueryId() { return null; } @Override public void registerAdditionalInfo(AdditionalContext object) { } @Override public <T extends AdditionalContext> T getAdditionalInfo(Class<T> claz) { return null; } })) .build(); Planner planner = Frameworks.getPlanner(config); SqlNode node = planner.parse("" + "select a[4].c \n" + "from x.y.z \n" + "where a.c.b = 5 and x[2] = 7 \n" + "group by d \n" + "having a.c < 5 \n" + "order by x.a.a.a.a.a"); String expected = "SELECT `a`[4]['c']\n" + "FROM `x`.`y`.`z`\n" + "WHERE `a`.`c`['b'] = 5 AND `x`[2] = 7\n" + "GROUP BY `d`\n" + "HAVING `a`.`c` < 5\n" + "ORDER BY `x`.`a`['a']['a']['a']['a']"; SqlNode rewritten = node.accept(new CompoundIdentifierConverter()); String rewrittenQuery = rewritten.toString(); DremioAssert.assertMultiLineStringEquals(expected, rewrittenQuery); }