Search in sources :

Example 6 with NETWORK

use of org.apache.cassandra.distributed.api.Feature.NETWORK in project cassandra by apache.

the class HintedHandoffAddRemoveNodesTest method shouldStreamHintsDuringDecommission.

/**
 * Replaces Python dtest {@code hintedhandoff_test.py:TestHintedHandoff.test_hintedhandoff_decom()}.
 * Ignored for now as there is some in-jvm bug which needs to be fixed, otherwise the test is flaky
 * For more information see CASSANDRA-16679
 */
@Ignore
@Test
public void shouldStreamHintsDuringDecommission() throws Exception {
    try (Cluster cluster = builder().withNodes(4).withConfig(config -> config.with(NETWORK, GOSSIP, NATIVE_PROTOCOL)).start()) {
        cluster.schemaChange(withKeyspace("CREATE KEYSPACE %s WITH replication = {'class': 'SimpleStrategy', 'replication_factor': 2}"));
        cluster.schemaChange(withKeyspace("CREATE TABLE %s.decom_hint_test (key int PRIMARY KEY, value int)"));
        cluster.get(4).shutdown().get();
        // Write data using the second node as the coordinator...
        populate(cluster, "decom_hint_test", 2, 0, 128, ConsistencyLevel.ONE);
        Long totalHints = countTotalHints(cluster);
        // ...and verify that we've accumulated hints intended for node 4, which is down.
        assertThat(totalHints).isGreaterThan(0);
        // Decomision node 1...
        assertEquals(4, endpointsKnownTo(cluster, 2));
        cluster.run(decommission(), 1);
        await().pollDelay(1, SECONDS).until(() -> endpointsKnownTo(cluster, 2) == 3);
        // ...and verify that all data still exists on either node 2 or 3.
        verify(cluster, "decom_hint_test", 2, 0, 128, ConsistencyLevel.ONE);
        // Start node 4 back up and verify that all hints were delivered.
        cluster.get(4).startup();
        await().atMost(30, SECONDS).pollDelay(3, SECONDS).until(() -> count(cluster, "decom_hint_test", 4).equals(totalHints));
        // Now decommission both nodes 2 and 3...
        cluster.run(GossipHelper.decommission(true), 2);
        cluster.run(GossipHelper.decommission(true), 3);
        await().pollDelay(1, SECONDS).until(() -> endpointsKnownTo(cluster, 4) == 1);
        // ...and verify that even if we drop below the replication factor of 2, all data has been preserved.
        verify(cluster, "decom_hint_test", 4, 0, 128, ConsistencyLevel.ONE);
    }
}
Also used : StorageMetrics(org.apache.cassandra.metrics.StorageMetrics) StorageService(org.apache.cassandra.service.StorageService) Test(org.junit.Test) ConsistencyLevel(org.apache.cassandra.distributed.api.ConsistencyLevel) GossipHelper(org.apache.cassandra.distributed.action.GossipHelper) NATIVE_PROTOCOL(org.apache.cassandra.distributed.api.Feature.NATIVE_PROTOCOL) TimeUnit(java.util.concurrent.TimeUnit) AssertUtils.assertRows(org.apache.cassandra.distributed.shared.AssertUtils.assertRows) TokenSupplier(org.apache.cassandra.distributed.api.TokenSupplier) Ignore(org.junit.Ignore) Cluster(org.apache.cassandra.distributed.Cluster) NetworkTopology(org.apache.cassandra.distributed.shared.NetworkTopology) AssertionsForClassTypes.assertThat(org.assertj.core.api.AssertionsForClassTypes.assertThat) Awaitility(org.awaitility.Awaitility) NETWORK(org.apache.cassandra.distributed.api.Feature.NETWORK) AssertUtils.row(org.apache.cassandra.distributed.shared.AssertUtils.row) Assert.assertEquals(org.junit.Assert.assertEquals) GossipHelper.decommission(org.apache.cassandra.distributed.action.GossipHelper.decommission) GOSSIP(org.apache.cassandra.distributed.api.Feature.GOSSIP) Cluster(org.apache.cassandra.distributed.Cluster) Ignore(org.junit.Ignore) Test(org.junit.Test)

Example 7 with NETWORK

use of org.apache.cassandra.distributed.api.Feature.NETWORK in project cassandra by apache.

