You are viewing a plain text version of this content. The canonical link for it is here.
Posted to oak-commits@jackrabbit.apache.org by al...@apache.org on 2014/07/03 16:58:09 UTC

svn commit: r1607664 - in /jackrabbit/oak/trunk/oak-core/src: main/java/org/apache/jackrabbit/oak/plugins/segment/Compactor.java test/java/org/apache/jackrabbit/oak/plugins/segment/CompactorTest.java

Author: alexparvulescu
Date: Thu Jul  3 14:58:08 2014
New Revision: 1607664

URL: http://svn.apache.org/r1607664
Log:
OAK-1932 TarMK compaction can create mixed segments
 - allowed the compactor to take into consideration the initial state

Added:
    jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/segment/CompactorTest.java   (with props)
Modified:
    jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/segment/Compactor.java

Modified: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/segment/Compactor.java
URL: http://svn.apache.org/viewvc/jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/segment/Compactor.java?rev=1607664&r1=1607663&r2=1607664&view=diff
==============================================================================
--- jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/segment/Compactor.java (original)
+++ jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/segment/Compactor.java Thu Jul  3 14:58:08 2014
@@ -20,7 +20,6 @@ import static com.google.common.collect.
 import static com.google.common.collect.Maps.newHashMap;
 import static org.apache.jackrabbit.oak.api.Type.BINARIES;
 import static org.apache.jackrabbit.oak.api.Type.BINARY;
-import static org.apache.jackrabbit.oak.plugins.memory.EmptyNodeState.EMPTY_NODE;
 
 import java.io.IOException;
 import java.io.InputStream;
@@ -62,8 +61,6 @@ public class Compactor {
 
     private final SegmentWriter writer;
 
-    private final SegmentNodeBuilder builder;
-
     private CompactionMap map = new CompactionMap(100000);
 
     /**
@@ -75,11 +72,11 @@ public class Compactor {
 
     public Compactor(SegmentWriter writer) {
         this.writer = writer;
-        this.builder =
-                new SegmentNodeBuilder(writer.writeNode(EMPTY_NODE), writer);
     }
 
     public SegmentNodeState compact(NodeState before, NodeState after) {
+        SegmentNodeBuilder builder = new SegmentNodeBuilder(
+                writer.writeNode(before), writer);
         after.compareAgainstBaseState(before, new CompactDiff(builder));
         return builder.getNodeState();
     }

Added: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/segment/CompactorTest.java
URL: http://svn.apache.org/viewvc/jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/segment/CompactorTest.java?rev=1607664&view=auto
==============================================================================
--- jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/segment/CompactorTest.java (added)
+++ jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/segment/CompactorTest.java Thu Jul  3 14:58:08 2014
@@ -0,0 +1,72 @@
+/*
+ * 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.jackrabbit.oak.plugins.segment;
+
+import junit.framework.Assert;
+
+import org.apache.jackrabbit.oak.Oak;
+import org.apache.jackrabbit.oak.api.CommitFailedException;
+import org.apache.jackrabbit.oak.plugins.segment.memory.MemoryStore;
+import org.apache.jackrabbit.oak.spi.commit.CommitInfo;
+import org.apache.jackrabbit.oak.spi.commit.EmptyHook;
+import org.apache.jackrabbit.oak.spi.security.OpenSecurityProvider;
+import org.apache.jackrabbit.oak.spi.state.NodeBuilder;
+import org.apache.jackrabbit.oak.spi.state.NodeState;
+import org.apache.jackrabbit.oak.spi.state.NodeStore;
+import org.junit.Test;
+
+public class CompactorTest {
+
+    @Test
+    public void testCompactor() throws Exception {
+        MemoryStore source = new MemoryStore();
+        try {
+            NodeStore store = new SegmentNodeStore(source);
+            init(store);
+
+            Compactor compactor = new Compactor(source.getTracker().getWriter());
+            addTestContent(store, 0);
+
+            NodeState initial = store.getRoot();
+            SegmentNodeState after = compactor
+                    .compact(initial, store.getRoot());
+            Assert.assertEquals(store.getRoot(), after);
+
+            addTestContent(store, 1);
+            after = compactor.compact(initial, store.getRoot());
+            Assert.assertEquals(store.getRoot(), after);
+
+        } finally {
+            source.close();
+        }
+
+    }
+
+    private static void init(NodeStore store) {
+        new Oak(store).with(new OpenSecurityProvider())
+                .createContentRepository();
+    }
+
+    private static void addTestContent(NodeStore store, int index)
+            throws CommitFailedException {
+        NodeBuilder builder = store.getRoot().builder();
+        builder.child("test" + index);
+        builder.child("child" + index);
+        store.merge(builder, EmptyHook.INSTANCE, CommitInfo.EMPTY);
+    }
+
+}

Propchange: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/segment/CompactorTest.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain