Search in sources :

Example 1 with MySQLRowDesc

use of io.vertx.mysqlclient.impl.MySQLRowDesc in project vertx-sql-client by eclipse-vertx.

the class QueryCommandBaseCodec method handleResultsetColumnDefinitionsDecodingCompleted.

protected void handleResultsetColumnDefinitionsDecodingCompleted() {
    commandHandlerState = CommandHandlerState.HANDLING_ROW_DATA_OR_END_PACKET;
    // use the column definitions if provided by execute or fetch response instead of prepare response
    MySQLRowDesc mySQLRowDesc = new MySQLRowDesc(columnDefinitions, format);
    decoder = new RowResultDecoder<>(cmd.collector(), mySQLRowDesc);
}
Also used : MySQLRowDesc(io.vertx.mysqlclient.impl.MySQLRowDesc)

Example 2 with MySQLRowDesc

use of io.vertx.mysqlclient.impl.MySQLRowDesc in project Mycat2 by MyCATApache.

the class QueryCommandBaseCodec method handleResultsetColumnDefinitionsDecodingCompleted.

protected void handleResultsetColumnDefinitionsDecodingCompleted() {
    commandHandlerState = CommandHandlerState.HANDLING_ROW_DATA_OR_END_PACKET;
    Collector<Row, ?, T> collector = cmd.collector();
    MySQLRowDesc mySQLRowDesc = new MySQLRowDesc(columnDefinitions, format);
    if (collector instanceof MysqlCollector) {
        ((MysqlCollector) collector).onColumnDefinitions(mySQLRowDesc);
    }
    decoder = new RowResultDecoder<>(collector, /*cmd.isSingleton()*/
    mySQLRowDesc);
}
Also used : MySQLRowDesc(io.vertx.mysqlclient.impl.MySQLRowDesc) Row(io.vertx.sqlclient.Row)

Example 3 with MySQLRowDesc

use of io.vertx.mysqlclient.impl.MySQLRowDesc in project Mycat2 by MyCATApache.

the class RowSetJdbcPreparedJdbcQuery method extracted.