the class NodeNotInRingTest method nodeNotInRingTest.

@Test
public void nodeNotInRingTest() throws Throwable {
    try (Cluster cluster = builder().withNodes(3).withConfig(config -> config.with(NETWORK, GOSSIP)).start()) {
        cluster.schemaChange("CREATE KEYSPACE IF NOT EXISTS " + KEYSPACE + " WITH replication = {'class': 'SimpleStrategy', 'replication_factor': 2};");
        cluster.schemaChange("CREATE TABLE IF NOT EXISTS " + KEYSPACE + ".tbl (pk int, ck int, v int, PRIMARY KEY (pk, ck))");
        cluster.filters().verbs(Verb.GOSSIP_DIGEST_ACK.id, Verb.GOSSIP_DIGEST_SYN.id).from(3).outbound().drop().on();
        cluster.run(GossipHelper.removeFromRing(cluster.get(3)), 1, 2);
        cluster.run(inst -> inst.runsOnInstance(() -> {
            Assert.assertEquals("There should be 2 remaining nodes in ring", 2, StorageService.instance.effectiveOwnershipWithPort(KEYSPACE).size());
        }), 1, 2);
        populate(cluster, 0, 50, 1, ConsistencyLevel.ALL);
        populate(cluster, 50, 100, 2, ConsistencyLevel.ALL);
        Map<Integer, Long> counts = BootstrapTest.count(cluster);
        Assert.assertEquals(0L, counts.get(3).longValue());
        Assert.assertEquals(100L, counts.get(2).longValue());
        Assert.assertEquals(100L, counts.get(1).longValue());
    }
}
Also used : Map(java.util.Map) TestBaseImpl(org.apache.cassandra.distributed.test.TestBaseImpl) ICluster(org.apache.cassandra.distributed.api.ICluster) StorageService(org.apache.cassandra.service.StorageService) Test(org.junit.Test) Cluster(org.apache.cassandra.distributed.Cluster) ConsistencyLevel(org.apache.cassandra.distributed.api.ConsistencyLevel) Verb(org.apache.cassandra.net.Verb) Assert(org.junit.Assert) GossipHelper(org.apache.cassandra.distributed.action.GossipHelper) NETWORK(org.apache.cassandra.distributed.api.Feature.NETWORK) GOSSIP(org.apache.cassandra.distributed.api.Feature.GOSSIP) ICluster(org.apache.cassandra.distributed.api.ICluster) Cluster(org.apache.cassandra.distributed.Cluster) Test(org.junit.Test)

Example 8 with NETWORK

use of org.apache.cassandra.distributed.api.Feature.NETWORK in project cassandra by apache.

the class AutoBootstrapTest method autoBootstrapTest.

// Originally part of BootstrapTest. Broken out into separate test as the in-JVM dtests fail
// if too many instances are created in the same JVM. Bug in the JVM is suspected.
@Test
public void autoBootstrapTest() throws Throwable {
    int originalNodeCount = 2;
    int expandedNodeCount = originalNodeCount + 1;
    try (Cluster cluster = builder().withNodes(originalNodeCount).withTokenSupplier(TokenSupplier.evenlyDistributedTokens(expandedNodeCount)).withNodeIdTopology(NetworkTopology.singleDcNetworkTopology(expandedNodeCount, "dc0", "rack0")).withConfig(config -> config.with(NETWORK, GOSSIP)).start()) {
        populate(cluster, 0, 100);
        bootstrapAndJoinNode(cluster);
        for (Map.Entry<Integer, Long> e : count(cluster).entrySet()) Assert.assertEquals("Node " + e.getKey() + " has incorrect row state", e.getValue().longValue(), 100L);
    }
}
Also used : TokenSupplier(org.apache.cassandra.distributed.api.TokenSupplier) Map(java.util.Map) Test(org.junit.Test) Cluster(org.apache.cassandra.distributed.Cluster) Assert(org.junit.Assert) NetworkTopology(org.apache.cassandra.distributed.shared.NetworkTopology) NETWORK(org.apache.cassandra.distributed.api.Feature.NETWORK) GOSSIP(org.apache.cassandra.distributed.api.Feature.GOSSIP) Cluster(org.apache.cassandra.distributed.Cluster) Map(java.util.Map) Test(org.junit.Test)

Example 9 with NETWORK

