Search in sources :

Example 16 with IgniteProductVersion

use of org.apache.ignite.lang.IgniteProductVersion in project ignite by apache.

the class ClusterCachesInfo method isMergeConfigSupports.

/**
 * @return {@code true} if grid supports merge of config and {@code False} otherwise.
 */
public boolean isMergeConfigSupports(ClusterNode joiningNode) {
    DiscoCache discoCache = ctx.discovery().discoCache();
    if (discoCache == null)
        return true;
    if (joiningNode != null && joiningNode.version().compareToIgnoreTimestamp(V_MERGE_CONFIG_SINCE) < 0)
        return false;
    Collection<ClusterNode> nodes = discoCache.allNodes();
    for (ClusterNode node : nodes) {
        IgniteProductVersion version = node.version();
        if (version.compareToIgnoreTimestamp(V_MERGE_CONFIG_SINCE) < 0)
            return false;
    }
    return true;
}
Also used : ClusterNode(org.apache.ignite.cluster.ClusterNode) DiscoCache(org.apache.ignite.internal.managers.discovery.DiscoCache) IgniteProductVersion(org.apache.ignite.lang.IgniteProductVersion)

Example 17 with IgniteProductVersion

use of org.apache.ignite.lang.IgniteProductVersion in project ignite by apache.

the class JdbcThinTcpIo method handshake.

/**
 * Used for versions: 2.1.5 and 2.3.0. The protocol version is changed but handshake format isn't changed.
 *
 * @param ver JDBC client version.
 * @throws IOException On IO error.
 * @throws SQLException On connection reject.
 */