public static <R> void extracted(Promise<SqlResult<R>> promise, Statement statement, ResultSet resultSet, Collector<Row, ?, R> collector) throws SQLException {
    try {
        if (resultSet == null) {
            Object o = collector.supplier().get();
            Function<Object, Object> finisher = (Function) collector.finisher();
            promise.complete(new MySqlResult<>(0, 0, 0, (R) finisher.apply(o), Collections.emptyList()));
            return;
        }
        JdbcRowMetaData metaData = new JdbcRowMetaData(resultSet.getMetaData());
        int columnCount = metaData.getColumnCount();
        List<ColumnDescriptor> columnDescriptors = new ArrayList<>();
        for (int i = 0; i < columnCount; i++) {
            int index = i;
            columnDescriptors.add(new ColumnDescriptor() {

                @Override
                public String name() {
                    return metaData.getColumnName(index);
                }

                @Override
                public boolean isArray() {
                    return false;
                }

                @Override
                public String typeName() {
                    return null;
                }

                @Override
                public JDBCType jdbcType() {
                    return JDBCType.valueOf(metaData.getColumnType(index));
                }
            });
        }
        RowDesc rowDesc = new RowDesc(metaData.getColumnList(), columnDescriptors);
        ColumnDefPacket[] columnDefPackets = new ColumnDefPacket[columnCount];
        for (int i = 0; i < columnCount; i++) {
            columnDefPackets[i] = new ColumnDefPacketImpl(metaData, i);
        }
        if (collector instanceof StreamMysqlCollector) {
            MySQLRowDesc mySQLRowDesc = new MySQLRowDesc(Arrays.asList(columnDefPackets).stream().map(packet -> {
                String catalog = new String(packet.getColumnCatalog());
                String schema = new String(packet.getColumnSchema());
                String table = new String(packet.getColumnTable());
                String orgTable = new String(packet.getColumnOrgTable());
                String name = new String(packet.getColumnName());
                String orgName = new String(packet.getColumnOrgName());
                int characterSet = packet.getColumnCharsetSet();
                long columnLength = packet.getColumnLength();
                DataType type = DataType.valueOf(packet.getColumnType() == 15 ? 253 : packet.getColumnType());
                int flags = packet.getColumnFlags();
                byte decimals = packet.getColumnDecimals();
                ColumnDefinition columnDefinition = new ColumnDefinition(catalog, schema, table, orgTable, name, orgName, characterSet, columnLength, type, flags, decimals);
                return columnDefinition;
            }).toArray(n -> new ColumnDefinition[n]), DataFormat.TEXT);
            ((StreamMysqlCollector) collector).onColumnDefinitions(mySQLRowDesc);
        }
        {
            Object supplier = collector.supplier().get();
            BiConsumer<Object, Row> accumulator = (BiConsumer) collector.accumulator();
            Function<Object, Object> finisher = (Function) collector.finisher();
            int count = 0;
            while (resultSet.next()) {
                JDBCRow jdbcRow = new MycatRow(rowDesc);
                for (int i = 0; i < columnCount; i++) {
                    jdbcRow.addValue(resultSet.getObject(i + 1));
                }
                count++;
                accumulator.accept(supplier, jdbcRow);
            }
            finisher.apply(supplier);
            resultSet.close();
            statement.close();
            promise.complete(new MySqlResult<>(count, 0, 0, (R) supplier, columnDescriptors));
        }
    } catch (Throwable throwable) {
        promise.tryFail(throwable);
    }
}
Also used : DataFormat(io.vertx.mysqlclient.impl.datatype.DataFormat) java.sql(java.sql) Arrays(java.util.Arrays) MetaClusterCurrent(io.mycat.MetaClusterCurrent) AbstractMySqlConnectionImpl.adaptType(io.mycat.vertxmycat.AbstractMySqlConnectionImpl.adaptType) LoggerFactory(org.slf4j.LoggerFactory) MySQLRowDesc(io.vertx.mysqlclient.impl.MySQLRowDesc) Function(java.util.function.Function) IOExecutor(io.mycat.IOExecutor) ArrayList(java.util.ArrayList) BigDecimal(java.math.BigDecimal) JDBCRow(io.vertx.jdbcclient.impl.JDBCRow) StreamMysqlCollector(io.vertx.mysqlclient.impl.codec.StreamMysqlCollector) BiConsumer(java.util.function.BiConsumer) AbstractMySqlConnectionImpl.toObjects(io.mycat.vertxmycat.AbstractMySqlConnectionImpl.toObjects) DataType(io.vertx.mysqlclient.impl.datatype.DataType) ColumnDefinition(io.vertx.mysqlclient.impl.protocol.ColumnDefinition) Collector(java.util.stream.Collector) io.vertx.sqlclient(io.vertx.sqlclient) JdbcRowMetaData(io.mycat.beans.mycat.JdbcRowMetaData) Logger(org.slf4j.Logger) ColumnDefPacket(io.mycat.beans.mysql.packet.ColumnDefPacket) Promise(io.vertx.core.Promise) PreparedStatement(java.sql.PreparedStatement) Future(io.vertx.core.Future) List(java.util.List) ColumnDescriptor(io.vertx.sqlclient.desc.ColumnDescriptor) ColumnDefPacketImpl(io.mycat.beans.mysql.packet.ColumnDefPacketImpl) MycatPreparedStatementUtil(io.mycat.calcite.executor.MycatPreparedStatementUtil) VertxRowSetImpl(io.vertx.mysqlclient.impl.codec.VertxRowSetImpl) RowDesc(io.vertx.sqlclient.impl.RowDesc) Handler(io.vertx.core.Handler) Collections(java.util.Collections) JDBCRow(io.vertx.jdbcclient.impl.JDBCRow) ArrayList(java.util.ArrayList) Function(java.util.function.Function) ColumnDefPacket(io.mycat.beans.mysql.packet.ColumnDefPacket) DataType(io.vertx.mysqlclient.impl.datatype.DataType) JdbcRowMetaData(io.mycat.beans.mycat.JdbcRowMetaData) MySQLRowDesc(io.vertx.mysqlclient.impl.MySQLRowDesc) StreamMysqlCollector(io.vertx.mysqlclient.impl.codec.StreamMysqlCollector) ColumnDescriptor(io.vertx.sqlclient.desc.ColumnDescriptor) ColumnDefPacketImpl(io.mycat.beans.mysql.packet.ColumnDefPacketImpl) ColumnDefinition(io.vertx.mysqlclient.impl.protocol.ColumnDefinition) MySQLRowDesc(io.vertx.mysqlclient.impl.MySQLRowDesc) RowDesc(io.vertx.sqlclient.impl.RowDesc) BiConsumer(java.util.function.BiConsumer)