use of org.apache.cassandra.distributed.api.Feature.NETWORK in project cassandra by apache.

the class CommunicationDuringDecommissionTest method internodeConnectionsDuringDecom.

@Test
public void internodeConnectionsDuringDecom() throws Throwable {
    try (Cluster cluster = builder().withNodes(4).withConfig(config -> config.with(NETWORK, GOSSIP, NATIVE_PROTOCOL)).start()) {
        BootstrapTest.populate(cluster, 0, 100);
        cluster.run(decommission(), 1);
        cluster.filters().allVerbs().from(1).messagesMatching((i, i1, iMessage) -> {
            throw new AssertionError("Decomissioned node should not send any messages");
        }).drop();
        Map<Integer, Long> connectionAttempts = new HashMap<>();
        long deadline = currentTimeMillis() + TimeUnit.SECONDS.toMillis(10);
        // Wait 10 seconds and check if there are any new connection attempts to the decomissioned node
        while (currentTimeMillis() <= deadline) {
            for (int i = 2; i <= cluster.size(); i++) {
                Object[][] res = cluster.get(i).executeInternal("SELECT active_connections, connection_attempts FROM system_views.internode_outbound WHERE address = '127.0.0.1' AND port = 7012");
                Assert.assertEquals(1, res.length);
                Assert.assertEquals(0L, ((Long) res[0][0]).longValue());
                long attempts = ((Long) res[0][1]).longValue();
                if (connectionAttempts.get(i) == null)
                    connectionAttempts.put(i, attempts);
                else
                    Assert.assertEquals(connectionAttempts.get(i), (Long) attempts);
            }
            LockSupport.parkNanos(TimeUnit.MILLISECONDS.toNanos(100));
        }
    }
}
Also used : Global.currentTimeMillis(org.apache.cassandra.utils.Clock.Global.currentTimeMillis) HashMap(java.util.HashMap) Test(org.junit.Test) NATIVE_PROTOCOL(org.apache.cassandra.distributed.api.Feature.NATIVE_PROTOCOL) TimeUnit(java.util.concurrent.TimeUnit) LockSupport(java.util.concurrent.locks.LockSupport) Map(java.util.Map) TestBaseImpl(org.apache.cassandra.distributed.test.TestBaseImpl) Cluster(org.apache.cassandra.distributed.Cluster) Assert(org.junit.Assert) NETWORK(org.apache.cassandra.distributed.api.Feature.NETWORK) GossipHelper.decommission(org.apache.cassandra.distributed.action.GossipHelper.decommission) GOSSIP(org.apache.cassandra.distributed.api.Feature.GOSSIP) HashMap(java.util.HashMap) Cluster(org.apache.cassandra.distributed.Cluster) Test(org.junit.Test)

Example 10 with NETWORK

use of org.apache.cassandra.distributed.api.Feature.NETWORK in project cassandra by apache.

the class StreamingTest method testStreaming.

