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 re...@apache.org on 2014/02/14 12:21:34 UTC

svn commit: r1568240 [3/4] - in /jackrabbit/oak/trunk: oak-auth-external/src/main/java/org/apache/jackrabbit/oak/spi/security/authentication/external/ oak-auth-external/src/main/java/org/apache/jackrabbit/oak/spi/security/authentication/external/impl/ ...

Modified: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/blob/datastore/DataStoreWrapperBackend.java
URL: http://svn.apache.org/viewvc/jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/blob/datastore/DataStoreWrapperBackend.java?rev=1568240&r1=1568239&r2=1568240&view=diff
==============================================================================
--- jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/blob/datastore/DataStoreWrapperBackend.java (original)
+++ jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/blob/datastore/DataStoreWrapperBackend.java Fri Feb 14 11:21:31 2014
@@ -1,119 +1,119 @@
-/*
- * 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.blob.datastore;
-
-import java.io.File;
-import java.io.FileInputStream;
-import java.io.IOException;
-import java.io.InputStream;
-import java.util.Iterator;
-import java.util.List;
-
-import org.apache.commons.io.IOUtils;
-import org.apache.jackrabbit.core.data.Backend;
-import org.apache.jackrabbit.core.data.CachingDataStore;
-import org.apache.jackrabbit.core.data.DataIdentifier;
-import org.apache.jackrabbit.core.data.DataStore;
-import org.apache.jackrabbit.core.data.DataStoreException;
-import org.apache.jackrabbit.core.data.MultiDataStoreAware;
-
-import com.google.common.collect.Lists;
-
-/**
- * {@link Backend} wrapper over Jackrabbit {@link DataStore} which enables using
- * a {@link CachingDataStore} for local file caching.
- */
-public class DataStoreWrapperBackend implements Backend {
-
-    /** The data store being wrapped. */
-    private DataStore dataStore;
-
-    /**
-     * Instantiates a new data store wrapper backend.
-     * 
-     * @param dataStore
-     *            the data store
-     */
-    public DataStoreWrapperBackend(DataStore dataStore) {
-        this.dataStore = dataStore;
-    }
-
-    @Override
-    public void init(CachingDataStore store, String homeDir, String config) throws DataStoreException {
-    }
-
-    @Override
-    public InputStream read(DataIdentifier identifier) throws DataStoreException {
-        return dataStore.getRecordIfStored(identifier).getStream();
-    }
-
-    @Override
-    public long getLength(DataIdentifier identifier) throws DataStoreException {
-        return dataStore.getRecord(identifier).getLength();
-    }
-
-    @Override
-    public long getLastModified(DataIdentifier identifier) throws DataStoreException {
-        return dataStore.getRecord(identifier).getLastModified();
-    }
-
-    @Override
-    public void write(DataIdentifier identifier, File file) throws DataStoreException {
-        InputStream stream = null;
-        try {
-            stream = new FileInputStream(file);
-            dataStore.addRecord(stream);
-        } catch (IOException io) {
-            throw new DataStoreException("Error retrieving stream from : " + file.getAbsolutePath());
-        } finally {
-            IOUtils.closeQuietly(stream);
-        }
-    }
-
-    @Override
-    public Iterator<DataIdentifier> getAllIdentifiers() throws DataStoreException {
-        return dataStore.getAllIdentifiers();
-    }
-
-    @Override
-    public void touch(DataIdentifier identifier, long minModifiedDate) throws DataStoreException {
-        // currently no-op
-    }
-
-    @Override
-    public boolean exists(DataIdentifier identifier) throws DataStoreException {
-        return (dataStore.getRecordIfStored(identifier) != null);
-    }
-
-    @Override
-    public void close() throws DataStoreException {
-        dataStore.close();
-    }
-
-    @Override
-    public List<DataIdentifier> deleteAllOlderThan(long timestamp) throws DataStoreException {
-        dataStore.deleteAllOlderThan(timestamp);
-        return Lists.newArrayList();
-    }
-
-    @Override
-    public void deleteRecord(DataIdentifier identifier) throws DataStoreException {
-        if (dataStore instanceof MultiDataStoreAware) {
-            ((MultiDataStoreAware) dataStore).deleteRecord(identifier);
-        }
-    }
-}
+/*
+ * 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.blob.datastore;
+
+import java.io.File;
+import java.io.FileInputStream;
+import java.io.IOException;
+import java.io.InputStream;
+import java.util.Iterator;
+import java.util.List;
+
+import org.apache.commons.io.IOUtils;
+import org.apache.jackrabbit.core.data.Backend;
+import org.apache.jackrabbit.core.data.CachingDataStore;
+import org.apache.jackrabbit.core.data.DataIdentifier;
+import org.apache.jackrabbit.core.data.DataStore;
+import org.apache.jackrabbit.core.data.DataStoreException;
+import org.apache.jackrabbit.core.data.MultiDataStoreAware;
+
+import com.google.common.collect.Lists;
+
+/**
+ * {@link Backend} wrapper over Jackrabbit {@link DataStore} which enables using
+ * a {@link CachingDataStore} for local file caching.
+ */
+public class DataStoreWrapperBackend implements Backend {
+
+    /** The data store being wrapped. */
+    private DataStore dataStore;
+
+    /**
+     * Instantiates a new data store wrapper backend.
+     * 
+     * @param dataStore
+     *            the data store
+     */
+    public DataStoreWrapperBackend(DataStore dataStore) {
+        this.dataStore = dataStore;
+    }
+
+    @Override
+    public void init(CachingDataStore store, String homeDir, String config) throws DataStoreException {
+    }
+
+    @Override
+    public InputStream read(DataIdentifier identifier) throws DataStoreException {
+        return dataStore.getRecordIfStored(identifier).getStream();
+    }
+
+    @Override
+    public long getLength(DataIdentifier identifier) throws DataStoreException {
+        return dataStore.getRecord(identifier).getLength();
+    }
+
+    @Override
+    public long getLastModified(DataIdentifier identifier) throws DataStoreException {
+        return dataStore.getRecord(identifier).getLastModified();
+    }
+
+    @Override
+    public void write(DataIdentifier identifier, File file) throws DataStoreException {
+        InputStream stream = null;
+        try {
+            stream = new FileInputStream(file);
+            dataStore.addRecord(stream);
+        } catch (IOException io) {
+            throw new DataStoreException("Error retrieving stream from : " + file.getAbsolutePath());
+        } finally {
+            IOUtils.closeQuietly(stream);
+        }
+    }
+
+    @Override
+    public Iterator<DataIdentifier> getAllIdentifiers() throws DataStoreException {
+        return dataStore.getAllIdentifiers();
+    }
+
+    @Override
+    public void touch(DataIdentifier identifier, long minModifiedDate) throws DataStoreException {
+        // currently no-op
+    }
+
+    @Override
+    public boolean exists(DataIdentifier identifier) throws DataStoreException {
+        return (dataStore.getRecordIfStored(identifier) != null);
+    }
+
+    @Override
+    public void close() throws DataStoreException {
+        dataStore.close();
+    }
+
+    @Override
+    public List<DataIdentifier> deleteAllOlderThan(long timestamp) throws DataStoreException {
+        dataStore.deleteAllOlderThan(timestamp);
+        return Lists.newArrayList();
+    }
+
+    @Override
+    public void deleteRecord(DataIdentifier identifier) throws DataStoreException {
+        if (dataStore instanceof MultiDataStoreAware) {
+            ((MultiDataStoreAware) dataStore).deleteRecord(identifier);
+        }
+    }
+}

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/blob/datastore/DataStoreWrapperBackend.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/commit/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/identifier/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/index/aggregate/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/index/nodetype/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/index/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/index/property/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/index/reference/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/memory/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/name/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/nodetype/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/nodetype/write/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/observation/filter/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/observation/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/value/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/plugins/version/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/query/SelectorExecutionPlan.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/query/fulltext/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/security/authentication/token/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/security/authentication/user/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/commit/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/lifecycle/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/query/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/security/authentication/callback/WhiteboardCallback.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/security/authentication/callback/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/security/authentication/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/security/authentication/token/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/security/authorization/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/security/authorization/permission/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/security/authorization/restriction/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/security/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/security/principal/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/security/privilege/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/security/user/action/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/security/user/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/security/user/util/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/state/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/whiteboard/CompositeRegistration.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/whiteboard/WhiteboardAware.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/whiteboard/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/spi/xml/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/stats/RepositoryStats.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/stats/StatisticManager.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/main/java/org/apache/jackrabbit/oak/util/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/cache/ConcurrentTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/MongoBlobGCTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/CloudStoreUtils.java
URL: http://svn.apache.org/viewvc/jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/CloudStoreUtils.java?rev=1568240&r1=1568239&r2=1568240&view=diff
==============================================================================
--- jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/CloudStoreUtils.java (original)
+++ jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/CloudStoreUtils.java Fri Feb 14 11:21:31 2014
@@ -1,43 +1,43 @@
-/*
- * 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.document.blob.cloud;
-
-import org.apache.jackrabbit.mk.blobs.AbstractBlobStore;
-import org.apache.jackrabbit.oak.plugins.blob.BlobStoreConfiguration;
-import org.apache.jackrabbit.oak.plugins.blob.BlobStoreHelper;
-import org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore;
-
-/**
- * Helper class for retrieving the appropriate blobStore instance
- */
-public class CloudStoreUtils {
-
-    /**
-     * Gets the blob store.
-     * 
-     * @return the blob store
-     * @throws Exception
-     *             the exception
-     */
-    public static AbstractBlobStore getBlobStore() throws Exception {
-        BlobStoreConfiguration config =
-                BlobStoreConfiguration.newInstance().loadFromSystemProps();
-        config.addProperty(
-                BlobStoreConfiguration.PROP_BLOB_STORE_PROVIDER, CloudBlobStore.class.getName());
-        return (AbstractBlobStore) BlobStoreHelper.create(config).orNull();
-    }
+/*
+ * 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.document.blob.cloud;
+
+import org.apache.jackrabbit.mk.blobs.AbstractBlobStore;
+import org.apache.jackrabbit.oak.plugins.blob.BlobStoreConfiguration;
+import org.apache.jackrabbit.oak.plugins.blob.BlobStoreHelper;
+import org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore;
+
+/**
+ * Helper class for retrieving the appropriate blobStore instance
+ */
+public class CloudStoreUtils {
+
+    /**
+     * Gets the blob store.
+     * 
+     * @return the blob store
+     * @throws Exception
+     *             the exception
+     */
+    public static AbstractBlobStore getBlobStore() throws Exception {
+        BlobStoreConfiguration config =
+                BlobStoreConfiguration.newInstance().loadFromSystemProps();
+        config.addProperty(
+                BlobStoreConfiguration.PROP_BLOB_STORE_PROVIDER, CloudBlobStore.class.getName());
+        return (AbstractBlobStore) BlobStoreHelper.create(config).orNull();
+    }
 }
\ No newline at end of file

Propchange: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/CloudStoreUtils.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/DocumentMKCloudGetLengthTest.java
URL: http://svn.apache.org/viewvc/jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/DocumentMKCloudGetLengthTest.java?rev=1568240&r1=1568239&r2=1568240&view=diff
==============================================================================
--- jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/DocumentMKCloudGetLengthTest.java (original)
+++ jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/DocumentMKCloudGetLengthTest.java Fri Feb 14 11:21:31 2014
@@ -1,61 +1,61 @@
-/*
- * 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.document.blob.cloud;
-
-import org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore;
-import org.apache.jackrabbit.oak.plugins.document.DocumentMK;
-import org.apache.jackrabbit.oak.plugins.document.MongoUtils;
-import org.apache.jackrabbit.oak.plugins.document.blob.DocumentMKGetLengthTest;
-import org.junit.After;
-import org.junit.Assume;
-import org.junit.Before;
-import org.junit.BeforeClass;
-
-/**
- * Tests for {@code DocumentMK#getLength(String)} with {@link CloudBlobStore}
- */
-public class DocumentMKCloudGetLengthTest extends DocumentMKGetLengthTest {
-    @BeforeClass
-    public static void setUpBeforeClass() throws Exception {
-        try {
-            Assume.assumeNotNull(CloudStoreUtils.getBlobStore());
-        } catch (Exception e) {
-            Assume.assumeNoException(e);
-        }
-    }
-
-    @Override
-    @Before
-    public void setUpConnection() throws Exception {
-        mongoConnection = MongoUtils.getConnection();
-        MongoUtils.dropCollections(mongoConnection.getDB());
-        mk = new DocumentMK.Builder().setMongoDB(mongoConnection.getDB())
-                .setBlobStore(CloudStoreUtils.getBlobStore()).open();
-    }
-
-    @Override
-    @After
-    public void tearDownConnection() throws Exception {
-        ((CloudBlobStore) mk.getNodeStore().getBlobStore()).deleteBucket();
-        mk.dispose();
-        // the db might already be closed
-        mongoConnection.close();
-        mongoConnection = MongoUtils.getConnection();
-        MongoUtils.dropCollections(mongoConnection.getDB());
-        mongoConnection.close();
-    }
+/*
+ * 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.document.blob.cloud;
+
+import org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore;
+import org.apache.jackrabbit.oak.plugins.document.DocumentMK;
+import org.apache.jackrabbit.oak.plugins.document.MongoUtils;
+import org.apache.jackrabbit.oak.plugins.document.blob.DocumentMKGetLengthTest;
+import org.junit.After;
+import org.junit.Assume;
+import org.junit.Before;
+import org.junit.BeforeClass;
+
+/**
+ * Tests for {@code DocumentMK#getLength(String)} with {@link CloudBlobStore}
+ */
+public class DocumentMKCloudGetLengthTest extends DocumentMKGetLengthTest {
+    @BeforeClass
+    public static void setUpBeforeClass() throws Exception {
+        try {
+            Assume.assumeNotNull(CloudStoreUtils.getBlobStore());
+        } catch (Exception e) {
+            Assume.assumeNoException(e);
+        }
+    }
+
+    @Override
+    @Before
+    public void setUpConnection() throws Exception {
+        mongoConnection = MongoUtils.getConnection();
+        MongoUtils.dropCollections(mongoConnection.getDB());
+        mk = new DocumentMK.Builder().setMongoDB(mongoConnection.getDB())
+                .setBlobStore(CloudStoreUtils.getBlobStore()).open();
+    }
+
+    @Override
+    @After
+    public void tearDownConnection() throws Exception {
+        ((CloudBlobStore) mk.getNodeStore().getBlobStore()).deleteBucket();
+        mk.dispose();
+        // the db might already be closed
+        mongoConnection.close();
+        mongoConnection = MongoUtils.getConnection();
+        MongoUtils.dropCollections(mongoConnection.getDB());
+        mongoConnection.close();
+    }
 }
\ No newline at end of file

Propchange: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/DocumentMKCloudGetLengthTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/DocumentMKCloudReadTest.java
URL: http://svn.apache.org/viewvc/jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/DocumentMKCloudReadTest.java?rev=1568240&r1=1568239&r2=1568240&view=diff
==============================================================================
--- jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/DocumentMKCloudReadTest.java (original)
+++ jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/DocumentMKCloudReadTest.java Fri Feb 14 11:21:31 2014
@@ -1,62 +1,62 @@
-/*
- * 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.document.blob.cloud;
-
-import org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore;
-import org.apache.jackrabbit.oak.plugins.document.DocumentMK;
-import org.apache.jackrabbit.oak.plugins.document.MongoUtils;
-import org.apache.jackrabbit.oak.plugins.document.blob.DocumentMKReadTest;
-import org.junit.After;
-import org.junit.Assume;
-import org.junit.Before;
-import org.junit.BeforeClass;
-
-/**
- * Tests for {@code DocumentMK#read(String, long, byte[], int, int)} with
- * {@link CloudBlobStore}
- */
-public class DocumentMKCloudReadTest extends DocumentMKReadTest {
-    @BeforeClass
-    public static void setUpBeforeClass() throws Exception {
-        try {
-            Assume.assumeNotNull(CloudStoreUtils.getBlobStore());
-        } catch (Exception e) {
-            Assume.assumeNoException(e);
-        }
-    }
-
-    @Override
-    @Before
-    public void setUpConnection() throws Exception {
-        mongoConnection = MongoUtils.getConnection();
-        MongoUtils.dropCollections(mongoConnection.getDB());
-        mk = new DocumentMK.Builder().setMongoDB(mongoConnection.getDB())
-                .setBlobStore(CloudStoreUtils.getBlobStore()).open();
-    }
-
-    @Override
-    @After
-    public void tearDownConnection() throws Exception {
-        ((CloudBlobStore) mk.getNodeStore().getBlobStore()).deleteBucket();
-        mk.dispose();
-        // the db might already be closed
-        mongoConnection.close();
-        mongoConnection = MongoUtils.getConnection();
-        MongoUtils.dropCollections(mongoConnection.getDB());
-        mongoConnection.close();
-    }
+/*
+ * 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.document.blob.cloud;
+
+import org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore;
+import org.apache.jackrabbit.oak.plugins.document.DocumentMK;
+import org.apache.jackrabbit.oak.plugins.document.MongoUtils;
+import org.apache.jackrabbit.oak.plugins.document.blob.DocumentMKReadTest;
+import org.junit.After;
+import org.junit.Assume;
+import org.junit.Before;
+import org.junit.BeforeClass;
+
+/**
+ * Tests for {@code DocumentMK#read(String, long, byte[], int, int)} with
+ * {@link CloudBlobStore}
+ */
+public class DocumentMKCloudReadTest extends DocumentMKReadTest {
+    @BeforeClass
+    public static void setUpBeforeClass() throws Exception {
+        try {
+            Assume.assumeNotNull(CloudStoreUtils.getBlobStore());
+        } catch (Exception e) {
+            Assume.assumeNoException(e);
+        }
+    }
+
+    @Override
+    @Before
+    public void setUpConnection() throws Exception {
+        mongoConnection = MongoUtils.getConnection();
+        MongoUtils.dropCollections(mongoConnection.getDB());
+        mk = new DocumentMK.Builder().setMongoDB(mongoConnection.getDB())
+                .setBlobStore(CloudStoreUtils.getBlobStore()).open();
+    }
+
+    @Override
+    @After
+    public void tearDownConnection() throws Exception {
+        ((CloudBlobStore) mk.getNodeStore().getBlobStore()).deleteBucket();
+        mk.dispose();
+        // the db might already be closed
+        mongoConnection.close();
+        mongoConnection = MongoUtils.getConnection();
+        MongoUtils.dropCollections(mongoConnection.getDB());
+        mongoConnection.close();
+    }
 }
\ No newline at end of file

Propchange: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/DocumentMKCloudReadTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/DocumentMKCloudWriteTest.java
URL: http://svn.apache.org/viewvc/jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/DocumentMKCloudWriteTest.java?rev=1568240&r1=1568239&r2=1568240&view=diff
==============================================================================
--- jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/DocumentMKCloudWriteTest.java (original)
+++ jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/DocumentMKCloudWriteTest.java Fri Feb 14 11:21:31 2014
@@ -1,62 +1,62 @@
-/*
- * 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.document.blob.cloud;
-
-import org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore;
-import org.apache.jackrabbit.oak.plugins.document.DocumentMK;
-import org.apache.jackrabbit.oak.plugins.document.MongoUtils;
-import org.apache.jackrabbit.oak.plugins.document.blob.DocumentMKWriteTest;
-import org.junit.After;
-import org.junit.Assume;
-import org.junit.Before;
-import org.junit.BeforeClass;
-
-/**
- * Tests for {@code DocumentMK#write(java.io.InputStream)} with
- * {@link CloudBlobStore}
- */
-public class DocumentMKCloudWriteTest extends DocumentMKWriteTest {
-    @BeforeClass
-    public static void setUpBeforeClass() throws Exception {
-        try {
-            Assume.assumeNotNull(CloudStoreUtils.getBlobStore());
-        } catch (Exception e) {
-            Assume.assumeNoException(e);
-        }
-    }
-
-    @Override
-    @Before
-    public void setUpConnection() throws Exception {
-        mongoConnection = MongoUtils.getConnection();
-        MongoUtils.dropCollections(mongoConnection.getDB());
-        mk = new DocumentMK.Builder().setMongoDB(mongoConnection.getDB())
-                .setBlobStore(CloudStoreUtils.getBlobStore()).open();
-    }
-
-    @Override
-    @After
-    public void tearDownConnection() throws Exception {
-        ((CloudBlobStore) mk.getNodeStore().getBlobStore()).deleteBucket();
-        mk.dispose();
-        // the db might already be closed
-        mongoConnection.close();
-        mongoConnection = MongoUtils.getConnection();
-        MongoUtils.dropCollections(mongoConnection.getDB());
-        mongoConnection.close();
-    }
+/*
+ * 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.document.blob.cloud;
+
+import org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore;
+import org.apache.jackrabbit.oak.plugins.document.DocumentMK;
+import org.apache.jackrabbit.oak.plugins.document.MongoUtils;
+import org.apache.jackrabbit.oak.plugins.document.blob.DocumentMKWriteTest;
+import org.junit.After;
+import org.junit.Assume;
+import org.junit.Before;
+import org.junit.BeforeClass;
+
+/**
+ * Tests for {@code DocumentMK#write(java.io.InputStream)} with
+ * {@link CloudBlobStore}
+ */
+public class DocumentMKCloudWriteTest extends DocumentMKWriteTest {
+    @BeforeClass
+    public static void setUpBeforeClass() throws Exception {
+        try {
+            Assume.assumeNotNull(CloudStoreUtils.getBlobStore());
+        } catch (Exception e) {
+            Assume.assumeNoException(e);
+        }
+    }
+
+    @Override
+    @Before
+    public void setUpConnection() throws Exception {
+        mongoConnection = MongoUtils.getConnection();
+        MongoUtils.dropCollections(mongoConnection.getDB());
+        mk = new DocumentMK.Builder().setMongoDB(mongoConnection.getDB())
+                .setBlobStore(CloudStoreUtils.getBlobStore()).open();
+    }
+
+    @Override
+    @After
+    public void tearDownConnection() throws Exception {
+        ((CloudBlobStore) mk.getNodeStore().getBlobStore()).deleteBucket();
+        mk.dispose();
+        // the db might already be closed
+        mongoConnection.close();
+        mongoConnection = MongoUtils.getConnection();
+        MongoUtils.dropCollections(mongoConnection.getDB());
+        mongoConnection.close();
+    }
 }
\ No newline at end of file

Propchange: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/DocumentMKCloudWriteTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/MongoCloudBlobGCTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/MongoCloudBlobStoreTest.java
URL: http://svn.apache.org/viewvc/jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/MongoCloudBlobStoreTest.java?rev=1568240&r1=1568239&r2=1568240&view=diff
==============================================================================
--- jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/MongoCloudBlobStoreTest.java (original)
+++ jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/MongoCloudBlobStoreTest.java Fri Feb 14 11:21:31 2014
@@ -1,57 +1,57 @@
-/*
- * 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.document.blob.cloud;
-
-import org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore;
-import org.apache.jackrabbit.oak.plugins.document.blob.AbstractBlobStoreTest;
-import org.junit.After;
-import org.junit.Assume;
-import org.junit.Before;
-import org.junit.BeforeClass;
-import org.junit.Test;
-
-/**
- * Tests the {@link CloudBlobStore} implementation.
- */
-public class MongoCloudBlobStoreTest extends AbstractBlobStoreTest {
-    @BeforeClass
-    public static void setUpBeforeClass() throws Exception {
-        try {
-            Assume.assumeNotNull(CloudStoreUtils.getBlobStore());
-        } catch (Exception e) {
-            Assume.assumeNoException(e);
-        }
-    }
-
-    @Before
-    @Override
-    public void setUp() throws Exception {
-        store = CloudStoreUtils.getBlobStore();
-    }
-
-    @Override
-    @After
-    public void tearDown() throws Exception {
-        ((CloudBlobStore) store).deleteBucket();
-        super.tearDown();
-    }
-
-    @Override
-    @Test
-    public void testGarbageCollection() throws Exception {
-    }
+/*
+ * 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.document.blob.cloud;
+
+import org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore;
+import org.apache.jackrabbit.oak.plugins.document.blob.AbstractBlobStoreTest;
+import org.junit.After;
+import org.junit.Assume;
+import org.junit.Before;
+import org.junit.BeforeClass;
+import org.junit.Test;
+
+/**
+ * Tests the {@link CloudBlobStore} implementation.
+ */
+public class MongoCloudBlobStoreTest extends AbstractBlobStoreTest {
+    @BeforeClass
+    public static void setUpBeforeClass() throws Exception {
+        try {
+            Assume.assumeNotNull(CloudStoreUtils.getBlobStore());
+        } catch (Exception e) {
+            Assume.assumeNoException(e);
+        }
+    }
+
+    @Before
+    @Override
+    public void setUp() throws Exception {
+        store = CloudStoreUtils.getBlobStore();
+    }
+
+    @Override
+    @After
+    public void tearDown() throws Exception {
+        ((CloudBlobStore) store).deleteBucket();
+        super.tearDown();
+    }
+
+    @Override
+    @Test
+    public void testGarbageCollection() throws Exception {
+    }
 }
\ No newline at end of file

Propchange: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/cloud/MongoCloudBlobStoreTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DataStoreUtils.java
URL: http://svn.apache.org/viewvc/jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DataStoreUtils.java?rev=1568240&r1=1568239&r2=1568240&view=diff
==============================================================================
--- jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DataStoreUtils.java (original)
+++ jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DataStoreUtils.java Fri Feb 14 11:21:31 2014
@@ -1,47 +1,47 @@
-/*
- * 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.document.blob.ds;
-
-import org.apache.jackrabbit.core.data.DataStore;
-import org.apache.jackrabbit.oak.plugins.blob.BlobStoreConfiguration;
-import org.apache.jackrabbit.oak.plugins.blob.BlobStoreHelper;
-import org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore;
-import org.apache.jackrabbit.oak.plugins.document.AbstractMongoConnectionTest;
-
-/**
- * Helper for retrieving the {@link DataStoreBlobStore} instantiated with the
- * appropriate {@link DataStore}.
- */
-public class DataStoreUtils extends AbstractMongoConnectionTest {
-    public static final String PATH = "./target/repository/";
-
-    /**
-     * Gets the blob store.
-     * 
-     * @return the blob store
-     * @throws Exception
-     *             the exception
-     */
-    public static DataStoreBlobStore getBlobStore() throws Exception {
-        BlobStoreConfiguration config =
-                BlobStoreConfiguration.newInstance().loadFromSystemProps();
-        config.addProperty(
-                BlobStoreConfiguration.PROP_BLOB_STORE_PROVIDER, DataStoreBlobStore.class.getName());
-        config.addProperty("path", PATH + "datastore");
-        return (DataStoreBlobStore) BlobStoreHelper.create(config).orNull();
-    }
-}
+/*
+ * 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.document.blob.ds;
+
+import org.apache.jackrabbit.core.data.DataStore;
+import org.apache.jackrabbit.oak.plugins.blob.BlobStoreConfiguration;
+import org.apache.jackrabbit.oak.plugins.blob.BlobStoreHelper;
+import org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore;
+import org.apache.jackrabbit.oak.plugins.document.AbstractMongoConnectionTest;
+
+/**
+ * Helper for retrieving the {@link DataStoreBlobStore} instantiated with the
+ * appropriate {@link DataStore}.
+ */
+public class DataStoreUtils extends AbstractMongoConnectionTest {
+    public static final String PATH = "./target/repository/";
+
+    /**
+     * Gets the blob store.
+     * 
+     * @return the blob store
+     * @throws Exception
+     *             the exception
+     */
+    public static DataStoreBlobStore getBlobStore() throws Exception {
+        BlobStoreConfiguration config =
+                BlobStoreConfiguration.newInstance().loadFromSystemProps();
+        config.addProperty(
+                BlobStoreConfiguration.PROP_BLOB_STORE_PROVIDER, DataStoreBlobStore.class.getName());
+        config.addProperty("path", PATH + "datastore");
+        return (DataStoreBlobStore) BlobStoreHelper.create(config).orNull();
+    }
+}

Propchange: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DataStoreUtils.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DocumentMKDataStoreGetLengthTest.java
URL: http://svn.apache.org/viewvc/jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DocumentMKDataStoreGetLengthTest.java?rev=1568240&r1=1568239&r2=1568240&view=diff
==============================================================================
--- jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DocumentMKDataStoreGetLengthTest.java (original)
+++ jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DocumentMKDataStoreGetLengthTest.java Fri Feb 14 11:21:31 2014
@@ -1,63 +1,63 @@
-/*
- * 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.document.blob.ds;
-
-import java.io.File;
-
-import org.apache.commons.io.FileUtils;
-import org.apache.jackrabbit.oak.plugins.document.DocumentMK;
-import org.apache.jackrabbit.oak.plugins.document.MongoUtils;
-import org.apache.jackrabbit.oak.plugins.document.blob.DocumentMKGetLengthTest;
-import org.junit.After;
-import org.junit.Assume;
-import org.junit.Before;
-import org.junit.BeforeClass;
-
-/**
- * Tests for {@code DocumentMK#getLength(String)} using {@link DataStore}
- */
-public class DocumentMKDataStoreGetLengthTest extends DocumentMKGetLengthTest {
-    @BeforeClass
-    public static void setUpBeforeClass() throws Exception {
-        try {
-            Assume.assumeNotNull(DataStoreUtils.getBlobStore());
-        } catch (Exception e) {
-            Assume.assumeNoException(e);
-        }
-    }
-
-    @Override
-    @Before
-    public void setUpConnection() throws Exception {
-        mongoConnection = MongoUtils.getConnection();
-        MongoUtils.dropCollections(mongoConnection.getDB());
-        mk = new DocumentMK.Builder().setMongoDB(mongoConnection.getDB())
-                .setBlobStore(DataStoreUtils.getBlobStore()).open();
-    }
-
-    @Override
-    @After
-    public void tearDownConnection() throws Exception {
-        FileUtils.deleteDirectory(new File(DataStoreUtils.PATH));
-        mk.dispose();
-        // the db might already be closed
-        mongoConnection.close();
-        mongoConnection = MongoUtils.getConnection();
-        MongoUtils.dropCollections(mongoConnection.getDB());
-        mongoConnection.close();
-    }
+/*
+ * 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.document.blob.ds;
+
+import java.io.File;
+
+import org.apache.commons.io.FileUtils;
+import org.apache.jackrabbit.oak.plugins.document.DocumentMK;
+import org.apache.jackrabbit.oak.plugins.document.MongoUtils;
+import org.apache.jackrabbit.oak.plugins.document.blob.DocumentMKGetLengthTest;
+import org.junit.After;
+import org.junit.Assume;
+import org.junit.Before;
+import org.junit.BeforeClass;
+
+/**
+ * Tests for {@code DocumentMK#getLength(String)} using {@link DataStore}
+ */
+public class DocumentMKDataStoreGetLengthTest extends DocumentMKGetLengthTest {
+    @BeforeClass
+    public static void setUpBeforeClass() throws Exception {
+        try {
+            Assume.assumeNotNull(DataStoreUtils.getBlobStore());
+        } catch (Exception e) {
+            Assume.assumeNoException(e);
+        }
+    }
+
+    @Override
+    @Before
+    public void setUpConnection() throws Exception {
+        mongoConnection = MongoUtils.getConnection();
+        MongoUtils.dropCollections(mongoConnection.getDB());
+        mk = new DocumentMK.Builder().setMongoDB(mongoConnection.getDB())
+                .setBlobStore(DataStoreUtils.getBlobStore()).open();
+    }
+
+    @Override
+    @After
+    public void tearDownConnection() throws Exception {
+        FileUtils.deleteDirectory(new File(DataStoreUtils.PATH));
+        mk.dispose();
+        // the db might already be closed
+        mongoConnection.close();
+        mongoConnection = MongoUtils.getConnection();
+        MongoUtils.dropCollections(mongoConnection.getDB());
+        mongoConnection.close();
+    }
 }
\ No newline at end of file

Propchange: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DocumentMKDataStoreGetLengthTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DocumentMKDataStoreReadTest.java
URL: http://svn.apache.org/viewvc/jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DocumentMKDataStoreReadTest.java?rev=1568240&r1=1568239&r2=1568240&view=diff
==============================================================================
--- jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DocumentMKDataStoreReadTest.java (original)
+++ jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DocumentMKDataStoreReadTest.java Fri Feb 14 11:21:31 2014
@@ -1,64 +1,64 @@
-/*
- * 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.document.blob.ds;
-
-import java.io.File;
-
-import org.apache.commons.io.FileUtils;
-import org.apache.jackrabbit.oak.plugins.document.DocumentMK;
-import org.apache.jackrabbit.oak.plugins.document.MongoUtils;
-import org.apache.jackrabbit.oak.plugins.document.blob.DocumentMKReadTest;
-import org.junit.After;
-import org.junit.Assume;
-import org.junit.Before;
-import org.junit.BeforeClass;
-
-/**
- * Tests for {@code DocumentMK#read(String, long, byte[], int, int)} using
- * {@link DataStore}
- */
-public class DocumentMKDataStoreReadTest extends DocumentMKReadTest {
-    @BeforeClass
-    public static void setUpBeforeClass() throws Exception {
-        try {
-            Assume.assumeNotNull(DataStoreUtils.getBlobStore());
-        } catch (Exception e) {
-            Assume.assumeNoException(e);
-        }
-    }
-
-    @Override
-    @Before
-    public void setUpConnection() throws Exception {
-        mongoConnection = MongoUtils.getConnection();
-        MongoUtils.dropCollections(mongoConnection.getDB());
-        mk = new DocumentMK.Builder().setMongoDB(mongoConnection.getDB())
-                .setBlobStore(DataStoreUtils.getBlobStore()).open();
-    }
-
-    @Override
-    @After
-    public void tearDownConnection() throws Exception {
-        FileUtils.deleteDirectory(new File(DataStoreUtils.PATH));
-        mk.dispose();
-        // the db might already be closed
-        mongoConnection.close();
-        mongoConnection = MongoUtils.getConnection();
-        MongoUtils.dropCollections(mongoConnection.getDB());
-        mongoConnection.close();
-    }
+/*
+ * 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.document.blob.ds;
+
+import java.io.File;
+
+import org.apache.commons.io.FileUtils;
+import org.apache.jackrabbit.oak.plugins.document.DocumentMK;
+import org.apache.jackrabbit.oak.plugins.document.MongoUtils;
+import org.apache.jackrabbit.oak.plugins.document.blob.DocumentMKReadTest;
+import org.junit.After;
+import org.junit.Assume;
+import org.junit.Before;
+import org.junit.BeforeClass;
+
+/**
+ * Tests for {@code DocumentMK#read(String, long, byte[], int, int)} using
+ * {@link DataStore}
+ */
+public class DocumentMKDataStoreReadTest extends DocumentMKReadTest {
+    @BeforeClass
+    public static void setUpBeforeClass() throws Exception {
+        try {
+            Assume.assumeNotNull(DataStoreUtils.getBlobStore());
+        } catch (Exception e) {
+            Assume.assumeNoException(e);
+        }
+    }
+
+    @Override
+    @Before
+    public void setUpConnection() throws Exception {
+        mongoConnection = MongoUtils.getConnection();
+        MongoUtils.dropCollections(mongoConnection.getDB());
+        mk = new DocumentMK.Builder().setMongoDB(mongoConnection.getDB())
+                .setBlobStore(DataStoreUtils.getBlobStore()).open();
+    }
+
+    @Override
+    @After
+    public void tearDownConnection() throws Exception {
+        FileUtils.deleteDirectory(new File(DataStoreUtils.PATH));
+        mk.dispose();
+        // the db might already be closed
+        mongoConnection.close();
+        mongoConnection = MongoUtils.getConnection();
+        MongoUtils.dropCollections(mongoConnection.getDB());
+        mongoConnection.close();
+    }
 }
\ No newline at end of file

Propchange: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DocumentMKDataStoreReadTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DocumentMKDataStoreWriteTest.java
URL: http://svn.apache.org/viewvc/jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DocumentMKDataStoreWriteTest.java?rev=1568240&r1=1568239&r2=1568240&view=diff
==============================================================================
--- jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DocumentMKDataStoreWriteTest.java (original)
+++ jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DocumentMKDataStoreWriteTest.java Fri Feb 14 11:21:31 2014
@@ -1,64 +1,64 @@
-/*
- * 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.document.blob.ds;
-
-import java.io.File;
-
-import org.apache.commons.io.FileUtils;
-import org.apache.jackrabbit.oak.plugins.document.DocumentMK;
-import org.apache.jackrabbit.oak.plugins.document.MongoUtils;
-import org.apache.jackrabbit.oak.plugins.document.blob.DocumentMKWriteTest;
-import org.junit.After;
-import org.junit.Assume;
-import org.junit.Before;
-import org.junit.BeforeClass;
-
-/**
- * Tests for {@code DocumentMK#write(java.io.InputStream)} using
- * {@link DataStore}
- */
-public class DocumentMKDataStoreWriteTest extends DocumentMKWriteTest {
-    @BeforeClass
-    public static void setUpBeforeClass() throws Exception {
-        try {
-            Assume.assumeNotNull(DataStoreUtils.getBlobStore());
-        } catch (Exception e) {
-            Assume.assumeNoException(e);
-        }
-    }
-
-    @Override
-    @Before
-    public void setUpConnection() throws Exception {
-        mongoConnection = MongoUtils.getConnection();
-        MongoUtils.dropCollections(mongoConnection.getDB());
-        mk = new DocumentMK.Builder().setMongoDB(mongoConnection.getDB())
-                .setBlobStore(DataStoreUtils.getBlobStore()).open();
-    }
-
-    @Override
-    @After
-    public void tearDownConnection() throws Exception {
-        FileUtils.deleteDirectory(new File(DataStoreUtils.PATH));
-        mk.dispose();
-        // the db might already be closed
-        mongoConnection.close();
-        mongoConnection = MongoUtils.getConnection();
-        MongoUtils.dropCollections(mongoConnection.getDB());
-        mongoConnection.close();
-    }
+/*
+ * 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.document.blob.ds;
+
+import java.io.File;
+
+import org.apache.commons.io.FileUtils;
+import org.apache.jackrabbit.oak.plugins.document.DocumentMK;
+import org.apache.jackrabbit.oak.plugins.document.MongoUtils;
+import org.apache.jackrabbit.oak.plugins.document.blob.DocumentMKWriteTest;
+import org.junit.After;
+import org.junit.Assume;
+import org.junit.Before;
+import org.junit.BeforeClass;
+
+/**
+ * Tests for {@code DocumentMK#write(java.io.InputStream)} using
+ * {@link DataStore}
+ */
+public class DocumentMKDataStoreWriteTest extends DocumentMKWriteTest {
+    @BeforeClass
+    public static void setUpBeforeClass() throws Exception {
+        try {
+            Assume.assumeNotNull(DataStoreUtils.getBlobStore());
+        } catch (Exception e) {
+            Assume.assumeNoException(e);
+        }
+    }
+
+    @Override
+    @Before
+    public void setUpConnection() throws Exception {
+        mongoConnection = MongoUtils.getConnection();
+        MongoUtils.dropCollections(mongoConnection.getDB());
+        mk = new DocumentMK.Builder().setMongoDB(mongoConnection.getDB())
+                .setBlobStore(DataStoreUtils.getBlobStore()).open();
+    }
+
+    @Override
+    @After
+    public void tearDownConnection() throws Exception {
+        FileUtils.deleteDirectory(new File(DataStoreUtils.PATH));
+        mk.dispose();
+        // the db might already be closed
+        mongoConnection.close();
+        mongoConnection = MongoUtils.getConnection();
+        MongoUtils.dropCollections(mongoConnection.getDB());
+        mongoConnection.close();
+    }
 }
\ No newline at end of file

Propchange: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/DocumentMKDataStoreWriteTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/MongoDataStoreBlobGCTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/MongoDataStoreBlobStoreTest.java
URL: http://svn.apache.org/viewvc/jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/MongoDataStoreBlobStoreTest.java?rev=1568240&r1=1568239&r2=1568240&view=diff
==============================================================================
--- jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/MongoDataStoreBlobStoreTest.java (original)
+++ jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/MongoDataStoreBlobStoreTest.java Fri Feb 14 11:21:31 2014
@@ -1,65 +1,65 @@
-/*
- * 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.document.blob.ds;
-
-import java.io.File;
-
-import org.apache.commons.io.FileUtils;
-import org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore;
-import org.apache.jackrabbit.oak.plugins.document.blob.AbstractBlobStoreTest;
-import org.junit.After;
-import org.junit.Assume;
-import org.junit.Before;
-import org.junit.BeforeClass;
-import org.junit.Test;
-
-/**
- * Tests the {@link DataStoreBlobStore} implementation.
- */
-public class MongoDataStoreBlobStoreTest extends AbstractBlobStoreTest {
-    @BeforeClass
-    public static void setUpBeforeClass() throws Exception {
-        try {
-            Assume.assumeNotNull(DataStoreUtils.getBlobStore());
-        } catch (Exception e) {
-            Assume.assumeNoException(e);
-        }
-    }
-
-    @Before
-    @Override
-    public void setUp() throws Exception {
-        store = DataStoreUtils.getBlobStore();
-    }
-
-    @Override
-    @Test
-    public void testCombinedIdentifier() throws Exception {
-    }
-
-    @Override
-    @Test
-    public void testGarbageCollection() throws Exception {
-    }
-
-    @After
-    @Override
-    public void tearDown() throws Exception {
-        FileUtils.deleteDirectory(new File(DataStoreUtils.PATH));
-        super.tearDown();
-    }
+/*
+ * 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.document.blob.ds;
+
+import java.io.File;
+
+import org.apache.commons.io.FileUtils;
+import org.apache.jackrabbit.oak.plugins.blob.datastore.DataStoreBlobStore;
+import org.apache.jackrabbit.oak.plugins.document.blob.AbstractBlobStoreTest;
+import org.junit.After;
+import org.junit.Assume;
+import org.junit.Before;
+import org.junit.BeforeClass;
+import org.junit.Test;
+
+/**
+ * Tests the {@link DataStoreBlobStore} implementation.
+ */
+public class MongoDataStoreBlobStoreTest extends AbstractBlobStoreTest {
+    @BeforeClass
+    public static void setUpBeforeClass() throws Exception {
+        try {
+            Assume.assumeNotNull(DataStoreUtils.getBlobStore());
+        } catch (Exception e) {
+            Assume.assumeNoException(e);
+        }
+    }
+
+    @Before
+    @Override
+    public void setUp() throws Exception {
+        store = DataStoreUtils.getBlobStore();
+    }
+
+    @Override
+    @Test
+    public void testCombinedIdentifier() throws Exception {
+    }
+
+    @Override
+    @Test
+    public void testGarbageCollection() throws Exception {
+    }
+
+    @After
+    @Override
+    public void tearDown() throws Exception {
+        FileUtils.deleteDirectory(new File(DataStoreUtils.PATH));
+        super.tearDown();
+    }
 }
\ No newline at end of file

Propchange: jackrabbit/oak/trunk/oak-core/src/test/java/org/apache/jackrabbit/oak/plugins/document/blob/ds/MongoDataStoreBlobStoreTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: jackrabbit/oak/trunk/oak-it/mk/src/test/java/org/apache/jackrabbit/mk/test/MongoCloudBlobMicroKernelFixture.java
URL: http://svn.apache.org/viewvc/jackrabbit/oak/trunk/oak-it/mk/src/test/java/org/apache/jackrabbit/mk/test/MongoCloudBlobMicroKernelFixture.java?rev=1568240&r1=1568239&r2=1568240&view=diff
==============================================================================
--- jackrabbit/oak/trunk/oak-it/mk/src/test/java/org/apache/jackrabbit/mk/test/MongoCloudBlobMicroKernelFixture.java (original)
+++ jackrabbit/oak/trunk/oak-it/mk/src/test/java/org/apache/jackrabbit/mk/test/MongoCloudBlobMicroKernelFixture.java Fri Feb 14 11:21:31 2014
@@ -1,78 +1,78 @@
-/*
- * 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.mk.test;
-
-import org.apache.jackrabbit.mk.api.MicroKernel;
-import org.apache.jackrabbit.mk.blobs.BlobStore;
-import org.apache.jackrabbit.oak.plugins.blob.BlobStoreConfiguration;
-import org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore;
-import org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStoreBuilder;
-import org.apache.jackrabbit.oak.plugins.document.Collection;
-import org.apache.jackrabbit.oak.plugins.document.DocumentMK;
-import org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobStore;
-import org.apache.jackrabbit.oak.plugins.document.util.MongoConnection;
-
-import com.mongodb.DB;
-
-/**
- * The Class MongoCloudBlobMicroKernelFixture.
- */
-public class MongoCloudBlobMicroKernelFixture extends BaseMongoMicroKernelFixture {
-
-    /** The blob store. */
-    private BlobStore blobStore;
-
-    /**
-     * Open connection.
-     * 
-     * @throws Exception
-     */
-    protected void openConnection() throws Exception {
-        if (blobStore == null) {
-            blobStore =
-                    CloudBlobStoreBuilder
-                            .newInstance()
-                            .build(
-                                    BlobStoreConfiguration.newInstance().loadFromSystemProps()).get();
-        }
-    }
-
-    @Override
-    protected BlobStore getBlobStore(com.mongodb.DB db) {
-        return blobStore;
-    }
-
-    @Override
-    public void setUpCluster(MicroKernel[] cluster) throws Exception {
-        MongoConnection connection = getMongoConnection();
-        openConnection();
-        DB db = connection.getDB();
-        dropCollections(db);
-
-        for (int i = 0; i < cluster.length; i++) {
-            cluster[i] = new DocumentMK.Builder().
-                    setMongoDB(db).setBlobStore(blobStore).setClusterId(i).open();
-        }
-    }
-
-    @Override
-    protected void dropCollections(DB db) {
-        db.getCollection(MongoBlobStore.COLLECTION_BLOBS).drop();
-        db.getCollection(Collection.NODES.toString()).drop();
-        ((CloudBlobStore) blobStore).deleteBucket();
-    }
-}
+/*
+ * 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.mk.test;
+
+import org.apache.jackrabbit.mk.api.MicroKernel;
+import org.apache.jackrabbit.mk.blobs.BlobStore;
+import org.apache.jackrabbit.oak.plugins.blob.BlobStoreConfiguration;
+import org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStore;
+import org.apache.jackrabbit.oak.plugins.blob.cloud.CloudBlobStoreBuilder;
+import org.apache.jackrabbit.oak.plugins.document.Collection;
+import org.apache.jackrabbit.oak.plugins.document.DocumentMK;
+import org.apache.jackrabbit.oak.plugins.document.mongo.MongoBlobStore;
+import org.apache.jackrabbit.oak.plugins.document.util.MongoConnection;
+
+import com.mongodb.DB;
+
+/**
+ * The Class MongoCloudBlobMicroKernelFixture.
+ */
+public class MongoCloudBlobMicroKernelFixture extends BaseMongoMicroKernelFixture {
+
+    /** The blob store. */
+    private BlobStore blobStore;
+
+    /**
+     * Open connection.
+     * 
+     * @throws Exception
+     */
+    protected void openConnection() throws Exception {
+        if (blobStore == null) {
+            blobStore =
+                    CloudBlobStoreBuilder
+                            .newInstance()
+                            .build(
+                                    BlobStoreConfiguration.newInstance().loadFromSystemProps()).get();
+        }
+    }
+
+    @Override
+    protected BlobStore getBlobStore(com.mongodb.DB db) {
+        return blobStore;
+    }
+
+    @Override
+    public void setUpCluster(MicroKernel[] cluster) throws Exception {
+        MongoConnection connection = getMongoConnection();
+        openConnection();
+        DB db = connection.getDB();
+        dropCollections(db);
+
+        for (int i = 0; i < cluster.length; i++) {
+            cluster[i] = new DocumentMK.Builder().
+                    setMongoDB(db).setBlobStore(blobStore).setClusterId(i).open();
+        }
+    }
+
+    @Override
+    protected void dropCollections(DB db) {
+        db.getCollection(MongoBlobStore.COLLECTION_BLOBS).drop();
+        db.getCollection(Collection.NODES.toString()).drop();
+        ((CloudBlobStore) blobStore).deleteBucket();
+    }
+}

Propchange: jackrabbit/oak/trunk/oak-it/mk/src/test/java/org/apache/jackrabbit/mk/test/MongoCloudBlobMicroKernelFixture.java
------------------------------------------------------------------------------
    svn:eol-style = native