Search in sources :

Example 1 with Cluster

use of org.neo4j.causalclustering.discovery.Cluster in project neo4j by neo4j.

the class CoreToCoreCopySnapshotIT method shouldBeAbleToDownloadLargerFreshSnapshot.

@Test
public void shouldBeAbleToDownloadLargerFreshSnapshot() throws Exception {
    // given
    Cluster cluster = clusterRule.startCluster();
    CoreClusterMember source = cluster.coreTx((db, tx) -> {
        createData(db, 1000);
        tx.success();
    });
    // when
    CoreClusterMember follower = cluster.awaitCoreMemberWithRole(Role.FOLLOWER, 5, TimeUnit.SECONDS);
    // shutdown the follower, remove the store, restart
    follower.shutdown();
    deleteDirectoryRecursively(follower.storeDir(), follower.serverId());
    deleteDirectoryRecursively(follower.clusterStateDirectory(), follower.serverId());
    follower.start();
    // then
    assertEquals(DbRepresentation.of(source.database()), DbRepresentation.of(follower.database()));
}
Also used : CoreClusterMember(org.neo4j.causalclustering.discovery.CoreClusterMember) Cluster(org.neo4j.causalclustering.discovery.Cluster) Test(org.junit.Test)

Example 2 with Cluster

use of org.neo4j.causalclustering.discovery.Cluster in project neo4j by neo4j.

the class CoreToCoreCopySnapshotIT method shouldBeAbleToDownloadToNewInstanceAfterPruning.

@Test
public void shouldBeAbleToDownloadToNewInstanceAfterPruning() throws Exception {
    // given
    Map<String, String> params = stringMap(CausalClusteringSettings.state_machine_flush_window_size.name(), "1", CausalClusteringSettings.raft_log_pruning_strategy.name(), "3 entries", CausalClusteringSettings.raft_log_rotation_size.name(), "1K");
    Cluster cluster = clusterRule.withSharedCoreParams(params).startCluster();
    CoreClusterMember leader = cluster.coreTx((db, tx) -> {
        createData(db, 10000);
        tx.success();
    });
    // when
    for (CoreClusterMember coreDb : cluster.coreMembers()) {
        coreDb.coreState().prune();
    }
    // to force a change of leader
    cluster.removeCoreMember(leader);
    leader = cluster.awaitLeader();
    int newDbId = 3;
    cluster.addCoreMemberWithId(newDbId).start();
    CoreGraphDatabase newDb = cluster.getCoreMemberById(newDbId).database();
    // then
    assertEquals(DbRepresentation.of(leader.database()), DbRepresentation.of(newDb));
}
Also used : CoreClusterMember(org.neo4j.causalclustering.discovery.CoreClusterMember) Cluster(org.neo4j.causalclustering.discovery.Cluster) CoreGraphDatabase(org.neo4j.causalclustering.core.CoreGraphDatabase) Test(org.junit.Test)

Example 3 with Cluster

use of org.neo4j.causalclustering.discovery.Cluster in project neo4j by neo4j.

the class ReadReplicaHierarchicalCatchupIT method shouldCatchupThroughHierarchy.