Example 4 with MySQLRowDesc

use of io.vertx.mysqlclient.impl.MySQLRowDesc in project Mycat2 by MyCATApache.

the class RowSetQuery method execute.

@Override
public Future<RowSet<Row>> execute() {
    VertxRowSetImpl vertxRowSet = new VertxRowSetImpl();
    StreamMysqlCollector streamMysqlCollector = new StreamMysqlCollector() {

        @Override
        public void onColumnDefinitions(MySQLRowDesc columnDefinitions) {
            vertxRowSet.setColumnDescriptor(columnDefinitions.columnDescriptor());
        }

        @Override
        public void onRow(Row row) {
            vertxRowSet.list.add(row);
        }
    };
    return runTextQuery(sql, mySQLClientSession.mySQLClientSession, streamMysqlCollector).map(voidSqlResult -> {
        vertxRowSet.setAffectRow(voidSqlResult.rowCount());
        vertxRowSet.setLastInsertId(voidSqlResult.property(MySQLClient.LAST_INSERTED_ID));
        return vertxRowSet;
    });
}
Also used : MySQLRowDesc(io.vertx.mysqlclient.impl.MySQLRowDesc) StreamMysqlCollector(io.vertx.mysqlclient.impl.codec.StreamMysqlCollector) VertxRowSetImpl(io.vertx.mysqlclient.impl.codec.VertxRowSetImpl) Row(io.vertx.sqlclient.Row)

Example 5 with MySQLRowDesc

use of io.vertx.mysqlclient.impl.MySQLRowDesc in project Mycat2 by MyCATApache.

the class VertxMycatTextCollector method onColumnDefEof.

@Override
public void onColumnDefEof(MySQLPacket mySQLPacket, int startPos, int endPos) {
    rowResultDecoder = new MycatVertxRowResultDecoder(collector, new MySQLRowDesc(currentColumnDefList, DataFormat.TEXT));
    this.c = collector.supplier().get();
    this.accumulator = collector.accumulator();
    if (collector instanceof StreamMysqlCollector) {
        MySQLRowDesc mySQLRowDesc = new MySQLRowDesc(this.currentColumnDefList, DataFormat.TEXT);
        ((StreamMysqlCollector) collector).onColumnDefinitions(mySQLRowDesc);
    }
}
Also used : MySQLRowDesc(io.vertx.mysqlclient.impl.MySQLRowDesc) StreamMysqlCollector(io.vertx.mysqlclient.impl.codec.StreamMysqlCollector)

Aggregations

MySQLRowDesc (io.vertx.mysqlclient.impl.MySQLRowDesc)5 StreamMysqlCollector (io.vertx.mysqlclient.impl.codec.StreamMysqlCollector)3 VertxRowSetImpl (io.vertx.mysqlclient.impl.codec.VertxRowSetImpl)2 Row (io.vertx.sqlclient.Row)2 IOExecutor (io.mycat.IOExecutor)1 MetaClusterCurrent (io.mycat.MetaClusterCurrent)1 JdbcRowMetaData (io.mycat.beans.mycat.JdbcRowMetaData)1 ColumnDefPacket (io.mycat.beans.mysql.packet.ColumnDefPacket)1 ColumnDefPacketImpl (io.mycat.beans.mysql.packet.ColumnDefPacketImpl)1 MycatPreparedStatementUtil (io.mycat.calcite.executor.MycatPreparedStatementUtil)1 AbstractMySqlConnectionImpl.adaptType (io.mycat.vertxmycat.AbstractMySqlConnectionImpl.adaptType)1 AbstractMySqlConnectionImpl.toObjects (io.mycat.vertxmycat.AbstractMySqlConnectionImpl.toObjects)1 Future (io.vertx.core.Future)1 Handler (io.vertx.core.Handler)1 Promise (io.vertx.core.Promise)1 JDBCRow (io.vertx.jdbcclient.impl.JDBCRow)1 DataFormat (io.vertx.mysqlclient.impl.datatype.DataFormat)1 DataType (io.vertx.mysqlclient.impl.datatype.DataType)1 ColumnDefinition (io.vertx.mysqlclient.impl.protocol.ColumnDefinition)1 io.vertx.sqlclient (io.vertx.sqlclient)1