private HandshakeResult handshake(ClientListenerProtocolVersion ver) throws IOException, SQLException {
    BinaryContext ctx = new BinaryContext(BinaryCachingMetadataHandler.create(), new IgniteConfiguration(), null);
    BinaryMarshaller marsh = new BinaryMarshaller();
    marsh.setContext(new MarshallerContextImpl(null, null));
    ctx.configure(marsh);
    BinaryWriterExImpl writer = new BinaryWriterExImpl(ctx, new BinaryHeapOutputStream(HANDSHAKE_MSG_SIZE), null, null);
    writer.writeByte((byte) ClientListenerRequest.HANDSHAKE);
    writer.writeShort(ver.major());
    writer.writeShort(ver.minor());
    writer.writeShort(ver.maintenance());
    writer.writeByte(ClientListenerNioListener.JDBC_CLIENT);
    writer.writeBoolean(connProps.isDistributedJoins());
    writer.writeBoolean(connProps.isEnforceJoinOrder());
    writer.writeBoolean(connProps.isCollocated());
    writer.writeBoolean(connProps.isReplicatedOnly());
    writer.writeBoolean(connProps.isAutoCloseServerCursor());
    writer.writeBoolean(connProps.isLazy());
    writer.writeBoolean(connProps.isSkipReducerOnUpdate());
    if (ver.compareTo(VER_2_7_0) >= 0)
        writer.writeString(connProps.nestedTxMode());
    if (ver.compareTo(VER_2_8_0) >= 0) {
        writer.writeByte(nullableBooleanToByte(connProps.isDataPageScanEnabled()));
        JdbcUtils.writeNullableInteger(writer, connProps.getUpdateBatchSize());
    }
    if (ver.compareTo(VER_2_9_0) >= 0) {
        String userAttrs = connProps.getUserAttributesFactory();
        if (F.isEmpty(userAttrs))
            writer.writeMap(null);
        else {
            try {
                Class<Factory<Map<String, String>>> cls = (Class<Factory<Map<String, String>>>) JdbcThinSSLUtil.class.getClassLoader().loadClass(userAttrs);
                Map<String, String> attrs = cls.newInstance().create();
                writer.writeMap(attrs);
            } catch (ClassNotFoundException | IllegalAccessException | InstantiationException e) {
                throw new SQLException("Could not found user attributes factory class: " + userAttrs, SqlStateCode.CLIENT_CONNECTION_FAILED, e);
            }
        }
        writer.writeByteArray(ThinProtocolFeature.featuresAsBytes(enabledFeatures()));
    }
    if (!F.isEmpty(connProps.getUsername())) {
        assert ver.compareTo(VER_2_5_0) >= 0 : "Authentication is supported since 2.5";
        writer.writeString(connProps.getUsername());
        writer.writeString(connProps.getPassword());
    }
    send(writer.array());
    BinaryReaderExImpl reader = new BinaryReaderExImpl(ctx, new BinaryHeapInputStream(read()), null, null, false);
    boolean accepted = reader.readBoolean();
    if (accepted) {
        HandshakeResult handshakeRes = new HandshakeResult();
        if (reader.available() > 0) {
            byte maj = reader.readByte();
            byte min = reader.readByte();
            byte maintenance = reader.readByte();
            String stage = reader.readString();
            long ts = reader.readLong();
            byte[] hash = reader.readByteArray();
            if (ver.compareTo(VER_2_8_0) >= 0)
                handshakeRes.nodeId(reader.readUuid());
            handshakeRes.igniteVersion(new IgniteProductVersion(maj, min, maintenance, stage, ts, hash));
            if (ver.compareTo(VER_2_9_0) >= 0) {
                byte[] srvFeatures = reader.readByteArray();
                EnumSet<JdbcThinFeature> features = JdbcThinFeature.enumSet(srvFeatures);
                handshakeRes.features(features);
            }
        } else {
            handshakeRes.igniteVersion(new IgniteProductVersion((byte) 2, (byte) 0, (byte) 0, "Unknown", 0L, null));
        }
        handshakeRes.serverProtocolVersion(ver);
        return handshakeRes;
    } else {
        short maj = reader.readShort();
        short min = reader.readShort();
        short maintenance = reader.readShort();
        String err = reader.readString();
        ClientListenerProtocolVersion srvProtoVer0 = ClientListenerProtocolVersion.create(maj, min, maintenance);
        if (srvProtoVer0.compareTo(VER_2_5_0) < 0 && !F.isEmpty(connProps.getUsername())) {
            throw new SQLException("Authentication doesn't support by remote server[driverProtocolVer=" + CURRENT_VER + ", remoteNodeProtocolVer=" + srvProtoVer0 + ", err=" + err + ", url=" + connProps.getUrl() + " address=" + sockAddr + ']', SqlStateCode.CONNECTION_REJECTED);
        }
        if (VER_2_8_0.equals(srvProtoVer0) || VER_2_7_0.equals(srvProtoVer0) || VER_2_5_0.equals(srvProtoVer0) || VER_2_4_0.equals(srvProtoVer0) || VER_2_3_0.equals(srvProtoVer0) || VER_2_1_5.equals(srvProtoVer0))
            return handshake(srvProtoVer0);
        else if (VER_2_1_0.equals(srvProtoVer0))
            return handshake_2_1_0();
        else {
            throw new SQLException("Handshake failed [driverProtocolVer=" + CURRENT_VER + ", remoteNodeProtocolVer=" + srvProtoVer0 + ", err=" + err + ']', SqlStateCode.CONNECTION_REJECTED);
        }
    }
}
Also used : BinaryReaderExImpl(org.apache.ignite.internal.binary.BinaryReaderExImpl) BinaryMarshaller(org.apache.ignite.internal.binary.BinaryMarshaller) SQLException(java.sql.SQLException) Factory(javax.cache.configuration.Factory) IgniteProductVersion(org.apache.ignite.lang.IgniteProductVersion) BinaryHeapInputStream(org.apache.ignite.internal.binary.streams.BinaryHeapInputStream) BinaryContext(org.apache.ignite.internal.binary.BinaryContext) MarshallerContextImpl(org.apache.ignite.internal.MarshallerContextImpl) BinaryHeapOutputStream(org.apache.ignite.internal.binary.streams.BinaryHeapOutputStream) IgniteConfiguration(org.apache.ignite.configuration.IgniteConfiguration) ClientListenerProtocolVersion(org.apache.ignite.internal.processors.odbc.ClientListenerProtocolVersion) BinaryWriterExImpl(org.apache.ignite.internal.binary.BinaryWriterExImpl) JdbcThinFeature(org.apache.ignite.internal.processors.odbc.jdbc.JdbcThinFeature) Map(java.util.Map)

Example 18 with IgniteProductVersion

use of org.apache.ignite.lang.IgniteProductVersion in project ignite by apache.

the class JdbcThinTcpIo method handshake_2_1_0.

/**
 * Compatibility handshake for server version 2.1.0
 *
 * @throws IOException On IO error.
 * @throws SQLException On connection reject.
 */
