Search in sources :

Example 1 with BatchInserter

use of org.neo4j.batchinsert.BatchInserter in project neo4j by neo4j.

the class BatchInsertionIT method shouldBeAbleToMakeRepeatedCallsToSetNodePropertyWithMultiplePropertiesPerBlock.

@Test
void shouldBeAbleToMakeRepeatedCallsToSetNodePropertyWithMultiplePropertiesPerBlock() throws Exception {
    BatchInserter inserter = BatchInserters.inserter(databaseLayout, fileSystem);
    long nodeId = inserter.createNode(Collections.emptyMap());
    final Object finalValue1 = 87;
    final Object finalValue2 = 3.14;
    inserter.setNodeProperty(nodeId, "a", "some property value");
    inserter.setNodeProperty(nodeId, "a", 42);
    inserter.setNodeProperty(nodeId, "b", finalValue2);
    inserter.setNodeProperty(nodeId, "a", finalValue2);
    inserter.setNodeProperty(nodeId, "a", true);
    inserter.setNodeProperty(nodeId, "a", finalValue1);
    inserter.shutdown();
    var db = getDatabase();
    try (Transaction tx = db.beginTx()) {
        assertThat(tx.getNodeById(nodeId).getProperty("a")).isEqualTo(finalValue1);
        assertThat(tx.getNodeById(nodeId).getProperty("b")).isEqualTo(finalValue2);
    }
}
Also used : BatchInserter(org.neo4j.batchinsert.BatchInserter) Transaction(org.neo4j.graphdb.Transaction) Test(org.junit.jupiter.api.Test)

Example 2 with BatchInserter

use of org.neo4j.batchinsert.BatchInserter in project neo4j by neo4j.

the class FileSystemClosingBatchInserterTest method closeFileSystemOnShutdown.

@Test
void closeFileSystemOnShutdown() throws Exception {
    BatchInserter batchInserter = mock(BatchInserter.class);
    FileSystemAbstraction fileSystem = mock(FileSystemAbstraction.class);
    FileSystemClosingBatchInserter inserter = new FileSystemClosingBatchInserter(batchInserter, fileSystem);
    inserter.shutdown();
    InOrder verificationOrder = inOrder(batchInserter, fileSystem);
    verificationOrder.verify(batchInserter).shutdown();
    verificationOrder.verify(fileSystem).close();
}
Also used : BatchInserter(org.neo4j.batchinsert.BatchInserter) FileSystemAbstraction(org.neo4j.io.fs.FileSystemAbstraction) InOrder(org.mockito.InOrder) Test(org.junit.jupiter.api.Test)

Example 3 with BatchInserter

use of org.neo4j.batchinsert.BatchInserter in project neo4j by neo4j.

the class BatchInsertTest method shouldCreateConsistentUniquenessConstraint.