@Test
public void shouldCatchupThroughHierarchy() throws Throwable {
    clusterRule = clusterRule.withInstanceReadReplicaParam(CausalClusteringSettings.server_groups, id -> serverGroups.get(id)).withInstanceCoreParam(CausalClusteringSettings.server_groups, id -> serverGroups.get(id));
    // given
    Cluster cluster = clusterRule.startCluster();
    int numberOfNodesToCreate = 100;
    cluster.coreTx((db, tx) -> {
        db.schema().constraintFor(label("Foo")).assertPropertyIsUnique("foobar").create();
        tx.success();
    });
    // 0, 1, 2 are core instances
    createLabelledNodesWithProperty(cluster, numberOfNodesToCreate, label("Foo"), () -> Pair.of("foobar", String.format("baz_bat%s", UUID.randomUUID())));
    // 3, 4 are other DCs
    ReadReplica east3 = cluster.addReadReplicaWithId(3);
    east3.start();
    ReadReplica west4 = cluster.addReadReplicaWithId(4);
    west4.start();
    checkDataHasReplicatedToReadReplicas(cluster, numberOfNodesToCreate);
    for (CoreClusterMember coreClusterMember : cluster.coreMembers()) {
        coreClusterMember.stopCatchupServer();
    }
    // 5, 6 are other DCs
    ReadReplica east5 = cluster.addReadReplicaWithId(5);
    east5.setUpstreamDatabaseSelectionStrategy("connect-within-data-center");
    east5.start();
    ReadReplica west6 = cluster.addReadReplicaWithId(6);
    west6.setUpstreamDatabaseSelectionStrategy("connect-within-data-center");
    west6.start();
    checkDataHasReplicatedToReadReplicas(cluster, numberOfNodesToCreate);
}
Also used : Iterables.count(org.neo4j.helpers.collection.Iterables.count) CausalClusteringSettings(org.neo4j.causalclustering.core.CausalClusteringSettings) Test(org.junit.Test) HashMap(java.util.HashMap) UUID(java.util.UUID) ClusterRule(org.neo4j.test.causalclustering.ClusterRule) Label.label(org.neo4j.graphdb.Label.label) Pair(org.neo4j.helpers.collection.Pair) DataCreator.createLabelledNodesWithProperty(org.neo4j.causalclustering.helpers.DataCreator.createLabelledNodesWithProperty) Cluster(org.neo4j.causalclustering.discovery.Cluster) Rule(org.junit.Rule) HazelcastDiscoveryServiceFactory(org.neo4j.causalclustering.discovery.HazelcastDiscoveryServiceFactory) Map(java.util.Map) Is.is(org.hamcrest.core.Is.is) CoreClusterMember(org.neo4j.causalclustering.discovery.CoreClusterMember) MatcherAssert.assertThat(org.hamcrest.MatcherAssert.assertThat) ReadReplica(org.neo4j.causalclustering.discovery.ReadReplica) Before(org.junit.Before) ReadReplicaToReadReplicaCatchupIT.checkDataHasReplicatedToReadReplicas(org.neo4j.causalclustering.scenarios.ReadReplicaToReadReplicaCatchupIT.checkDataHasReplicatedToReadReplicas) ReadReplica(org.neo4j.causalclustering.discovery.ReadReplica) CoreClusterMember(org.neo4j.causalclustering.discovery.CoreClusterMember) Cluster(org.neo4j.causalclustering.discovery.Cluster) Test(org.junit.Test)

Example 4 with Cluster

use of org.neo4j.causalclustering.discovery.Cluster in project neo4j by neo4j.

the class ReadReplicaReplicationIT method transactionsShouldNotAppearOnTheReadReplicaWhilePollingIsPaused.

@Test
public void transactionsShouldNotAppearOnTheReadReplicaWhilePollingIsPaused() throws Throwable {
    // given
    Cluster cluster = clusterRule.startCluster();
    ReadReplicaGraphDatabase readReplicaGraphDatabase = cluster.findAnyReadReplica().database();
    CatchupPollingProcess pollingClient = readReplicaGraphDatabase.getDependencyResolver().resolveDependency(CatchupPollingProcess.class);
    pollingClient.stop();
    cluster.coreTx((coreGraphDatabase, transaction) -> {
        coreGraphDatabase.createNode();
        transaction.success();
    });
    CoreGraphDatabase leaderDatabase = cluster.awaitLeader().database();
    long transactionVisibleOnLeader = transactionIdTracker(leaderDatabase).newestEncounteredTxId();
    // when the poller is paused, transaction doesn't make it to the read replica
    try {
        transactionIdTracker(readReplicaGraphDatabase).awaitUpToDate(transactionVisibleOnLeader, ofSeconds(3));
        fail("should have thrown exception");
    } catch (TransactionFailureException e) {
    // expected timeout
    }
    // when the poller is resumed, it does make it to the read replica
    pollingClient.start();
    transactionIdTracker(readReplicaGraphDatabase).awaitUpToDate(transactionVisibleOnLeader, ofSeconds(3));
}
Also used : TransactionFailureException(org.neo4j.kernel.api.exceptions.TransactionFailureException) CatchupPollingProcess(org.neo4j.causalclustering.catchup.tx.CatchupPollingProcess) Cluster(org.neo4j.causalclustering.discovery.Cluster) ReadReplicaGraphDatabase(org.neo4j.causalclustering.readreplica.ReadReplicaGraphDatabase) CoreGraphDatabase(org.neo4j.causalclustering.core.CoreGraphDatabase) Test(org.junit.Test)

Example 5 with Cluster

use of org.neo4j.causalclustering.discovery.Cluster in project neo4j by neo4j.