private void testStreaming(int nodes, int replicationFactor, int rowCount, String compactionStrategy) throws Throwable {
    try (Cluster cluster = builder().withNodes(nodes).withDataDirCount(// this test expects there to only be a single sstable to stream (with ddirs = 3, we get 3 sstables)
    1).withConfig(config -> config.with(NETWORK)).start()) {
        cluster.schemaChange("CREATE KEYSPACE " + KEYSPACE + " WITH replication = {'class': 'SimpleStrategy', 'replication_factor': " + replicationFactor + "};");
        cluster.schemaChange(String.format("CREATE TABLE %s.cf (k text, c1 text, c2 text, PRIMARY KEY (k)) WITH compaction = {'class': '%s', 'enabled': 'true'}", KEYSPACE, compactionStrategy));
        for (int i = 0; i < rowCount; ++i) {
            for (int n = 1; n < nodes; ++n) cluster.get(n).executeInternal(String.format("INSERT INTO %s.cf (k, c1, c2) VALUES (?, 'value1', 'value2');", KEYSPACE), Integer.toString(i));
        }
        cluster.get(nodes).executeInternal("TRUNCATE system.available_ranges;");
        {
            Object[][] results = cluster.get(nodes).executeInternal(String.format("SELECT k, c1, c2 FROM %s.cf;", KEYSPACE));
            Assert.assertEquals(0, results.length);
        }
        // collect message and state
        registerSink(cluster, nodes);
        cluster.get(nodes).runOnInstance(() -> StorageService.instance.rebuild(null, KEYSPACE, null, null));
        {
            Object[][] results = cluster.get(nodes).executeInternal(String.format("SELECT k, c1, c2 FROM %s.cf;", KEYSPACE));
            Assert.assertEquals(1000, results.length);
            Arrays.sort(results, Comparator.comparingInt(a -> Integer.parseInt((String) a[0])));
            for (int i = 0; i < results.length; ++i) {
                Assert.assertEquals(Integer.toString(i), results[i][0]);
                Assert.assertEquals("value1", results[i][1]);
                Assert.assertEquals("value2", results[i][2]);
            }
        }
    }
}
Also used : RECEIVED(org.apache.cassandra.streaming.messages.StreamMessage.Type.RECEIVED) InetAddressAndPort(org.apache.cassandra.locator.InetAddressAndPort) Arrays(java.util.Arrays) PREPARE_SYNACK(org.apache.cassandra.streaming.messages.StreamMessage.Type.PREPARE_SYNACK) STREAM_INIT(org.apache.cassandra.streaming.messages.StreamMessage.Type.STREAM_INIT) STREAMING(org.apache.cassandra.streaming.StreamSession.State.STREAMING) InetAddress(java.net.InetAddress) PREPARE_ACK(org.apache.cassandra.streaming.messages.StreamMessage.Type.PREPARE_ACK) StreamSession(org.apache.cassandra.streaming.StreamSession) PREPARE_SYN(org.apache.cassandra.streaming.messages.StreamMessage.Type.PREPARE_SYN) Map(java.util.Map) StreamMessage(org.apache.cassandra.streaming.messages.StreamMessage) LinkedList(java.util.LinkedList) NETWORK(org.apache.cassandra.distributed.api.Feature.NETWORK) ConcurrentHashMap(java.util.concurrent.ConcurrentHashMap) StorageService(org.apache.cassandra.service.StorageService) Test(org.junit.Test) InetSocketAddress(java.net.InetSocketAddress) Collectors(java.util.stream.Collectors) Serializable(java.io.Serializable) List(java.util.List) IInvokableInstance(org.apache.cassandra.distributed.api.IInvokableInstance) PREPARING(org.apache.cassandra.streaming.StreamSession.State.PREPARING) STREAM(org.apache.cassandra.streaming.messages.StreamMessage.Type.STREAM) Cluster(org.apache.cassandra.distributed.Cluster) Queue(java.util.Queue) VisibleForTesting(com.google.common.annotations.VisibleForTesting) Comparator(java.util.Comparator) Assert(org.junit.Assert) WAIT_COMPLETE(org.apache.cassandra.streaming.StreamSession.State.WAIT_COMPLETE) Cluster(org.apache.cassandra.distributed.Cluster)

Aggregations

NETWORK (org.apache.cassandra.distributed.api.Feature.NETWORK)34 GOSSIP (org.apache.cassandra.distributed.api.Feature.GOSSIP)33 Test (org.junit.Test)32 Cluster (org.apache.cassandra.distributed.Cluster)27 Assert (org.junit.Assert)17 IInvokableInstance (org.apache.cassandra.distributed.api.IInvokableInstance)16 ConsistencyLevel (org.apache.cassandra.distributed.api.ConsistencyLevel)13 NATIVE_PROTOCOL (org.apache.cassandra.distributed.api.Feature.NATIVE_PROTOCOL)13 StorageService (org.apache.cassandra.service.StorageService)13 ByteBuddy (net.bytebuddy.ByteBuddy)12 ClassLoadingStrategy (net.bytebuddy.dynamic.loading.ClassLoadingStrategy)12 MethodDelegation (net.bytebuddy.implementation.MethodDelegation)12 ElementMatchers.named (net.bytebuddy.matcher.ElementMatchers.named)12 List (java.util.List)11 Map (java.util.Map)11 TimeUnit (java.util.concurrent.TimeUnit)11 ICluster (org.apache.cassandra.distributed.api.ICluster)10 NetworkTopology (org.apache.cassandra.distributed.shared.NetworkTopology)10 IOException (java.io.IOException)9 TokenSupplier (org.apache.cassandra.distributed.api.TokenSupplier)9