Search in sources :

Example 6 with ReadReplica

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

the class ReadReplicaReplicationIT method allServersBecomeAvailable.

@Test
public void allServersBecomeAvailable() throws Exception {
    // given
    Cluster cluster = clusterRule.startCluster();
    // then
    for (final ReadReplica readReplica : cluster.readReplicas()) {
        ThrowingSupplier<Boolean, Exception> availability = () -> readReplica.database().isAvailable(0);
        assertEventually("read replica becomes available", availability, is(true), 10, SECONDS);
    }
}
Also used : ReadReplica(org.neo4j.causalclustering.discovery.ReadReplica) Cluster(org.neo4j.causalclustering.discovery.Cluster) AtomicBoolean(java.util.concurrent.atomic.AtomicBoolean) UnsatisfiedDependencyException(org.neo4j.kernel.impl.util.UnsatisfiedDependencyException) LifecycleException(org.neo4j.kernel.lifecycle.LifecycleException) TransactionFailureException(org.neo4j.kernel.api.exceptions.TransactionFailureException) IOException(java.io.IOException) WriteOperationsNotAllowedException(org.neo4j.graphdb.security.WriteOperationsNotAllowedException) Test(org.junit.Test)

Example 7 with ReadReplica

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

the class ReadReplicaReplicationIT method shouldBeAbleToPullTxAfterHavingDownloadedANewStoreAfterPruning.

@Test
public void shouldBeAbleToPullTxAfterHavingDownloadedANewStoreAfterPruning() throws Exception {
    // given
    Map<String, String> params = stringMap(GraphDatabaseSettings.keep_logical_logs.name(), "keep_none", GraphDatabaseSettings.logical_log_rotation_threshold.name(), "1M", GraphDatabaseSettings.check_point_interval_time.name(), "100ms");
    Cluster cluster = clusterRule.withSharedCoreParams(params).startCluster();
    cluster.coreTx((db, tx) -> {
        createData(db, 10);
        tx.success();
    });
    awaitEx(() -> readReplicasUpToDateAsTheLeader(cluster.awaitLeader(), cluster.readReplicas()), 1, TimeUnit.MINUTES);
    ReadReplica readReplica = cluster.getReadReplicaById(0);
    long highestReadReplicaLogVersion = physicalLogFiles(readReplica).getHighestLogVersion();
    readReplica.shutdown();
    CoreClusterMember core;
    do {
        core = cluster.coreTx((db, tx) -> {
            createData(db, 1_000);
            tx.success();
        });
    } while (physicalLogFiles(core).getLowestLogVersion() <= highestReadReplicaLogVersion);
    readReplica.start();
    awaitEx(() -> readReplicasUpToDateAsTheLeader(cluster.awaitLeader(), cluster.readReplicas()), 1, TimeUnit.MINUTES);
    // when
    cluster.coreTx((db, tx) -> {
        createData(db, 10);
        tx.success();
    });
    // then
    assertEventually("The read replica has the same data as the core members", () -> DbRepresentation.of(readReplica.database()), equalTo(DbRepresentation.of(cluster.awaitLeader().database())), 10, TimeUnit.SECONDS);
}
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) ReadReplica(org.neo4j.causalclustering.discovery.ReadReplica) CoreClusterMember(org.neo4j.causalclustering.discovery.CoreClusterMember) Cluster(org.neo4j.causalclustering.discovery.Cluster) CoreMatchers.containsString(org.hamcrest.CoreMatchers.containsString) Test(org.junit.Test)

Example 8 with ReadReplica

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

the class ReadReplicaStoreCopyIT method shouldNotBePossibleToStartTransactionsWhenReadReplicaCopiesStore.

@Test(timeout = 120_000)
public void shouldNotBePossibleToStartTransactionsWhenReadReplicaCopiesStore() throws Throwable {
    Cluster cluster = clusterRule.startCluster();
    ReadReplica readReplica = cluster.findAnyReadReplica();
    readReplica.txPollingClient().stop();
    writeSomeDataAndForceLogRotations(cluster);
    Semaphore storeCopyBlockingSemaphore = addStoreCopyBlockingMonitor(readReplica);
    try {
        readReplica.txPollingClient().start();
        waitForStoreCopyToStartAndBlock(storeCopyBlockingSemaphore);
        ReadReplicaGraphDatabase replicaGraphDatabase = readReplica.database();
        try {
            replicaGraphDatabase.beginTx();
            fail("Exception expected");
        } catch (Exception e) {
            assertThat(e, instanceOf(TransactionFailureException.class));
            assertThat(e.getMessage(), containsString("Database is stopped to copy store"));
        }
    } finally {
        // release all waiters of the semaphore
        storeCopyBlockingSemaphore.release(Integer.MAX_VALUE);
    }
}
Also used : ReadReplica(org.neo4j.causalclustering.discovery.ReadReplica) Cluster(org.neo4j.causalclustering.discovery.Cluster) Semaphore(java.util.concurrent.Semaphore) ReadReplicaGraphDatabase(org.neo4j.causalclustering.readreplica.ReadReplicaGraphDatabase) TransactionFailureException(org.neo4j.graphdb.TransactionFailureException) IOException(java.io.IOException) UncheckedIOException(java.io.UncheckedIOException) Test(org.junit.Test)