@ParameterizedTest
@MethodSource("params")
void shouldCreateConsistentUniquenessConstraint(int denseNodeThreshold) throws Exception {
    // given
    BatchInserter inserter = newBatchInserter(denseNodeThreshold);
    // when
    inserter.createDeferredConstraint(label("Hacker")).assertPropertyIsUnique("handle").create();
    // then
    GraphDatabaseAPI graphdb = switchToEmbeddedGraphDatabaseService(inserter, denseNodeThreshold);
    try {
        NeoStores neoStores = graphdb.getDependencyResolver().resolveDependency(RecordStorageEngine.class).testAccessNeoStores();
        SchemaStore store = neoStores.getSchemaStore();
        TokenHolders tokenHolders = graphdb.getDependencyResolver().resolveDependency(TokenHolders.class);
        SchemaRuleAccess schemaRuleAccess = SchemaRuleAccess.getSchemaRuleAccess(store, tokenHolders, () -> KernelVersion.LATEST);
        List<Long> inUse = new ArrayList<>();
        SchemaRecord record = store.newRecord();
        for (long i = 1, high = store.getHighestPossibleIdInUse(NULL); i <= high; i++) {
            store.getRecord(i, record, RecordLoad.FORCE, NULL);
            if (record.inUse()) {
                inUse.add(i);
            }
        }
        assertEquals(2, inUse.size(), "records in use");
        SchemaRule rule0 = schemaRuleAccess.loadSingleSchemaRule(inUse.get(0), NULL);
        SchemaRule rule1 = schemaRuleAccess.loadSingleSchemaRule(inUse.get(1), NULL);
        IndexDescriptor indexRule;
        ConstraintDescriptor constraint;
        if (rule0 instanceof IndexDescriptor) {
            indexRule = (IndexDescriptor) rule0;
            constraint = (ConstraintDescriptor) rule1;
        } else {
            constraint = (ConstraintDescriptor) rule0;
            indexRule = (IndexDescriptor) rule1;
        }
        OptionalLong owningConstraintId = indexRule.getOwningConstraintId();
        assertTrue(owningConstraintId.isPresent(), "index should have owning constraint");
        assertEquals(constraint.getId(), owningConstraintId.getAsLong(), "index should reference constraint");
        assertEquals(indexRule.getId(), constraint.asIndexBackedConstraint().ownedIndexId(), "constraint should reference index");
    } finally {
        managementService.shutdown();
    }
}
Also used : SchemaStore(org.neo4j.kernel.impl.store.SchemaStore) SchemaRuleAccess(org.neo4j.internal.recordstorage.SchemaRuleAccess) ArrayList(java.util.ArrayList) SchemaRule(org.neo4j.internal.schema.SchemaRule) IndexDescriptor(org.neo4j.internal.schema.IndexDescriptor) BatchInserter(org.neo4j.batchinsert.BatchInserter) GraphDatabaseAPI(org.neo4j.kernel.internal.GraphDatabaseAPI) SchemaRecord(org.neo4j.kernel.impl.store.record.SchemaRecord) RecordStorageEngine(org.neo4j.internal.recordstorage.RecordStorageEngine) NeoStores(org.neo4j.kernel.impl.store.NeoStores) ConstraintDescriptor(org.neo4j.internal.schema.ConstraintDescriptor) OptionalLong(java.util.OptionalLong) OptionalLong(java.util.OptionalLong) TokenHolders(org.neo4j.token.TokenHolders) ParameterizedTest(org.junit.jupiter.params.ParameterizedTest) MethodSource(org.junit.jupiter.params.provider.MethodSource)

Example 4 with BatchInserter

use of org.neo4j.batchinsert.BatchInserter in project neo4j by neo4j.

the class BatchInsertTest method shouldCreateDeferredUniquenessConstraintInEmptyDatabase.

@ParameterizedTest
@MethodSource("params")
void shouldCreateDeferredUniquenessConstraintInEmptyDatabase(int denseNodeThreshold) throws Exception {
    // GIVEN
    BatchInserter inserter = newBatchInserter(denseNodeThreshold);
    // WHEN
    ConstraintDefinition definition = inserter.createDeferredConstraint(label("Hacker")).assertPropertyIsUnique("handle").create();
    // THEN
    assertEquals("Hacker", definition.getLabel().name());
    assertEquals(ConstraintType.UNIQUENESS, definition.getConstraintType());
    assertEquals(asSet("handle"), Iterables.asSet(definition.getPropertyKeys()));
    inserter.shutdown();
}
Also used : BatchInserter(org.neo4j.batchinsert.BatchInserter) ConstraintDefinition(org.neo4j.graphdb.schema.ConstraintDefinition) ParameterizedTest(org.junit.jupiter.params.ParameterizedTest) MethodSource(org.junit.jupiter.params.provider.MethodSource)

Example 5 with BatchInserter

use of org.neo4j.batchinsert.BatchInserter in project neo4j by neo4j.

the class BatchInsertTest method shouldRepopulatePreexistingIndexed.