the class ReadReplicaReplicationIT method aReadReplicShouldBeAbleToRejoinTheCluster.

@Test
public void aReadReplicShouldBeAbleToRejoinTheCluster() throws Exception {
    int readReplicaId = 4;
    Cluster cluster = clusterRule.withNumberOfReadReplicas(0).startCluster();
    cluster.coreTx(createSomeData);
    cluster.addReadReplicaWithId(readReplicaId).start();
    // let's spend some time by adding more data
    cluster.coreTx(createSomeData);
    awaitEx(() -> readReplicasUpToDateAsTheLeader(cluster.awaitLeader(), cluster.readReplicas()), 1, TimeUnit.MINUTES);
    cluster.removeReadReplicaWithMemberId(readReplicaId);
    // let's spend some time by adding more data
    cluster.coreTx(createSomeData);
    cluster.addReadReplicaWithId(readReplicaId).start();
    awaitEx(() -> readReplicasUpToDateAsTheLeader(cluster.awaitLeader(), cluster.readReplicas()), 1, TimeUnit.MINUTES);
    Function<ClusterMember, DbRepresentation> toRep = db -> DbRepresentation.of(db.database());
    Set<DbRepresentation> dbs = cluster.coreMembers().stream().map(toRep).collect(toSet());
    dbs.addAll(cluster.readReplicas().stream().map(toRep).collect(toSet()));
    cluster.shutdown();
    assertEquals(1, dbs.size());
}
Also used : ResourceIterator(org.neo4j.graphdb.ResourceIterator) AvailabilityGuard(org.neo4j.kernel.AvailabilityGuard) Log(org.neo4j.logging.Log) CausalClusteringSettings(org.neo4j.causalclustering.core.CausalClusteringSettings) ReadReplicaGraphDatabase(org.neo4j.causalclustering.readreplica.ReadReplicaGraphDatabase) CoreMatchers.startsWith(org.hamcrest.CoreMatchers.startsWith) ThrowingSupplier(org.neo4j.function.ThrowingSupplier) HighLimit(org.neo4j.kernel.impl.store.format.highlimit.HighLimit) Map(java.util.Map) Is.is(org.hamcrest.core.Is.is) CoreClusterMember(org.neo4j.causalclustering.discovery.CoreClusterMember) Assert.fail(org.junit.Assert.fail) Transaction(org.neo4j.graphdb.Transaction) Path(java.nio.file.Path) Collectors.toSet(java.util.stream.Collectors.toSet) Standard(org.neo4j.kernel.impl.store.format.standard.Standard) PageCache(org.neo4j.io.pagecache.PageCache) CoreMatchers.containsString(org.hamcrest.CoreMatchers.containsString) Collection(java.util.Collection) Set(java.util.Set) BinaryOperator(java.util.function.BinaryOperator) UnsatisfiedDependencyException(org.neo4j.kernel.impl.util.UnsatisfiedDependencyException) Cluster(org.neo4j.causalclustering.discovery.Cluster) GraphDatabaseAPI(org.neo4j.kernel.internal.GraphDatabaseAPI) CoreGraphDatabase(org.neo4j.causalclustering.core.CoreGraphDatabase) Matchers.instanceOf(org.hamcrest.Matchers.instanceOf) TransactionIdTracker(org.neo4j.kernel.api.txtracking.TransactionIdTracker) MetaDataStore(org.neo4j.kernel.impl.store.MetaDataStore) Matchers.equalTo(org.hamcrest.Matchers.equalTo) Predicates.awaitEx(org.neo4j.function.Predicates.awaitEx) Matchers.greaterThan(org.hamcrest.Matchers.greaterThan) GraphDatabaseSettings(org.neo4j.graphdb.factory.GraphDatabaseSettings) SortedMap(java.util.SortedMap) Mockito.mock(org.mockito.Mockito.mock) Role(org.neo4j.causalclustering.core.consensus.roles.Role) ClusterMember(org.neo4j.causalclustering.discovery.ClusterMember) Label(org.neo4j.graphdb.Label) TransactionIdStore(org.neo4j.kernel.impl.transaction.log.TransactionIdStore) Iterables.count(org.neo4j.helpers.collection.Iterables.count) AtomicBoolean(java.util.concurrent.atomic.AtomicBoolean) Monitors(org.neo4j.kernel.monitoring.Monitors) MINUTES(java.util.concurrent.TimeUnit.MINUTES) ClusterRule(org.neo4j.test.causalclustering.ClusterRule) LabelScanStore(org.neo4j.kernel.api.labelscan.LabelScanStore) Duration.ofSeconds(java.time.Duration.ofSeconds) Function(java.util.function.Function) Node(org.neo4j.graphdb.Node) HashSet(java.util.HashSet) CatchupPollingProcess(org.neo4j.causalclustering.catchup.tx.CatchupPollingProcess) LifecycleException(org.neo4j.kernel.lifecycle.LifecycleException) HazelcastDiscoveryServiceFactory(org.neo4j.causalclustering.discovery.HazelcastDiscoveryServiceFactory) GraphDatabaseService(org.neo4j.graphdb.GraphDatabaseService) TIME(org.neo4j.kernel.impl.store.MetaDataStore.Position.TIME) BiConsumer(java.util.function.BiConsumer) TransactionFailureException(org.neo4j.kernel.api.exceptions.TransactionFailureException) MatcherAssert.assertThat(org.hamcrest.MatcherAssert.assertThat) MapUtil.stringMap(org.neo4j.helpers.collection.MapUtil.stringMap) FileNames(org.neo4j.causalclustering.core.consensus.log.segmented.FileNames) PhysicalLogFiles(org.neo4j.kernel.impl.transaction.log.PhysicalLogFiles) FileCopyMonitor(org.neo4j.causalclustering.catchup.tx.FileCopyMonitor) Assert.assertTrue(org.junit.Assert.assertTrue) Test(org.junit.Test) IOException(java.io.IOException) Assert.assertEventually(org.neo4j.test.assertion.Assert.assertEventually) File(java.io.File) TimeUnit(java.util.concurrent.TimeUnit) DefaultFileSystemAbstraction(org.neo4j.io.fs.DefaultFileSystemAbstraction) SampleData.createData(org.neo4j.causalclustering.scenarios.SampleData.createData) Rule(org.junit.Rule) Paths(java.nio.file.Paths) WriteOperationsNotAllowedException(org.neo4j.graphdb.security.WriteOperationsNotAllowedException) GraphDatabaseFacade(org.neo4j.kernel.impl.factory.GraphDatabaseFacade) DbRepresentation(org.neo4j.test.DbRepresentation) Clock(java.time.Clock) ReadReplica(org.neo4j.causalclustering.discovery.ReadReplica) SECONDS(java.util.concurrent.TimeUnit.SECONDS) Assert.assertEquals(org.junit.Assert.assertEquals) FileSystemAbstraction(org.neo4j.io.fs.FileSystemAbstraction) CoreClusterMember(org.neo4j.causalclustering.discovery.CoreClusterMember) ClusterMember(org.neo4j.causalclustering.discovery.ClusterMember) Cluster(org.neo4j.causalclustering.discovery.Cluster) DbRepresentation(org.neo4j.test.DbRepresentation) Test(org.junit.Test)