Example 9 with ReadReplica

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

the class ClusterFormationIT method shouldSupportBuiltInProcedures.

@Test
public void shouldSupportBuiltInProcedures() throws Exception {
    cluster.addReadReplicaWithId(0).start();
    Stream.concat(cluster.readReplicas().stream().map(ReadReplica::database), cluster.coreMembers().stream().map(CoreClusterMember::database)).forEach(gdb -> {
        {
            Result result = gdb.execute("CALL dbms.procedures()");
            assertTrue(result.hasNext());
            result.close();
        }
        try (InternalTransaction tx = gdb.beginTransaction(KernelTransaction.Type.explicit, EnterpriseSecurityContext.AUTH_DISABLED)) {
            Result result = gdb.execute(tx, "CALL dbms.listQueries()", Collections.emptyMap());
            assertTrue(result.hasNext());
            result.close();
            tx.success();
        }
    });
}
Also used : ReadReplica(org.neo4j.causalclustering.discovery.ReadReplica) CoreClusterMember(org.neo4j.causalclustering.discovery.CoreClusterMember) InternalTransaction(org.neo4j.kernel.impl.coreapi.InternalTransaction) Result(org.neo4j.graphdb.Result) Test(org.junit.Test)

Example 10 with ReadReplica

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

the class CausalClusteringProceduresIT method readReplicaProceduresShouldBeAvailable.

@Test
public void readReplicaProceduresShouldBeAvailable() throws Exception {
    // given
    String[] readReplicaProcs = new String[] { // Server role
    "dbms.cluster.role", // Kernel built procedures
    "dbms.procedures", // Built in procedure from enterprise
    "dbms.listQueries" };
    // when
    for (String procedure : readReplicaProcs) {
        Optional<ReadReplica> firstReadReplica = cluster.readReplicas().stream().findFirst();
        assert firstReadReplica.isPresent();
        ReadReplicaGraphDatabase database = firstReadReplica.get().database();
        InternalTransaction tx = database.beginTransaction(KernelTransaction.Type.explicit, AUTH_DISABLED);
        Result readReplicaResult = database.execute("CALL " + procedure + "()");
        // then
        assertTrue("read replica with procedure " + procedure, readReplicaResult.hasNext());
        readReplicaResult.close();
        tx.close();
    }
}
Also used : ReadReplica(org.neo4j.causalclustering.discovery.ReadReplica) ReadReplicaGraphDatabase(org.neo4j.causalclustering.readreplica.ReadReplicaGraphDatabase) InternalTransaction(org.neo4j.kernel.impl.coreapi.InternalTransaction) Result(org.neo4j.graphdb.Result) Test(org.junit.Test)

Aggregations

ReadReplica (org.neo4j.causalclustering.discovery.ReadReplica)22 Test (org.junit.Test)20 Cluster (org.neo4j.causalclustering.discovery.Cluster)13 CoreClusterMember (org.neo4j.causalclustering.discovery.CoreClusterMember)13 IOException (java.io.IOException)8 ReadReplicaGraphDatabase (org.neo4j.causalclustering.readreplica.ReadReplicaGraphDatabase)7 AtomicBoolean (java.util.concurrent.atomic.AtomicBoolean)6 Rule (org.junit.Rule)6 Node (org.neo4j.graphdb.Node)6 Transaction (org.neo4j.graphdb.Transaction)6 WriteOperationsNotAllowedException (org.neo4j.graphdb.security.WriteOperationsNotAllowedException)6 TransactionFailureException (org.neo4j.kernel.api.exceptions.TransactionFailureException)6 UnsatisfiedDependencyException (org.neo4j.kernel.impl.util.UnsatisfiedDependencyException)6 LifecycleException (org.neo4j.kernel.lifecycle.LifecycleException)6 Monitors (org.neo4j.kernel.monitoring.Monitors)6 ClusterRule (org.neo4j.test.causalclustering.ClusterRule)6 File (java.io.File)5 HashSet (java.util.HashSet)5 Map (java.util.Map)5 TimeUnit (java.util.concurrent.TimeUnit)5