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

com.hazelcast.org.apache.calcite.adapter.jdbc.JdbcTable Maven / Gradle / Ivy

/*
 * 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.adapter.jdbc;

import com.hazelcast.org.apache.calcite.DataContext;
import com.hazelcast.org.apache.calcite.adapter.java.AbstractQueryableTable;
import com.hazelcast.org.apache.calcite.adapter.java.JavaTypeFactory;
import com.hazelcast.org.apache.calcite.avatica.ColumnMetaData;
import com.hazelcast.org.apache.calcite.jdbc.CalciteConnection;
import com.hazelcast.org.apache.calcite.linq4j.Enumerable;
import com.hazelcast.org.apache.calcite.linq4j.Enumerator;
import com.hazelcast.org.apache.calcite.linq4j.QueryProvider;
import com.hazelcast.org.apache.calcite.linq4j.Queryable;
import com.hazelcast.org.apache.calcite.plan.Convention;
import com.hazelcast.org.apache.calcite.plan.RelOptCluster;
import com.hazelcast.org.apache.calcite.plan.RelOptTable;
import com.hazelcast.org.apache.calcite.prepare.Prepare.CatalogReader;
import com.hazelcast.org.apache.calcite.rel.RelNode;
import com.hazelcast.org.apache.calcite.rel.core.TableModify;
import com.hazelcast.org.apache.calcite.rel.core.TableModify.Operation;
import com.hazelcast.org.apache.calcite.rel.logical.LogicalTableModify;
import com.hazelcast.org.apache.calcite.rel.type.RelDataType;
import com.hazelcast.org.apache.calcite.rel.type.RelDataTypeFactory;
import com.hazelcast.org.apache.calcite.rel.type.RelProtoDataType;
import com.hazelcast.org.apache.calcite.rex.RexNode;
import com.hazelcast.org.apache.calcite.runtime.ResultSetEnumerable;
import com.hazelcast.org.apache.calcite.schema.ModifiableTable;
import com.hazelcast.org.apache.calcite.schema.ScannableTable;
import com.hazelcast.org.apache.calcite.schema.Schema;
import com.hazelcast.org.apache.calcite.schema.SchemaPlus;
import com.hazelcast.org.apache.calcite.schema.TranslatableTable;
import com.hazelcast.org.apache.calcite.schema.impl.AbstractTableQueryable;
import com.hazelcast.org.apache.calcite.sql.SqlIdentifier;
import com.hazelcast.org.apache.calcite.sql.SqlNodeList;
import com.hazelcast.org.apache.calcite.sql.SqlSelect;
import com.hazelcast.org.apache.calcite.sql.SqlWriterConfig;
import com.hazelcast.org.apache.calcite.sql.parser.SqlParserPos;
import com.hazelcast.org.apache.calcite.sql.pretty.SqlPrettyWriter;
import com.hazelcast.org.apache.calcite.sql.util.SqlString;
import com.hazelcast.org.apache.calcite.util.Pair;
import com.hazelcast.org.apache.calcite.util.Util;

import com.hazelcast.com.google.common.collect.Lists;

import java.sql.SQLException;
import java.util.ArrayList;
import java.util.Collection;
import java.util.List;
import java.util.Objects;

/**
 * Queryable that gets its data from a table within a JDBC connection.
 *
 * 

The idea is not to read the whole table, however. The idea is to use * this as a building block for a query, by applying Queryable operators * such as * {@link com.hazelcast.org.apache.calcite.linq4j.Queryable#where(com.hazelcast.org.apache.calcite.linq4j.function.Predicate2)}. * The resulting queryable can then be converted to a SQL query, which can be * executed efficiently on the JDBC server.

*/ public class JdbcTable extends AbstractQueryableTable implements TranslatableTable, ScannableTable, ModifiableTable { private RelProtoDataType protoRowType; public final JdbcSchema jdbcSchema; public final String jdbcCatalogName; public final String jdbcSchemaName; public final String jdbcTableName; public final Schema.TableType jdbcTableType; JdbcTable(JdbcSchema jdbcSchema, String jdbcCatalogName, String jdbcSchemaName, String jdbcTableName, Schema.TableType jdbcTableType) { super(Object[].class); this.jdbcSchema = Objects.requireNonNull(jdbcSchema); this.jdbcCatalogName = jdbcCatalogName; this.jdbcSchemaName = jdbcSchemaName; this.jdbcTableName = Objects.requireNonNull(jdbcTableName); this.jdbcTableType = Objects.requireNonNull(jdbcTableType); } public String toString() { return "JdbcTable {" + jdbcTableName + "}"; } @Override public Schema.TableType getJdbcTableType() { return jdbcTableType; } @Override public C unwrap(Class aClass) { if (aClass.isInstance(jdbcSchema.getDataSource())) { return aClass.cast(jdbcSchema.getDataSource()); } else if (aClass.isInstance(jdbcSchema.dialect)) { return aClass.cast(jdbcSchema.dialect); } else { return super.unwrap(aClass); } } public RelDataType getRowType(RelDataTypeFactory typeFactory) { if (protoRowType == null) { try { protoRowType = jdbcSchema.getRelDataType( jdbcCatalogName, jdbcSchemaName, jdbcTableName); } catch (SQLException e) { throw new RuntimeException( "Exception while reading definition of table '" + jdbcTableName + "'", e); } } return protoRowType.apply(typeFactory); } private List> fieldClasses( final JavaTypeFactory typeFactory) { final RelDataType rowType = protoRowType.apply(typeFactory); return Lists.transform(rowType.getFieldList(), f -> { final RelDataType type = f.getType(); final Class clazz = (Class) typeFactory.getJavaClass(type); final ColumnMetaData.Rep rep = Util.first(ColumnMetaData.Rep.of(clazz), ColumnMetaData.Rep.OBJECT); return Pair.of(rep, type.getSqlTypeName().getJdbcOrdinal()); }); } SqlString generateSql() { final SqlNodeList selectList = SqlNodeList.SINGLETON_STAR; SqlSelect node = new SqlSelect(SqlParserPos.ZERO, SqlNodeList.EMPTY, selectList, tableName(), null, null, null, null, null, null, null, null); final SqlWriterConfig config = SqlPrettyWriter.config() .withAlwaysUseParentheses(true) .withDialect(jdbcSchema.dialect); final SqlPrettyWriter writer = new SqlPrettyWriter(config); node.unparse(writer, 0, 0); return writer.toSqlString(); } /** Returns the table name, qualified with catalog and schema name if * applicable, as a parse tree node ({@link SqlIdentifier}). */ public SqlIdentifier tableName() { final List names = new ArrayList<>(3); if (jdbcSchema.catalog != null) { names.add(jdbcSchema.catalog); } if (jdbcSchema.schema != null) { names.add(jdbcSchema.schema); } names.add(jdbcTableName); return new SqlIdentifier(names, SqlParserPos.ZERO); } public RelNode toRel(RelOptTable.ToRelContext context, RelOptTable relOptTable) { return new JdbcTableScan(context.getCluster(), relOptTable, this, jdbcSchema.convention); } public Queryable asQueryable(QueryProvider queryProvider, SchemaPlus schema, String tableName) { return new JdbcTableQueryable<>(queryProvider, schema, tableName); } public Enumerable scan(DataContext root) { final JavaTypeFactory typeFactory = root.getTypeFactory(); final SqlString sql = generateSql(); return ResultSetEnumerable.of(jdbcSchema.getDataSource(), sql.getSql(), JdbcUtils.ObjectArrayRowBuilder.factory(fieldClasses(typeFactory))); } @Override public Collection getModifiableCollection() { return null; } @Override public TableModify toModificationRel(RelOptCluster cluster, RelOptTable table, CatalogReader catalogReader, RelNode input, Operation operation, List updateColumnList, List sourceExpressionList, boolean flattened) { jdbcSchema.convention.register(cluster.getPlanner()); return new LogicalTableModify(cluster, cluster.traitSetOf(Convention.NONE), table, catalogReader, input, operation, updateColumnList, sourceExpressionList, flattened); } /** Enumerable that returns the contents of a {@link JdbcTable} by connecting * to the JDBC data source. * * @param element type */ private class JdbcTableQueryable extends AbstractTableQueryable { JdbcTableQueryable(QueryProvider queryProvider, SchemaPlus schema, String tableName) { super(queryProvider, schema, JdbcTable.this, tableName); } @Override public String toString() { return "JdbcTableQueryable {table: " + tableName + "}"; } public Enumerator enumerator() { final JavaTypeFactory typeFactory = ((CalciteConnection) queryProvider).getTypeFactory(); final SqlString sql = generateSql(); //noinspection unchecked final Enumerable enumerable = (Enumerable) ResultSetEnumerable.of( jdbcSchema.getDataSource(), sql.getSql(), JdbcUtils.ObjectArrayRowBuilder.factory(fieldClasses(typeFactory))); return enumerable.enumerator(); } } }




© 2015 - 2024 Weber Informatics LLC | Privacy Policy