You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by il...@apache.org on 2021/04/08 16:47:09 UTC

[ignite] branch master updated: IGNITE-13381 Local cluster group should have correct node ID after reconnect - Fixes #8985.

This is an automated email from the ASF dual-hosted git repository.

ilyak pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/ignite.git


The following commit(s) were added to refs/heads/master by this push:
     new d7782bd  IGNITE-13381 Local cluster group should have correct node ID after reconnect - Fixes #8985.
d7782bd is described below

commit d7782bd709be35cc37e2983fa9c9e5927dea4b73
Author: aalexandrov@gridgain.com <aa...@gridgain.com>
AuthorDate: Thu Apr 8 19:39:23 2021 +0300

    IGNITE-13381 Local cluster group should have correct node ID after reconnect - Fixes #8985.
    
    Signed-off-by: Ilya Kasnacheev <il...@gmail.com>
---
 .../ignite/internal/cluster/IgniteClusterImpl.java |   2 +-
 ...ientCheckClusterGroupLocalIdAfterReconnect.java | 142 +++++++++++++++++++++
 .../testsuites/IgniteClientReconnectTestSuite.java |   2 +
 3 files changed, 145 insertions(+), 1 deletion(-)

diff --git a/modules/core/src/main/java/org/apache/ignite/internal/cluster/IgniteClusterImpl.java b/modules/core/src/main/java/org/apache/ignite/internal/cluster/IgniteClusterImpl.java
index 6ee7da9..3b55295 100644
--- a/modules/core/src/main/java/org/apache/ignite/internal/cluster/IgniteClusterImpl.java
+++ b/modules/core/src/main/java/org/apache/ignite/internal/cluster/IgniteClusterImpl.java
@@ -158,7 +158,7 @@ public class IgniteClusterImpl extends ClusterGroupAdapter implements IgniteClus
         guard();
 
         try {
-            return new ClusterGroupAdapter(ctx, null, Collections.singleton(cfg.getNodeId()));
+            return new ClusterGroupAdapter(ctx, null, Collections.singleton(ctx.discovery().localNode().id()));
         }
         finally {
             unguard();
diff --git a/modules/core/src/test/java/org/apache/ignite/internal/IgniteClientCheckClusterGroupLocalIdAfterReconnect.java b/modules/core/src/test/java/org/apache/ignite/internal/IgniteClientCheckClusterGroupLocalIdAfterReconnect.java
new file mode 100644
index 0000000..61c7fe3
--- /dev/null
+++ b/modules/core/src/test/java/org/apache/ignite/internal/IgniteClientCheckClusterGroupLocalIdAfterReconnect.java
@@ -0,0 +1,142 @@
+/*
+ * 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 org.apache.ignite.internal;
+
+import java.io.Externalizable;
+import java.io.IOException;
+import java.io.ObjectInput;
+import java.io.ObjectOutput;
+import java.util.UUID;
+import java.util.concurrent.CountDownLatch;
+import java.util.concurrent.TimeUnit;
+import org.apache.ignite.Ignite;
+import org.apache.ignite.IgniteMessaging;
+import org.apache.ignite.cluster.ClusterGroup;
+import org.apache.ignite.configuration.IgniteConfiguration;
+import org.apache.ignite.events.DiscoveryEvent;
+import org.apache.ignite.events.EventType;
+import org.apache.ignite.lang.IgniteBiPredicate;
+import org.apache.ignite.lang.IgniteFuture;
+import org.apache.ignite.lang.IgnitePredicate;
+import org.apache.ignite.testframework.junits.common.GridCommonAbstractTest;
+import org.junit.After;
+import org.junit.Test;
+
+/**
+ * Tests that localId for cluster groups will be changed after reconnect.
+ */
+public class IgniteClientCheckClusterGroupLocalIdAfterReconnect extends GridCommonAbstractTest {
+    /** Latch timeout*/
+    private final int LATCH_TIMEOUT = 10_000;
+
+    /** Object for messaging*/
+    private static class External implements Externalizable {
+        /** */
+        private External() {}
+
+        /** {@inheritDoc} */
+        @Override public void writeExternal(ObjectOutput out) throws IOException {}
+
+        /** {@inheritDoc} */
+        @Override public void readExternal(ObjectInput in) throws IOException, ClassNotFoundException {}
+    }
+
+    /** {@inheritDoc} */
+    @Override protected IgniteConfiguration getConfiguration(String igniteInstanceName) throws Exception {
+        IgniteConfiguration cfg = super.getConfiguration(igniteInstanceName);
+
+        cfg.setFailureDetectionTimeout(5000);
+        cfg.setClientFailureDetectionTimeout(5000);
+
+        return cfg;
+    }
+
+    /** Stop all nodes after test */
+    @After
+    public void tearDown() {
+        stopAllGrids();
+    }
+
+    /**
+     * Test checks that local id in cluster group was change and client
+     * will be able to send the message to itself after reconnect.
+     */
+    @Test
+    public void testClusterGroupLocalIdAfterClientReconnect() throws Exception {
+        Ignite server = startGrid(0);
+
+        Ignite client = startClientGrid(1);
+
+        UUID clientId = client.cluster().node().id();
+
+        ClusterGroup cg1 = client.cluster().forLocal();
+
+        assertNotNull("Local client ID is different with local ClusterGroup node id. ", cg1.node(clientId));
+
+        // check sending messages is possible while connected
+        IgniteMessaging messaging = client.message(client.cluster().forLocal());
+
+        CountDownLatch topicSignal = new CountDownLatch(2);
+
+        messaging.localListen("topic", (IgniteBiPredicate<UUID, Object>) (uuid, n) -> {
+            topicSignal.countDown();
+
+            return true;
+        });
+
+        // countDown latch = 1
+        messaging.send("topic", new External());
+
+        CountDownLatch discSignal = new CountDownLatch(1);
+
+        client.events().localListen((IgnitePredicate<DiscoveryEvent>) evt -> {
+            discSignal.countDown();
+
+            return true;
+        }, EventType.EVT_CLIENT_NODE_DISCONNECTED);
+
+        server.close();
+
+        assertTrue("client did not disconnect", discSignal.await(LATCH_TIMEOUT, TimeUnit.SECONDS));
+
+        startGrid(0);
+
+        // wait for client reconnect
+        IgniteFuture future = client.cluster().clientReconnectFuture();
+
+        assertNotNull(future);
+
+        future.get(20_000);   // throws if times out
+
+        ClusterGroup cg2 = client.cluster().forLocal();
+
+        UUID newClientId = client.cluster().localNode().id();
+
+        assertNotNull("Local client ID wasn't changed for local ClusterGroup.", cg2.node(newClientId));
+
+        awaitPartitionMapExchange();
+
+        // check sending messages is possible after reconnecting
+        // countDown latch = 0
+        messaging = client.message(client.cluster().forLocal());
+
+        messaging.send("topic", new External());
+
+        assertTrue("Message wasn't received", topicSignal.await(LATCH_TIMEOUT, TimeUnit.SECONDS));
+    }
+}
diff --git a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteClientReconnectTestSuite.java b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteClientReconnectTestSuite.java
index 0682ed4..0e7b904 100644
--- a/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteClientReconnectTestSuite.java
+++ b/modules/core/src/test/java/org/apache/ignite/testsuites/IgniteClientReconnectTestSuite.java
@@ -17,6 +17,7 @@
 
 package org.apache.ignite.testsuites;
 
+import org.apache.ignite.internal.IgniteClientCheckClusterGroupLocalIdAfterReconnect;
 import org.apache.ignite.internal.IgniteClientConnectAfterCommunicationFailureTest;
 import org.apache.ignite.internal.IgniteClientReconnectApiExceptionTest;
 import org.apache.ignite.internal.IgniteClientReconnectAtomicsTest;
@@ -47,6 +48,7 @@ import org.junit.runners.Suite;
     IgniteClientReconnectDelayedSpiTest.class,
     IgniteClientReconnectBinaryContexTest.class,
     IgniteClientReconnectContinuousProcessorTest.class,
+    IgniteClientCheckClusterGroupLocalIdAfterReconnect.class,
     IgniteClientReconnectComputeTest.class,
     IgniteClientReconnectAtomicsTest.class,
     IgniteClientReconnectAtomicsWithLostPartitionsTest.class,