@ParameterizedTest
@MethodSource("params")
void shouldRepopulatePreexistingIndexed(int denseNodeThreshold) throws Throwable {
    // GIVEN
    long jakewins = dbWithIndexAndSingleIndexedNode(denseNodeThreshold);
    IndexPopulator populator = mock(IndexPopulator.class);
    IndexProvider provider = mock(IndexProvider.class);
    IndexAccessor accessor = mock(IndexAccessor.class);
    when(provider.getProviderDescriptor()).thenReturn(DESCRIPTOR);
    when(provider.completeConfiguration(any(IndexDescriptor.class))).then(inv -> inv.getArgument(0));
    when(provider.getPopulator(any(IndexDescriptor.class), any(IndexSamplingConfig.class), any(), any(), any(TokenNameLookup.class))).thenReturn(populator);
    when(populator.sample(any(CursorContext.class))).thenReturn(new IndexSample());
    when(provider.getOnlineAccessor(any(IndexDescriptor.class), any(IndexSamplingConfig.class), any(TokenNameLookup.class))).thenReturn(accessor);
    BatchInserter inserter = newBatchInserterWithIndexProvider(singleInstanceIndexProviderFactory(KEY, provider), provider.getProviderDescriptor(), denseNodeThreshold);
    long boggle = inserter.createNode(map("handle", "b0ggl3"), label("Hacker"));
    // WHEN
    inserter.shutdown();
    // THEN
    verify(provider).init();
    verify(provider).start();
    verify(provider).getPopulator(any(IndexDescriptor.class), any(IndexSamplingConfig.class), any(), any(), any(TokenNameLookup.class));
    verify(populator).create();
    verify(populator).add(argThat(c -> c.contains(add(jakewins, internalIndex.schema(), Values.of("Jakewins"))) && c.contains(add(boggle, internalIndex.schema(), Values.of("b0ggl3")))), any(CursorContext.class));
    verify(populator).verifyDeferredConstraints(any(NodePropertyAccessor.class));
    verify(populator).close(eq(true), any());
    verify(provider).stop();
    verify(provider).shutdown();
}
Also used : IndexProvider(org.neo4j.kernel.api.index.IndexProvider) Arrays(java.util.Arrays) ResourceIterator(org.neo4j.graphdb.ResourceIterator) DatabaseReadOnlyChecker.readOnly(org.neo4j.configuration.helpers.DatabaseReadOnlyChecker.readOnly) CursorContext(org.neo4j.io.pagecache.context.CursorContext) ArgumentMatchers.eq(org.mockito.ArgumentMatchers.eq) Direction(org.neo4j.graphdb.Direction) TokenNameLookup(org.neo4j.common.TokenNameLookup) IndexPopulator(org.neo4j.kernel.api.index.IndexPopulator) NORMAL(org.neo4j.kernel.impl.store.record.RecordLoad.NORMAL) Config(org.neo4j.configuration.Config) IndexSamplingConfig(org.neo4j.kernel.impl.api.index.IndexSamplingConfig) DEFAULT_DATABASE_NAME(org.neo4j.configuration.GraphDatabaseSettings.DEFAULT_DATABASE_NAME) Arrays.asList(java.util.Arrays.asList) Map(java.util.Map) PageCacheTracer(org.neo4j.io.pagecache.tracing.PageCacheTracer) NULL(org.neo4j.io.pagecache.context.CursorContext.NULL) RecoveryCleanupWorkCollector(org.neo4j.index.internal.gbptree.RecoveryCleanupWorkCollector) TokenIndexProviderFactory(org.neo4j.kernel.impl.index.schema.TokenIndexProviderFactory) SchemaStore(org.neo4j.kernel.impl.store.SchemaStore) Set(java.util.Set) SchemaRecord(org.neo4j.kernel.impl.store.record.SchemaRecord) Arguments(org.junit.jupiter.params.provider.Arguments) GraphDatabaseAPI(org.neo4j.kernel.internal.GraphDatabaseAPI) ConstraintDefinition(org.neo4j.graphdb.schema.ConstraintDefinition) Stream(java.util.stream.Stream) BatchInserter(org.neo4j.batchinsert.BatchInserter) IndexEntryUpdate.add(org.neo4j.storageengine.api.IndexEntryUpdate.add) Assertions.assertTrue(org.junit.jupiter.api.Assertions.assertTrue) RelationshipType(org.neo4j.graphdb.RelationshipType) NodeStore(org.neo4j.kernel.impl.store.NodeStore) IndexDescriptor(org.neo4j.internal.schema.IndexDescriptor) Mockito.mock(org.mockito.Mockito.mock) Assertions.assertThrows(org.junit.jupiter.api.Assertions.assertThrows) Assertions.fail(org.junit.jupiter.api.Assertions.fail) MapUtil.map(org.neo4j.internal.helpers.collection.MapUtil.map) SimpleDateFormat(java.text.SimpleDateFormat) KernelVersion(org.neo4j.kernel.KernelVersion) Node(org.neo4j.graphdb.Node) ArrayList(java.util.ArrayList) OptionalLong(java.util.OptionalLong) TestDatabaseManagementServiceBuilder(org.neo4j.test.TestDatabaseManagementServiceBuilder) GBPTreeCountsStore(org.neo4j.internal.counts.GBPTreeCountsStore) Assertions.assertEquals(org.junit.jupiter.api.Assertions.assertEquals) MemoryTracker(org.neo4j.memory.MemoryTracker) NodePropertyAccessor(org.neo4j.storageengine.api.NodePropertyAccessor) TestIndexProviderDescriptor(org.neo4j.kernel.impl.api.index.TestIndexProviderDescriptor) IndexSample(org.neo4j.kernel.api.index.IndexSample) Files(java.nio.file.Files) Iterators(org.neo4j.internal.helpers.collection.Iterators) IOException(java.io.IOException) Label.label(org.neo4j.graphdb.Label.label) Assertions.assertArrayEquals(org.junit.jupiter.api.Assertions.assertArrayEquals) ParameterizedTest(org.junit.jupiter.params.ParameterizedTest) ExtensionFactory(org.neo4j.kernel.extension.ExtensionFactory) TokenHolders(org.neo4j.token.TokenHolders) ConstraintType(org.neo4j.graphdb.schema.ConstraintType) NodeRecord(org.neo4j.kernel.impl.store.record.NodeRecord) IndexDefinition(org.neo4j.graphdb.schema.IndexDefinition) RecordLoad(org.neo4j.kernel.impl.store.record.RecordLoad) Iterators.asCollection(org.neo4j.internal.helpers.collection.Iterators.asCollection) SchemaIndexTestHelper.singleInstanceIndexProviderFactory(org.neo4j.kernel.impl.api.index.SchemaIndexTestHelper.singleInstanceIndexProviderFactory) SchemaRule(org.neo4j.internal.schema.SchemaRule) SchemaRuleAccess(org.neo4j.internal.recordstorage.SchemaRuleAccess) ArgumentMatchers.argThat(org.mockito.ArgumentMatchers.argThat) MyRelTypes(org.neo4j.kernel.impl.MyRelTypes) Assertions.assertThat(org.assertj.core.api.Assertions.assertThat) ConstraintDescriptor(org.neo4j.internal.schema.ConstraintDescriptor) DatabaseLayout(org.neo4j.io.layout.DatabaseLayout) NodeLabelsField(org.neo4j.kernel.impl.store.NodeLabelsField) Assertions.assertFalse(org.junit.jupiter.api.Assertions.assertFalse) Iterables.map(org.neo4j.internal.helpers.collection.Iterables.map) Iterables.single(org.neo4j.internal.helpers.collection.Iterables.single) Transaction(org.neo4j.graphdb.Transaction) IndexProviderDescriptor(org.neo4j.internal.schema.IndexProviderDescriptor) MethodSource(org.junit.jupiter.params.provider.MethodSource) PageCache(org.neo4j.io.pagecache.PageCache) TestDirectory(org.neo4j.test.rule.TestDirectory) RecordStorageEngine(org.neo4j.internal.recordstorage.RecordStorageEngine) Neo4jLayoutExtension(org.neo4j.test.extension.Neo4jLayoutExtension) String.format(java.lang.String.format) Test(org.junit.jupiter.api.Test) List(java.util.List) INSTANCE(org.neo4j.memory.EmptyMemoryTracker.INSTANCE) DatabaseManagementService(org.neo4j.dbms.api.DatabaseManagementService) ArgumentMatchers.any(org.mockito.ArgumentMatchers.any) Label(org.neo4j.graphdb.Label) GraphDatabaseSettings(org.neo4j.configuration.GraphDatabaseSettings) HashMap(java.util.HashMap) IndexAccessor(org.neo4j.kernel.api.index.IndexAccessor) Iterators.iterator(org.neo4j.internal.helpers.collection.Iterators.iterator) IndexProvider(org.neo4j.kernel.api.index.IndexProvider) Values(org.neo4j.values.storable.Values) GraphDatabaseSettings.preallocate_logical_logs(org.neo4j.configuration.GraphDatabaseSettings.preallocate_logical_logs) HashSet(java.util.HashSet) ConstraintViolationException(org.neo4j.graphdb.ConstraintViolationException) NodeLabels(org.neo4j.kernel.impl.store.NodeLabels) GraphDatabaseService(org.neo4j.graphdb.GraphDatabaseService) NeoStores(org.neo4j.kernel.impl.store.NeoStores) Inject(org.neo4j.test.extension.Inject) Iterables(org.neo4j.internal.helpers.collection.Iterables) GraphDatabaseSettings.dense_node_threshold(org.neo4j.configuration.GraphDatabaseSettings.dense_node_threshold) GraphDatabaseInternalSettings(org.neo4j.configuration.GraphDatabaseInternalSettings) Arguments.arguments(org.junit.jupiter.params.provider.Arguments.arguments) TestIndexDescriptorFactory(org.neo4j.kernel.api.schema.index.TestIndexDescriptorFactory) PageCacheExtension(org.neo4j.test.extension.pagecache.PageCacheExtension) Mockito.when(org.mockito.Mockito.when) Mockito.verify(org.mockito.Mockito.verify) TimeUnit(java.util.concurrent.TimeUnit) CountsAccessor(org.neo4j.counts.CountsAccessor) Relationship(org.neo4j.graphdb.Relationship) CountsBuilder(org.neo4j.internal.counts.CountsBuilder) Iterators.asSet(org.neo4j.internal.helpers.collection.Iterators.asSet) Pair(org.neo4j.internal.helpers.collection.Pair) GraphDatabaseSettings.neo4j_home(org.neo4j.configuration.GraphDatabaseSettings.neo4j_home) BatchInserters(org.neo4j.batchinsert.BatchInserters) Collections(java.util.Collections) TransactionIdStore(org.neo4j.storageengine.api.TransactionIdStore) FileSystemAbstraction(org.neo4j.io.fs.FileSystemAbstraction) IndexPopulator(org.neo4j.kernel.api.index.IndexPopulator) IndexSamplingConfig(org.neo4j.kernel.impl.api.index.IndexSamplingConfig) BatchInserter(org.neo4j.batchinsert.BatchInserter) TokenNameLookup(org.neo4j.common.TokenNameLookup) IndexSample(org.neo4j.kernel.api.index.IndexSample) IndexAccessor(org.neo4j.kernel.api.index.IndexAccessor) CursorContext(org.neo4j.io.pagecache.context.CursorContext) IndexDescriptor(org.neo4j.internal.schema.IndexDescriptor) NodePropertyAccessor(org.neo4j.storageengine.api.NodePropertyAccessor) ParameterizedTest(org.junit.jupiter.params.ParameterizedTest) MethodSource(org.junit.jupiter.params.provider.MethodSource)

Aggregations

BatchInserter (org.neo4j.batchinsert.BatchInserter)23 ParameterizedTest (org.junit.jupiter.params.ParameterizedTest)15 Test (org.junit.jupiter.api.Test)14 Transaction (org.neo4j.graphdb.Transaction)13 GraphDatabaseService (org.neo4j.graphdb.GraphDatabaseService)11 MethodSource (org.junit.jupiter.params.provider.MethodSource)8 Label (org.neo4j.graphdb.Label)6 IndexDefinition (org.neo4j.graphdb.schema.IndexDefinition)6 IndexDescriptor (org.neo4j.internal.schema.IndexDescriptor)6 GraphDatabaseAPI (org.neo4j.kernel.internal.GraphDatabaseAPI)6 ArrayList (java.util.ArrayList)4 OptionalLong (java.util.OptionalLong)4 IndexSamplingConfig (org.neo4j.kernel.impl.api.index.IndexSamplingConfig)4 IOException (java.io.IOException)3 String.format (java.lang.String.format)3 Files (java.nio.file.Files)3 SimpleDateFormat (java.text.SimpleDateFormat)3 Arrays (java.util.Arrays)3 Arrays.asList (java.util.Arrays.asList)3 Collections (java.util.Collections)3