private HandshakeResult handshake_2_1_0() throws IOException, SQLException {
    BinaryWriterExImpl writer = new BinaryWriterExImpl(null, new BinaryHeapOutputStream(HANDSHAKE_MSG_SIZE), null, null);
    writer.writeByte((byte) ClientListenerRequest.HANDSHAKE);
    writer.writeShort(VER_2_1_0.major());
    writer.writeShort(VER_2_1_0.minor());
    writer.writeShort(VER_2_1_0.maintenance());
    writer.writeByte(ClientListenerNioListener.JDBC_CLIENT);
    writer.writeBoolean(connProps.isDistributedJoins());
    writer.writeBoolean(connProps.isEnforceJoinOrder());
    writer.writeBoolean(connProps.isCollocated());
    writer.writeBoolean(connProps.isReplicatedOnly());
    writer.writeBoolean(connProps.isAutoCloseServerCursor());
    send(writer.array());
    BinaryReaderExImpl reader = new BinaryReaderExImpl(null, new BinaryHeapInputStream(read()), null, null, false);
    boolean accepted = reader.readBoolean();
    if (accepted) {
        HandshakeResult handshakeRes = new HandshakeResult();
        handshakeRes.igniteVersion(new IgniteProductVersion((byte) 2, (byte) 1, (byte) 0, "Unknown", 0L, null));
        handshakeRes.serverProtocolVersion(VER_2_1_0);
        return handshakeRes;
    } else {
        short maj = reader.readShort();
        short min = reader.readShort();
        short maintenance = reader.readShort();
        String err = reader.readString();
        ClientListenerProtocolVersion ver = ClientListenerProtocolVersion.create(maj, min, maintenance);
        throw new SQLException("Handshake failed [driverProtocolVer=" + CURRENT_VER + ", remoteNodeProtocolVer=" + ver + ", err=" + err + ']', SqlStateCode.CONNECTION_REJECTED);
    }
}
Also used : BinaryReaderExImpl(org.apache.ignite.internal.binary.BinaryReaderExImpl) BinaryHeapOutputStream(org.apache.ignite.internal.binary.streams.BinaryHeapOutputStream) SQLException(java.sql.SQLException) ClientListenerProtocolVersion(org.apache.ignite.internal.processors.odbc.ClientListenerProtocolVersion) BinaryHeapInputStream(org.apache.ignite.internal.binary.streams.BinaryHeapInputStream) IgniteProductVersion(org.apache.ignite.lang.IgniteProductVersion) BinaryWriterExImpl(org.apache.ignite.internal.binary.BinaryWriterExImpl)

Aggregations

IgniteProductVersion (org.apache.ignite.lang.IgniteProductVersion)18 Map (java.util.Map)6 UUID (java.util.UUID)5 IgniteConfiguration (org.apache.ignite.configuration.IgniteConfiguration)4 ArrayList (java.util.ArrayList)3 HashMap (java.util.HashMap)3 ClusterNode (org.apache.ignite.cluster.ClusterNode)3 GridCommonAbstractTest (org.apache.ignite.testframework.junits.common.GridCommonAbstractTest)3 Test (org.junit.Test)3 SQLException (java.sql.SQLException)2 IgniteCheckedException (org.apache.ignite.IgniteCheckedException)2 BinaryReaderExImpl (org.apache.ignite.internal.binary.BinaryReaderExImpl)2 BinaryWriterExImpl (org.apache.ignite.internal.binary.BinaryWriterExImpl)2 BinaryHeapInputStream (org.apache.ignite.internal.binary.streams.BinaryHeapInputStream)2 BinaryHeapOutputStream (org.apache.ignite.internal.binary.streams.BinaryHeapOutputStream)2 GroupKeyEncrypted (org.apache.ignite.internal.managers.encryption.GroupKeyEncrypted)2 CheckpointRecord (org.apache.ignite.internal.pagemem.wal.record.CheckpointRecord)2 DataRecord (org.apache.ignite.internal.pagemem.wal.record.DataRecord)2 IndexRenameRootPageRecord (org.apache.ignite.internal.pagemem.wal.record.IndexRenameRootPageRecord)2 MasterKeyChangeRecordV2 (org.apache.ignite.internal.pagemem.wal.record.MasterKeyChangeRecordV2)2