diff --git a/apis/atmos/src/test/java/org/jclouds/atmos/internal/StubAtmosAsyncClient.java b/apis/atmos/src/test/java/org/jclouds/atmos/internal/StubAtmosAsyncClient.java index 7e6762270a..c4bd2c02a4 100644 --- a/apis/atmos/src/test/java/org/jclouds/atmos/internal/StubAtmosAsyncClient.java +++ b/apis/atmos/src/test/java/org/jclouds/atmos/internal/StubAtmosAsyncClient.java @@ -43,7 +43,7 @@ import org.jclouds.atmos.domain.SystemMetadata; import org.jclouds.atmos.domain.UserMetadata; import org.jclouds.atmos.options.ListOptions; import org.jclouds.atmos.options.PutOptions; -import org.jclouds.blobstore.TransientAsyncBlobStore; +import org.jclouds.blobstore.LocalAsyncBlobStore; import org.jclouds.blobstore.domain.Blob; import org.jclouds.blobstore.domain.BlobMetadata; import org.jclouds.blobstore.functions.HttpGetOptionsListToGetOptions; @@ -61,7 +61,7 @@ import com.google.common.util.concurrent.ListenableFuture; */ public class StubAtmosAsyncClient implements AtmosAsyncClient { private final HttpGetOptionsListToGetOptions httpGetOptionsConverter; - private final TransientAsyncBlobStore blobStore; + private final LocalAsyncBlobStore blobStore; private final AtmosObject.Factory objectProvider; private final ObjectToBlob object2Blob; private final BlobToObject blob2Object; @@ -71,7 +71,7 @@ public class StubAtmosAsyncClient implements AtmosAsyncClient { private final ExecutorService service; @Inject - private StubAtmosAsyncClient(TransientAsyncBlobStore blobStore, AtmosObject.Factory objectProvider, + private StubAtmosAsyncClient(LocalAsyncBlobStore blobStore, AtmosObject.Factory objectProvider, HttpGetOptionsListToGetOptions httpGetOptionsConverter, ObjectToBlob object2Blob, BlobToObject blob2Object, BlobMetadataToObject blob2ObjectInfo, ListOptionsToBlobStoreListOptions container2ContainerListOptions, @Named(Constants.PROPERTY_USER_THREADS) ExecutorService service, diff --git a/apis/filesystem/src/main/java/org/jclouds/filesystem/FilesystemAsyncBlobStore.java b/apis/filesystem/src/main/java/org/jclouds/filesystem/FilesystemAsyncBlobStore.java deleted file mode 100644 index 8d1aca8592..0000000000 --- a/apis/filesystem/src/main/java/org/jclouds/filesystem/FilesystemAsyncBlobStore.java +++ /dev/null @@ -1,586 +0,0 @@ -/** - * Licensed to jclouds, Inc. (jclouds) under one or more - * contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. jclouds 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.jclouds.filesystem; - -import static com.google.common.base.Preconditions.checkNotNull; -import static com.google.common.base.Preconditions.checkState; -import static com.google.common.base.Throwables.getCausalChain; -import static com.google.common.base.Throwables.propagate; -import static com.google.common.collect.Iterables.filter; -import static com.google.common.collect.Iterables.find; -import static com.google.common.collect.Iterables.size; -import static com.google.common.collect.Iterables.transform; -import static com.google.common.collect.Sets.filter; -import static com.google.common.collect.Sets.newTreeSet; -import static com.google.common.io.ByteStreams.toByteArray; -import static com.google.common.util.concurrent.Futures.immediateFailedFuture; -import static com.google.common.util.concurrent.Futures.immediateFuture; - -import java.io.ByteArrayOutputStream; -import java.io.IOException; -import java.util.Date; -import java.util.Set; -import java.util.SortedSet; -import java.util.concurrent.ExecutorService; - -import javax.annotation.Resource; -import javax.inject.Inject; -import javax.inject.Named; - -import org.jclouds.Constants; -import org.jclouds.blobstore.BlobStoreContext; -import org.jclouds.blobstore.ContainerNotFoundException; -import org.jclouds.blobstore.KeyNotFoundException; -import org.jclouds.blobstore.LocalStorageStrategy; -import org.jclouds.blobstore.domain.Blob; -import org.jclouds.blobstore.domain.Blob.Factory; -import org.jclouds.blobstore.domain.BlobMetadata; -import org.jclouds.blobstore.domain.MutableBlobMetadata; -import org.jclouds.blobstore.domain.MutableStorageMetadata; -import org.jclouds.blobstore.domain.PageSet; -import org.jclouds.blobstore.domain.StorageMetadata; -import org.jclouds.blobstore.domain.StorageType; -import org.jclouds.blobstore.domain.internal.MutableStorageMetadataImpl; -import org.jclouds.blobstore.domain.internal.PageSetImpl; -import org.jclouds.blobstore.internal.BaseAsyncBlobStore; -import org.jclouds.blobstore.options.CreateContainerOptions; -import org.jclouds.blobstore.options.GetOptions; -import org.jclouds.blobstore.options.ListContainerOptions; -import org.jclouds.blobstore.options.PutOptions; -import org.jclouds.blobstore.strategy.IfDirectoryReturnNameStrategy; -import org.jclouds.blobstore.util.BlobStoreUtils; -import org.jclouds.blobstore.util.BlobUtils; -import org.jclouds.collect.Memoized; -import org.jclouds.domain.Location; -import org.jclouds.http.HttpCommand; -import org.jclouds.http.HttpRequest; -import org.jclouds.http.HttpResponse; -import org.jclouds.http.HttpResponseException; -import org.jclouds.http.HttpUtils; -import org.jclouds.io.ContentMetadata; -import org.jclouds.io.ContentMetadataCodec; -import org.jclouds.io.Payload; -import org.jclouds.logging.Logger; - -import com.google.common.base.Function; -import com.google.common.base.Predicate; -import com.google.common.base.Supplier; -import com.google.common.base.Throwables; -import com.google.common.collect.Iterables; -import com.google.common.util.concurrent.Futures; -import com.google.common.util.concurrent.ListenableFuture; - -/** - * - * Preconditions: Blob name cannot start with / char (or \ under windows) - * - * @author Alfredo "Rainbowbreeze" Morresi - */ -public class FilesystemAsyncBlobStore extends BaseAsyncBlobStore { - - @Resource - protected Logger logger = Logger.NULL; - - protected final ContentMetadataCodec contentMetadataCodec; - protected final IfDirectoryReturnNameStrategy ifDirectoryReturnName; - protected final Factory blobFactory; - protected final LocalStorageStrategy storageStrategy; - - @Inject - protected FilesystemAsyncBlobStore(BlobStoreContext context, - BlobUtils blobUtils, - @Named(Constants.PROPERTY_USER_THREADS) ExecutorService service, - Supplier defaultLocation, - @Memoized Supplier> locations, - ContentMetadataCodec contentMetadataCodec, - IfDirectoryReturnNameStrategy ifDirectoryReturnName, - Factory blobFactory, LocalStorageStrategy storageStrategy) { - super(context, blobUtils, service, defaultLocation, locations); - this.blobFactory = blobFactory; - this.contentMetadataCodec = contentMetadataCodec; - this.ifDirectoryReturnName = ifDirectoryReturnName; - this.storageStrategy = storageStrategy; - } - - /** - * default maxResults is 1000 - */ - @Override - public ListenableFuture> list(final String container, ListContainerOptions options) { - - // Check if the container exists - if (!storageStrategy.containerExists(container)) - return immediateFailedFuture(cnfe(container)); - - // Loading blobs from container - Iterable blobBelongingToContainer = null; - try { - blobBelongingToContainer = storageStrategy.getBlobKeysInsideContainer(container); - } catch (IOException e) { - logger.error(e, "An error occurred loading blobs contained into container %s", container); - Throwables.propagate(e); - } - - SortedSet contents = newTreeSet(transform(blobBelongingToContainer, - new Function() { - public StorageMetadata apply(String key) { - Blob oldBlob = loadBlob(container, key); - checkState(oldBlob != null, "blob " + key + " is not present although it was in the list of " - + container); - checkState(oldBlob.getMetadata() != null, "blob " + container + "/" + key + " has no metadata"); - MutableBlobMetadata md = BlobStoreUtils.copy(oldBlob.getMetadata()); - String directoryName = ifDirectoryReturnName.execute(md); - if (directoryName != null) { - md.setName(directoryName); - md.setType(StorageType.RELATIVE_PATH); - } - return md; - } - })); - - String marker = null; - if (options != null) { - if (options.getMarker() != null) { - final String finalMarker = options.getMarker(); - StorageMetadata lastMarkerMetadata = find(contents, new Predicate() { - public boolean apply(StorageMetadata metadata) { - return metadata.getName().compareTo(finalMarker) > 0; - } - }); - contents = contents.tailSet(lastMarkerMetadata); - } - - final String prefix = options.getDir(); - if (prefix != null) { - contents = newTreeSet(filter(contents, new Predicate() { - public boolean apply(StorageMetadata o) { - return (o != null && o.getName().startsWith(prefix) && !o.getName().equals(prefix)); - } - })); - } - - int maxResults = options.getMaxResults() != null ? options.getMaxResults() : 1000; - if (!contents.isEmpty()) { - StorageMetadata lastElement = contents.last(); - contents = newTreeSet(Iterables.limit(contents, maxResults)); - if (!contents.contains(lastElement)) { - // Partial listing - marker = contents.last().getName(); - } - } - - final String delimiter = options.isRecursive() ? null : storageStrategy.getSeparator(); - if (delimiter != null) { - SortedSet commonPrefixes = newTreeSet( - transform(contents, new CommonPrefixes(prefix, delimiter))); - commonPrefixes.remove(CommonPrefixes.NO_PREFIX); - - contents = newTreeSet(filter(contents, new DelimiterFilter(prefix, delimiter))); - - Iterables. addAll(contents, transform(commonPrefixes, - new Function() { - public StorageMetadata apply(String o) { - MutableStorageMetadata md = new MutableStorageMetadataImpl(); - md.setType(StorageType.RELATIVE_PATH); - md.setName(o); - return md; - } - })); - } - - // trim metadata, if the response isn't supposed to be detailed. - if (!options.isDetailed()) { - for (StorageMetadata md : contents) { - md.getUserMetadata().clear(); - } - } - } - - return Futures.> immediateFuture(new PageSetImpl(contents, - marker)); - - } - - private ContainerNotFoundException cnfe(final String name) { - return new ContainerNotFoundException(name, String.format( - "container %s not in %s", name, - storageStrategy.getAllContainerNames())); - } - - /** - * {@inheritDoc} - */ - @Override - public ListenableFuture removeBlob(final String container, final String key) { - storageStrategy.removeBlob(container, key); - return immediateFuture(null); - } - - /** - * {@inheritDoc} - */ - @Override - public ListenableFuture clearContainer(final String container) { - storageStrategy.clearContainer(container); - return immediateFuture(null); - } - - /** - * Override parent method because it uses strange futures and listenables - * that creates problem in the test if more than one test that deletes the - * container is executed - * - * @param container - * @return - */ - @Override - public ListenableFuture deleteContainer(final String container) { - deleteAndVerifyContainerGone(container); - return immediateFuture(null); - } - - public ListenableFuture deleteContainerIfEmpty(final String container) { - Boolean returnVal = true; - if (storageStrategy.containerExists(container)) { - try { - if (Iterables.isEmpty(storageStrategy.getBlobKeysInsideContainer(container))) - storageStrategy.deleteContainer(container); - else - returnVal = false; - } catch (IOException e) { - logger.error(e, "An error occurred loading blobs contained into container %s", container); - Throwables.propagate(e); - } - } - return immediateFuture(returnVal); - } - - /** - * {@inheritDoc} - */ - @Override - public ListenableFuture containerExists(final String containerName) { - return immediateFuture(storageStrategy.containerExists(containerName)); - } - - /** - * {@inheritDoc} - */ - @Override - public ListenableFuture> list() { - Iterable containers = storageStrategy.getAllContainerNames(); - - return Futures.> immediateFuture(new PageSetImpl(transform( - containers, new Function() { - public StorageMetadata apply(String name) { - MutableStorageMetadata cmd = create(); - cmd.setName(name); - cmd.setType(StorageType.CONTAINER); - cmd.setLocation(storageStrategy.getLocation(name)); - return cmd; - } - }), null)); - } - - protected MutableStorageMetadata create() { - return new MutableStorageMetadataImpl(); - } - - /** - * {@inheritDoc} - */ - @Override - public ListenableFuture createContainerInLocation(final Location location, - final String name) { - boolean result = storageStrategy.createContainerInLocation(name, location); - return immediateFuture(result); - } - - private Blob loadBlob(final String container, final String key) { - logger.debug("Opening blob in container: %s - %s", container, key); - return storageStrategy.getBlob(container, key); - } - - protected static class DelimiterFilter implements Predicate { - private final String prefix; - private final String delimiter; - - public DelimiterFilter(String prefix, String delimiter) { - this.prefix = prefix; - this.delimiter = delimiter; - } - - public boolean apply(StorageMetadata metadata) { - if (prefix == null) - return metadata.getName().indexOf(delimiter) == -1; - // ensure we don't accidentally append twice - String toMatch = prefix.endsWith("/") ? prefix : prefix + delimiter; - if (metadata.getName().startsWith(toMatch)) { - String unprefixedName = metadata.getName().replaceFirst(toMatch, ""); - if (unprefixedName.equals("")) { - // we are the prefix in this case, return false - return false; - } - return unprefixedName.indexOf(delimiter) == -1; - } - return false; - } - } - - protected static class CommonPrefixes implements Function { - private final String prefix; - private final String delimiter; - public static final String NO_PREFIX = "NO_PREFIX"; - - public CommonPrefixes(String prefix, String delimiter) { - this.prefix = prefix; - this.delimiter = delimiter; - } - - public String apply(StorageMetadata metadata) { - String working = metadata.getName(); - if (prefix != null) { - // ensure we don't accidentally append twice - String toMatch = prefix.endsWith("/") ? prefix : prefix + delimiter; - if (working.startsWith(toMatch)) { - working = working.replaceFirst(toMatch, ""); - } - } - if (working.contains(delimiter)) { - return working.substring(0, working.indexOf(delimiter)); - } - return NO_PREFIX; - } - } - - public static HttpResponseException returnResponseException(int code) { - HttpResponse response = HttpResponse.builder().statusCode(code).build(); - return new HttpResponseException(new HttpCommand() { - - public int getRedirectCount() { - return 0; - } - - public int incrementRedirectCount() { - return 0; - } - - public boolean isReplayable() { - return false; - } - - public Exception getException() { - return null; - } - - public int getFailureCount() { - return 0; - } - - public int incrementFailureCount() { - return 0; - } - - public void setException(Exception exception) { - - } - - @Override - public HttpRequest getCurrentRequest() { - return HttpRequest.builder().method("GET").endpoint("http://stub").build(); - } - - @Override - public void setCurrentRequest(HttpRequest request) { - - } - - }, response); - } - - /** - * {@inheritDoc} - */ - @Override - public ListenableFuture putBlob(String containerName, Blob blob) { - checkNotNull(containerName, "containerName must be set"); - checkNotNull(blob, "blob must be set"); - String blobKey = blob.getMetadata().getName(); - - logger.debug("Put blob with key [%s] to container [%s]", blobKey, containerName); - if (!storageStrategy.containerExists(containerName)) { - return Futures.immediateFailedFuture(new IllegalStateException("containerName not found: " + containerName)); - } - - try { - return immediateFuture(storageStrategy.putBlob(containerName, blob)); - } catch (IOException e) { - logger.error(e, "An error occurred storing the new blob with name [%s] to container [%s].", blobKey, - containerName); - throw Throwables.propagate(e); - } - } - - private void copyPayloadHeadersToBlob(Payload payload, Blob blob) { - blob.getAllHeaders().putAll(contentMetadataCodec.toHeaders(payload.getContentMetadata())); - } - - /** - * {@inheritDoc} - */ - @Override - public ListenableFuture blobExists(final String containerName, final String key) { - if (!storageStrategy.containerExists(containerName)) - return immediateFailedFuture(cnfe(containerName)); - return immediateFuture(storageStrategy.blobExists(containerName, key)); - } - - /** - * {@inheritDoc} - */ - @Override - public ListenableFuture getBlob(final String containerName, final String key, GetOptions options) { - logger.debug("Retrieving blob with key %s from container %s", key, containerName); - // If the container doesn't exist, an exception is thrown - if (!storageStrategy.containerExists(containerName)) { - logger.debug("Container %s does not exist", containerName); - return immediateFailedFuture(cnfe(containerName)); - } - // If the blob doesn't exist, a null object is returned - if (!storageStrategy.blobExists(containerName, key)) { - logger.debug("Item %s does not exist in container %s", key, containerName); - return immediateFuture(null); - } - - Blob blob = loadBlob(containerName, key); - - if (options != null) { - if (options.getIfMatch() != null) { - if (!blob.getMetadata().getETag().equals(options.getIfMatch())) - return immediateFailedFuture(returnResponseException(412)); - } - if (options.getIfNoneMatch() != null) { - if (blob.getMetadata().getETag().equals(options.getIfNoneMatch())) - return immediateFailedFuture(returnResponseException(304)); - } - if (options.getIfModifiedSince() != null) { - Date modifiedSince = options.getIfModifiedSince(); - if (blob.getMetadata().getLastModified().before(modifiedSince)) { - HttpResponse response = HttpResponse.builder().statusCode(304).build(); - return immediateFailedFuture(new HttpResponseException(String.format("%1$s is before %2$s", blob - .getMetadata().getLastModified(), modifiedSince), null, response)); - } - - } - if (options.getIfUnmodifiedSince() != null) { - Date unmodifiedSince = options.getIfUnmodifiedSince(); - if (blob.getMetadata().getLastModified().after(unmodifiedSince)) { - HttpResponse response = HttpResponse.builder().statusCode(412).build(); - return immediateFailedFuture(new HttpResponseException(String.format("%1$s is after %2$s", blob - .getMetadata().getLastModified(), unmodifiedSince), null, response)); - } - } - blob = copyBlob(blob); - - if (options.getRanges() != null && options.getRanges().size() > 0) { - byte[] data; - try { - data = toByteArray(blob.getPayload()); - } catch (IOException e) { - return immediateFailedFuture(new RuntimeException(e)); - } - ByteArrayOutputStream out = new ByteArrayOutputStream(); - for (String s : options.getRanges()) { - // HTTP uses a closed interval while Java array indexing uses a - // half-open interval. - int offset = 0; - int last = data.length - 1; - if (s.startsWith("-")) { - offset = last - Integer.parseInt(s.substring(1)) + 1; - } else if (s.endsWith("-")) { - offset = Integer.parseInt(s.substring(0, s.length() - 1)); - } else if (s.contains("-")) { - String[] firstLast = s.split("\\-"); - offset = Integer.parseInt(firstLast[0]); - last = Integer.parseInt(firstLast[1]); - } else { - return immediateFailedFuture(new IllegalArgumentException("illegal range: " + s)); - } - - if (offset > last) { - return immediateFailedFuture(new IllegalArgumentException("illegal range: " + s)); - } - if (last + 1 > data.length) { - last = data.length - 1; - } - out.write(data, offset, last - offset + 1); - } - ContentMetadata cmd = blob.getPayload().getContentMetadata(); - byte[] byteArray = out.toByteArray(); - blob.setPayload(byteArray); - HttpUtils.copy(cmd, blob.getPayload().getContentMetadata()); - blob.getPayload().getContentMetadata().setContentLength(Long.valueOf(byteArray.length)); - } - } - checkNotNull(blob.getPayload(), "payload " + blob); - return immediateFuture(blob); - } - - /** - * {@inheritDoc} - */ - @Override - public ListenableFuture blobMetadata(final String container, final String key) { - try { - Blob blob = getBlob(container, key).get(); - return immediateFuture(blob != null ? (BlobMetadata) BlobStoreUtils.copy(blob.getMetadata()) : null); - } catch (Exception e) { - if (size(filter(getCausalChain(e), KeyNotFoundException.class)) >= 1) - return immediateFuture(null); - return immediateFailedFuture(e); - } - } - - private Blob copyBlob(Blob blob) { - Blob returnVal = blobFactory.create(BlobStoreUtils.copy(blob.getMetadata())); - returnVal.setPayload(blob.getPayload()); - copyPayloadHeadersToBlob(blob.getPayload(), returnVal); - return returnVal; - } - - @Override - protected boolean deleteAndVerifyContainerGone(final String container) { - storageStrategy.deleteContainer(container); - return storageStrategy.containerExists(container); - } - - @Override - public ListenableFuture putBlob(String container, Blob blob, PutOptions options) { - // TODO implement options - return putBlob(container, blob); - } - - @Override - public ListenableFuture createContainerInLocation(Location location, String container, - CreateContainerOptions options) { - if (options.isPublicRead()) - throw new UnsupportedOperationException("publicRead"); - return createContainerInLocation(location, container); - } -} diff --git a/apis/filesystem/src/main/java/org/jclouds/filesystem/FilesystemBlobStore.java b/apis/filesystem/src/main/java/org/jclouds/filesystem/FilesystemBlobStore.java deleted file mode 100644 index e21c3c0c59..0000000000 --- a/apis/filesystem/src/main/java/org/jclouds/filesystem/FilesystemBlobStore.java +++ /dev/null @@ -1,31 +0,0 @@ -/** - * Licensed to jclouds, Inc. (jclouds) under one or more - * contributor license agreements. See the NOTICE file - * distributed with this work for additional information - * regarding copyright ownership. jclouds 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.jclouds.filesystem; - -import java.util.concurrent.TimeUnit; - -import org.jclouds.blobstore.BlobStore; -import org.jclouds.concurrent.Timeout; - -/** - * - * @author Alfredo "Rainbowbreeze" Morresi - */ -@Timeout(duration = 2, timeUnit = TimeUnit.MINUTES) public interface FilesystemBlobStore extends BlobStore { -} diff --git a/apis/filesystem/src/main/java/org/jclouds/filesystem/config/FilesystemBlobStoreContextModule.java b/apis/filesystem/src/main/java/org/jclouds/filesystem/config/FilesystemBlobStoreContextModule.java index 26f39d70af..1eb4079fcb 100644 --- a/apis/filesystem/src/main/java/org/jclouds/filesystem/config/FilesystemBlobStoreContextModule.java +++ b/apis/filesystem/src/main/java/org/jclouds/filesystem/config/FilesystemBlobStoreContextModule.java @@ -21,14 +21,14 @@ package org.jclouds.filesystem.config; import org.jclouds.blobstore.AsyncBlobStore; import org.jclouds.blobstore.BlobRequestSigner; import org.jclouds.blobstore.BlobStore; +import org.jclouds.blobstore.LocalAsyncBlobStore; import org.jclouds.blobstore.LocalStorageStrategy; import org.jclouds.blobstore.TransientBlobRequestSigner; import org.jclouds.blobstore.attr.ConsistencyModel; import org.jclouds.blobstore.config.BlobStoreMapModule; import org.jclouds.blobstore.config.BlobStoreObjectModule; +import org.jclouds.blobstore.config.LocalBlobStore; import org.jclouds.blobstore.util.BlobUtils; -import org.jclouds.filesystem.FilesystemAsyncBlobStore; -import org.jclouds.filesystem.FilesystemBlobStore; import org.jclouds.filesystem.predicates.validators.FilesystemBlobKeyValidator; import org.jclouds.filesystem.predicates.validators.FilesystemContainerNameValidator; import org.jclouds.filesystem.predicates.validators.internal.FilesystemBlobKeyValidatorImpl; @@ -48,10 +48,10 @@ public class FilesystemBlobStoreContextModule extends AbstractModule { @Override protected void configure() { - bind(AsyncBlobStore.class).to(FilesystemAsyncBlobStore.class).asEagerSingleton(); + bind(AsyncBlobStore.class).to(LocalAsyncBlobStore.class).asEagerSingleton(); // forward all requests from TransientBlobStore to TransientAsyncBlobStore. needs above binding as cannot proxy a class - BinderUtils.bindClient(binder(), FilesystemBlobStore.class, AsyncBlobStore.class, ImmutableMap., Class>of()); - bind(BlobStore.class).to(FilesystemBlobStore.class); + BinderUtils.bindClient(binder(), LocalBlobStore.class, AsyncBlobStore.class, ImmutableMap., Class>of()); + bind(BlobStore.class).to(LocalBlobStore.class); install(new BlobStoreObjectModule()); install(new BlobStoreMapModule()); diff --git a/apis/s3/src/test/java/org/jclouds/s3/internal/StubS3AsyncClient.java b/apis/s3/src/test/java/org/jclouds/s3/internal/StubS3AsyncClient.java index 566380ed23..85a59522d1 100644 --- a/apis/s3/src/test/java/org/jclouds/s3/internal/StubS3AsyncClient.java +++ b/apis/s3/src/test/java/org/jclouds/s3/internal/StubS3AsyncClient.java @@ -37,7 +37,7 @@ import org.jclouds.Constants; import org.jclouds.aws.domain.Region; import org.jclouds.blobstore.AsyncBlobStore; import org.jclouds.blobstore.KeyNotFoundException; -import org.jclouds.blobstore.TransientAsyncBlobStore; +import org.jclouds.blobstore.LocalAsyncBlobStore; import org.jclouds.blobstore.domain.Blob; import org.jclouds.blobstore.domain.BlobMetadata; import org.jclouds.blobstore.domain.MutableBlobMetadata; @@ -103,7 +103,7 @@ public class StubS3AsyncClient implements S3AsyncClient { @Inject private StubS3AsyncClient(@Named(Constants.PROPERTY_USER_THREADS) ExecutorService service, - TransientAsyncBlobStore blobStore, ConcurrentMap> containerToBlobs, + LocalAsyncBlobStore blobStore, ConcurrentMap> containerToBlobs, ConcurrentMap containerToLocation, DateService dateService, S3Object.Factory objectProvider, Blob.Factory blobProvider, HttpGetOptionsListToGetOptions httpGetOptionsConverter, ObjectToBlob object2Blob, BlobToObject blob2Object, @@ -158,22 +158,22 @@ public class StubS3AsyncClient implements S3AsyncClient { Blob object = source.get(sourceObject); if (options.getIfMatch() != null) { if (!object.getMetadata().getETag().equals(options.getIfMatch())) - return immediateFailedFuture(TransientAsyncBlobStore.returnResponseException(412)); + return immediateFailedFuture(LocalAsyncBlobStore.returnResponseException(412)); } if (options.getIfNoneMatch() != null) { if (object.getMetadata().getETag().equals(options.getIfNoneMatch())) - return immediateFailedFuture(TransientAsyncBlobStore.returnResponseException(412)); + return immediateFailedFuture(LocalAsyncBlobStore.returnResponseException(412)); } if (options.getIfModifiedSince() != null) { Date modifiedSince = dateService.rfc822DateParse(options.getIfModifiedSince()); if (modifiedSince.after(object.getMetadata().getLastModified())) - return immediateFailedFuture(TransientAsyncBlobStore.returnResponseException(412)); + return immediateFailedFuture(LocalAsyncBlobStore.returnResponseException(412)); } if (options.getIfUnmodifiedSince() != null) { Date unmodifiedSince = dateService.rfc822DateParse(options.getIfUnmodifiedSince()); if (unmodifiedSince.before(object.getMetadata().getLastModified())) - return immediateFailedFuture(TransientAsyncBlobStore.returnResponseException(412)); + return immediateFailedFuture(LocalAsyncBlobStore.returnResponseException(412)); } Blob sourceS3 = source.get(sourceObject); MutableBlobMetadata newMd = BlobStoreUtils.copy(sourceS3.getMetadata(), destinationObject); diff --git a/apis/swift/src/test/java/org/jclouds/openstack/swift/internal/StubSwiftAsyncClient.java b/apis/swift/src/test/java/org/jclouds/openstack/swift/internal/StubSwiftAsyncClient.java index 00a889a2fe..354ffee1c4 100644 --- a/apis/swift/src/test/java/org/jclouds/openstack/swift/internal/StubSwiftAsyncClient.java +++ b/apis/swift/src/test/java/org/jclouds/openstack/swift/internal/StubSwiftAsyncClient.java @@ -33,7 +33,7 @@ import javax.inject.Named; import javax.inject.Singleton; import org.jclouds.Constants; -import org.jclouds.blobstore.TransientAsyncBlobStore; +import org.jclouds.blobstore.LocalAsyncBlobStore; import org.jclouds.blobstore.domain.BlobMetadata; import org.jclouds.blobstore.domain.PageSet; import org.jclouds.blobstore.domain.StorageMetadata; @@ -68,7 +68,7 @@ import com.google.common.util.concurrent.ListenableFuture; @Singleton public class StubSwiftAsyncClient implements CommonSwiftAsyncClient { private final HttpGetOptionsListToGetOptions httpGetOptionsConverter; - private final TransientAsyncBlobStore blobStore; + private final LocalAsyncBlobStore blobStore; private final SwiftObject.Factory objectProvider; private final ObjectToBlob object2Blob; private final BlobToObject blob2Object; @@ -79,7 +79,7 @@ public class StubSwiftAsyncClient implements CommonSwiftAsyncClient { @Inject private StubSwiftAsyncClient(@Named(Constants.PROPERTY_USER_THREADS) ExecutorService service, - TransientAsyncBlobStore blobStore, + LocalAsyncBlobStore blobStore, SwiftObject.Factory objectProvider, HttpGetOptionsListToGetOptions httpGetOptionsConverter, ObjectToBlob object2Blob, BlobToObject blob2Object, ResourceToObjectInfo blob2ObjectInfo, ListContainerOptionsToBlobStoreListContainerOptions container2ContainerListOptions, diff --git a/blobstore/src/main/java/org/jclouds/blobstore/TransientAsyncBlobStore.java b/blobstore/src/main/java/org/jclouds/blobstore/LocalAsyncBlobStore.java similarity index 98% rename from blobstore/src/main/java/org/jclouds/blobstore/TransientAsyncBlobStore.java rename to blobstore/src/main/java/org/jclouds/blobstore/LocalAsyncBlobStore.java index 72fde80d74..16fc21bf63 100644 --- a/blobstore/src/main/java/org/jclouds/blobstore/TransientAsyncBlobStore.java +++ b/blobstore/src/main/java/org/jclouds/blobstore/LocalAsyncBlobStore.java @@ -83,12 +83,15 @@ import com.google.common.util.concurrent.Futures; import com.google.common.util.concurrent.ListenableFuture; /** - * Implementation of {@link BaseAsyncBlobStore} which keeps all data in a local Map object. - * + * Implementation of {@link BaseAsyncBlobStore} which uses a pluggable + * LocalStorageStrategy. + * * @author Adrian Cole + * @author Alfredo "Rainbowbreeze" Morresi + * @author Andrew Gaul * @author James Murty */ -public class TransientAsyncBlobStore extends BaseAsyncBlobStore { +public class LocalAsyncBlobStore extends BaseAsyncBlobStore { @Resource protected Logger logger = Logger.NULL; @@ -99,7 +102,7 @@ public class TransientAsyncBlobStore extends BaseAsyncBlobStore { protected final LocalStorageStrategy storageStrategy; @Inject - protected TransientAsyncBlobStore(BlobStoreContext context, + protected LocalAsyncBlobStore(BlobStoreContext context, BlobUtils blobUtils, @Named(Constants.PROPERTY_USER_THREADS) ExecutorService service, Supplier defaultLocation, diff --git a/blobstore/src/main/java/org/jclouds/blobstore/config/TransientBlobStore.java b/blobstore/src/main/java/org/jclouds/blobstore/config/LocalBlobStore.java similarity index 94% rename from blobstore/src/main/java/org/jclouds/blobstore/config/TransientBlobStore.java rename to blobstore/src/main/java/org/jclouds/blobstore/config/LocalBlobStore.java index b088d5fa28..3c33c23f45 100644 --- a/blobstore/src/main/java/org/jclouds/blobstore/config/TransientBlobStore.java +++ b/blobstore/src/main/java/org/jclouds/blobstore/config/LocalBlobStore.java @@ -24,6 +24,6 @@ import org.jclouds.blobstore.BlobStore; import org.jclouds.concurrent.Timeout; @Timeout(duration = 2, timeUnit = TimeUnit.MINUTES) -public interface TransientBlobStore extends BlobStore { +public interface LocalBlobStore extends BlobStore { -} \ No newline at end of file +} diff --git a/blobstore/src/main/java/org/jclouds/blobstore/config/TransientBlobStoreContextModule.java b/blobstore/src/main/java/org/jclouds/blobstore/config/TransientBlobStoreContextModule.java index a6d0bfc456..e5bdb32cd6 100644 --- a/blobstore/src/main/java/org/jclouds/blobstore/config/TransientBlobStoreContextModule.java +++ b/blobstore/src/main/java/org/jclouds/blobstore/config/TransientBlobStoreContextModule.java @@ -21,8 +21,8 @@ package org.jclouds.blobstore.config; import org.jclouds.blobstore.AsyncBlobStore; import org.jclouds.blobstore.BlobRequestSigner; import org.jclouds.blobstore.BlobStore; +import org.jclouds.blobstore.LocalAsyncBlobStore; import org.jclouds.blobstore.LocalStorageStrategy; -import org.jclouds.blobstore.TransientAsyncBlobStore; import org.jclouds.blobstore.TransientBlobRequestSigner; import org.jclouds.blobstore.TransientStorageStrategy; import org.jclouds.blobstore.attr.ConsistencyModel; @@ -39,12 +39,12 @@ import com.google.inject.AbstractModule; public class TransientBlobStoreContextModule extends AbstractModule { @Override protected void configure() { - bind(AsyncBlobStore.class).to(TransientAsyncBlobStore.class).asEagerSingleton(); + bind(AsyncBlobStore.class).to(LocalAsyncBlobStore.class).asEagerSingleton(); // forward all requests from TransientBlobStore to TransientAsyncBlobStore. needs above binding as cannot proxy a class - BinderUtils.bindClient(binder(), TransientBlobStore.class, AsyncBlobStore.class, ImmutableMap., Class>of()); + BinderUtils.bindClient(binder(), LocalBlobStore.class, AsyncBlobStore.class, ImmutableMap., Class>of()); install(new BlobStoreObjectModule()); install(new BlobStoreMapModule()); - bind(BlobStore.class).to(TransientBlobStore.class); + bind(BlobStore.class).to(LocalBlobStore.class); bind(ConsistencyModel.class).toInstance(ConsistencyModel.STRICT); bind(LocalStorageStrategy.class).to(TransientStorageStrategy.class); bind(BlobRequestSigner.class).to(TransientBlobRequestSigner.class); diff --git a/blobstore/src/test/java/org/jclouds/blobstore/TransientBlobRequestSignerTest.java b/blobstore/src/test/java/org/jclouds/blobstore/TransientBlobRequestSignerTest.java index 39a0679a32..445accb319 100644 --- a/blobstore/src/test/java/org/jclouds/blobstore/TransientBlobRequestSignerTest.java +++ b/blobstore/src/test/java/org/jclouds/blobstore/TransientBlobRequestSignerTest.java @@ -42,7 +42,7 @@ import com.google.inject.TypeLiteral; */ // NOTE:without testName, this will not call @Before* and fail w/NPE during surefire @Test(groups = "unit", testName = "TransientBlobRequestSignerTest") -public class TransientBlobRequestSignerTest extends BaseAsyncClientTest { +public class TransientBlobRequestSignerTest extends BaseAsyncClientTest { private BlobRequestSigner signer; private Provider blobFactory; @@ -121,8 +121,8 @@ public class TransientBlobRequestSignerTest extends BaseAsyncClientTest> createTypeLiteral() { - return new TypeLiteral>() { + protected TypeLiteral> createTypeLiteral() { + return new TypeLiteral>() { }; }