Aggregations

Cluster (org.neo4j.causalclustering.discovery.Cluster)52 Test (org.junit.Test)51 CoreClusterMember (org.neo4j.causalclustering.discovery.CoreClusterMember)21 File (java.io.File)14 HazelcastDiscoveryServiceFactory (org.neo4j.causalclustering.discovery.HazelcastDiscoveryServiceFactory)13 ReadReplica (org.neo4j.causalclustering.discovery.ReadReplica)13 Node (org.neo4j.graphdb.Node)12 Rule (org.junit.Rule)11 WriteOperationsNotAllowedException (org.neo4j.graphdb.security.WriteOperationsNotAllowedException)11 IOException (java.io.IOException)10 AtomicBoolean (java.util.concurrent.atomic.AtomicBoolean)10 Transaction (org.neo4j.graphdb.Transaction)10 TransactionFailureException (org.neo4j.kernel.api.exceptions.TransactionFailureException)10 ClusterRule (org.neo4j.test.causalclustering.ClusterRule)10 CoreGraphDatabase (org.neo4j.causalclustering.core.CoreGraphDatabase)9 Map (java.util.Map)8 TimeUnit (java.util.concurrent.TimeUnit)8 ReadReplicaGraphDatabase (org.neo4j.causalclustering.readreplica.ReadReplicaGraphDatabase)8 GraphDatabaseService (org.neo4j.graphdb.GraphDatabaseService)8 UnsatisfiedDependencyException (org.neo4j.kernel.impl.util.UnsatisfiedDependencyException)8