All Downloads are FREE. Search and download functionalities are using the official Maven repository.

com.microsoft.windowsazure.storage.blob.CloudPageBlob Maven / Gradle / Ivy

/**
 * Copyright Microsoft Corporation
 * 
 * Licensed 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 com.microsoft.windowsazure.storage.blob;

import java.io.ByteArrayInputStream;
import java.io.IOException;
import java.io.InputStream;
import java.io.OutputStream;
import java.net.HttpURLConnection;
import java.net.URI;
import java.security.MessageDigest;
import java.security.NoSuchAlgorithmException;
import java.util.ArrayList;

import com.microsoft.windowsazure.storage.AccessCondition;
import com.microsoft.windowsazure.storage.Constants;
import com.microsoft.windowsazure.storage.DoesServiceRequest;
import com.microsoft.windowsazure.storage.OperationContext;
import com.microsoft.windowsazure.storage.StorageException;
import com.microsoft.windowsazure.storage.StorageUri;
import com.microsoft.windowsazure.storage.core.Base64;
import com.microsoft.windowsazure.storage.core.ExecutionEngine;
import com.microsoft.windowsazure.storage.core.RequestLocationMode;
import com.microsoft.windowsazure.storage.core.SR;
import com.microsoft.windowsazure.storage.core.StorageRequest;
import com.microsoft.windowsazure.storage.core.Utility;

/**
 * Represents a Windows Azure page blob.
 */
public final class CloudPageBlob extends CloudBlob {
    /**
     * Creates an instance of the CloudPageBlob class using the specified relative URI and storage service
     * client.
     * 
     * @param uri
     *            A java.net.URI object that represents the relative URI to the blob, beginning with the
     *            container name.
     * 
     * @throws StorageException
     *             If a storage service error occurred.
     */
    public CloudPageBlob(final URI uri) throws StorageException {
        this(new StorageUri(uri));
    }

    /**
     * Creates an instance of the CloudPageBlob class using the specified relative URI and storage service
     * client.
     * 
     * @param uri
     *            A StorageUri object that represents the relative URI to the blob, beginning with the
     *            container name.
     * 
     * @throws StorageException
     *             If a storage service error occurred.
     */
    public CloudPageBlob(final StorageUri uri) throws StorageException {
        super(BlobType.PAGE_BLOB);

        Utility.assertNotNull("blobAbsoluteUri", uri);
        this.setStorageUri(uri);
        this.parseURIQueryStringAndVerify(uri, null, Utility.determinePathStyleFromUri(uri.getPrimaryUri(), null));;
    }

    /**
     * Creates an instance of the CloudPageBlob class by copying values from another page blob.
     * 
     * @param otherBlob
     *            A CloudPageBlob object that represents the page blob to copy.
     * 
     * @throws StorageException
     *             If a storage service error occurred.
     */
    public CloudPageBlob(final CloudPageBlob otherBlob) throws StorageException {
        super(otherBlob);
    }

    /**
     * Creates an instance of the CloudPageBlob class using the specified URI and cloud blob client.
     * 
     * @param uri
     *            A java.net.URI object that represents the absolute URI to the blob, beginning with the
     *            container name.
     * @param client
     *            A {@link CloudBlobClient} object that specifies the endpoint for the Blob service.
     * 
     * @throws StorageException
     *             If a storage service error occurred.
     */
    public CloudPageBlob(final URI uri, final CloudBlobClient client) throws StorageException {
        this(new StorageUri(uri), client);
    }

    /**
     * Creates an instance of the CloudPageBlob class using the specified URI and cloud blob client.
     * 
     * @param uri
     *            A StorageUri object that represents the absolute URI to the blob, beginning with the
     *            container name.
     * @param client
     *            A {@link CloudBlobClient} object that specifies the endpoint for the Blob service.
     * 
     * @throws StorageException
     *             If a storage service error occurred.
     */
    public CloudPageBlob(final StorageUri uri, final CloudBlobClient client) throws StorageException {
        super(BlobType.PAGE_BLOB, uri, client);
    }

    /**
     * Creates an instance of the CloudPageBlob class using the specified URI, cloud blob client, and cloud
     * blob container.
     * 
     * @param uri
     *            A java.net.URI object that represents the relative URI to the blob, beginning with the
     *            container name.
     * @param client
     *            A {@link CloudBlobClient} object that specifies the endpoint for the Blob service.
     * @param container
     *            A {@link CloudBlobContainer} object that represents the container to use for the blob.
     * 
     * @throws StorageException
     *             If a storage service error occurred.
     */
    public CloudPageBlob(final URI uri, final CloudBlobClient client, final CloudBlobContainer container)
            throws StorageException {
        this(new StorageUri(uri), client, container);
    }

    /**
     * Creates an instance of the CloudPageBlob class using the specified URI, cloud blob client, and cloud
     * blob container.
     * 
     * @param uri
     *            A StorageUri object that represents the relative URI to the blob, beginning with the
     *            container name.
     * @param client
     *            A {@link CloudBlobClient} object that specifies the endpoint for the Blob service.
     * @param container
     *            A {@link CloudBlobContainer} object that represents the container to use for the blob.
     * 
     * @throws StorageException
     *             If a storage service error occurred.
     */
    public CloudPageBlob(final StorageUri uri, final CloudBlobClient client, final CloudBlobContainer container)
            throws StorageException {
        super(BlobType.PAGE_BLOB, uri, client, container);
    }

    /**
     * Creates an instance of the CloudPageBlob class using the specified URI, snapshot ID, and cloud blob
     * client.
     * 
     * @param uri
     *            A java.net.URI object that represents the absolute URI to the blob, beginning with the
     *            container name.
     * @param snapshotID
     *            A String that represents the snapshot version, if applicable.
     * @param client
     *            A {@link CloudBlobContainer} object that represents the container to use for the blob.
     * 
     * @throws StorageException
     *             If a storage service error occurred.
     */
    public CloudPageBlob(final URI uri, final String snapshotID, final CloudBlobClient client) throws StorageException {
        this(new StorageUri(uri), snapshotID, client);
    }

    /**
     * Creates an instance of the CloudPageBlob class using the specified URI, snapshot ID, and cloud blob
     * client.
     * 
     * @param uri
     *            A StorageUri object that represents the absolute URI to the blob, beginning with the
     *            container name.
     * @param snapshotID
     *            A String that represents the snapshot version, if applicable.
     * @param client
     *            A {@link CloudBlobContainer} object that represents the container to use for the blob.
     * 
     * @throws StorageException
     *             If a storage service error occurred.
     */
    public CloudPageBlob(final StorageUri uri, final String snapshotID, final CloudBlobClient client)
            throws StorageException {
        super(BlobType.PAGE_BLOB, uri, snapshotID, client);
    }

    /**
     * Clears pages from a page blob.
     * 

* Calling clearPages releases the storage space used by the specified pages. Pages that have been * cleared are no longer tracked as part of the page blob, and no longer incur a charge against the storage account. * * @param offset * The offset, in bytes, at which to begin clearing pages. This value must be a multiple of 512. * @param length * The length, in bytes, of the data range to be cleared. This value must be a multiple of 512. * * @throws IOException * If an I/O exception occurred. * @throws StorageException * If a storage service error occurred. */ @DoesServiceRequest public void clearPages(final long offset, final long length) throws StorageException, IOException { this.clearPages(offset, length, null /* accessCondition */, null /* options */, null /* opContext */); } /** * Clears pages from a page blob using the specified lease ID, request options, and operation context. *

* Calling clearPages releases the storage space used by the specified pages. Pages that have been * cleared are no longer tracked as part of the page blob, and no longer incur a charge against the storage account. * * @param offset * The offset, in bytes, at which to begin clearing pages. This value must be a multiple of 512. * @param length * The length, in bytes, of the data range to be cleared. This value must be a multiple of 512. * @param accessCondition * An {@link AccessCondition} object that represents the access conditions for the blob. * @param options * A {@link BlobRequestOptions} object that specifies any additional options for the request. Specifying * null will use the default request options from the associated service client ( * {@link CloudBlobClient}). * @param opContext * An {@link OperationContext} object that represents the context for the current operation. This object * is used to track requests to the storage service, and to provide additional runtime information about * the operation. * * @throws IOException * If an I/O exception occurred. * @throws StorageException * If a storage service error occurred. */ @DoesServiceRequest public void clearPages(final long offset, final long length, final AccessCondition accessCondition, BlobRequestOptions options, OperationContext opContext) throws StorageException, IOException { if (offset % BlobConstants.PAGE_SIZE != 0) { throw new IllegalArgumentException(SR.INVALID_PAGE_START_OFFSET); } if (length % BlobConstants.PAGE_SIZE != 0) { throw new IllegalArgumentException(SR.INVALID_PAGE_BLOB_LENGTH); } if (opContext == null) { opContext = new OperationContext(); } options = BlobRequestOptions.applyDefaults(options, BlobType.PAGE_BLOB, this.blobServiceClient); final PageProperties pageProps = new PageProperties(); pageProps.setPageOperation(PageOperationType.CLEAR); pageProps.getRange().setStartOffset(offset); pageProps.getRange().setEndOffset(offset + length - 1); this.putPagesInternal(pageProps, null, length, null, accessCondition, options, opContext); } /** * Creates a page blob. * * @param length * The size, in bytes, of the page blob. * * @throws IllegalArgumentException * If the length is not a multiple of 512. * @throws StorageException * If a storage service error occurred. */ @DoesServiceRequest public void create(final long length) throws StorageException { this.create(length, null /* accessCondition */, null /* options */, null /* opContext */); } /** * Creates a page blob using the specified request options and operation context. * * @param length * The size, in bytes, of the page blob. * @param accessCondition * An {@link AccessCondition} object that represents the access conditions for the blob. * @param options * A {@link BlobRequestOptions} object that specifies any additional options for the request. Specifying * null will use the default request options from the associated service client ( * {@link CloudBlobClient}). * @param opContext * An {@link OperationContext} object that represents the context for the current operation. This object * is used to track requests to the storage service, and to provide additional runtime information about * the operation. * * @throws IllegalArgumentException * If the length is not a multiple of 512. * * @throws StorageException * If a storage service error occurred. */ @DoesServiceRequest public void create(final long length, final AccessCondition accessCondition, BlobRequestOptions options, OperationContext opContext) throws StorageException { assertNoWriteOperationForSnapshot(); if (length % BlobConstants.PAGE_SIZE != 0) { throw new IllegalArgumentException(SR.INVALID_PAGE_BLOB_LENGTH); } if (opContext == null) { opContext = new OperationContext(); } options = BlobRequestOptions.applyDefaults(options, BlobType.PAGE_BLOB, this.blobServiceClient); ExecutionEngine.executeWithRetry(this.blobServiceClient, this, this.createImpl(length, accessCondition, options), options.getRetryPolicyFactory(), opContext); } private StorageRequest createImpl(final long length, final AccessCondition accessCondition, final BlobRequestOptions options) throws StorageException { final StorageRequest putRequest = new StorageRequest( options, this.getStorageUri()) { @Override public HttpURLConnection buildRequest(CloudBlobClient client, CloudBlob blob, OperationContext context) throws Exception { return BlobRequest.put(blob.getTransformedAddress(context).getUri(this.getCurrentLocation()), options.getTimeoutIntervalInMs(), blob.properties, BlobType.PAGE_BLOB, length, accessCondition, options, context); } @Override public void setHeaders(HttpURLConnection connection, CloudBlob blob, OperationContext context) { BlobRequest.addMetadata(connection, blob.metadata, context); } @Override public void signRequest(HttpURLConnection connection, CloudBlobClient client, OperationContext context) throws Exception { StorageRequest.signBlobAndQueueRequest(connection, client, 0L, null); } @Override public Void preProcessResponse(CloudBlob blob, CloudBlobClient client, OperationContext context) throws Exception { if (this.getResult().getStatusCode() != HttpURLConnection.HTTP_CREATED) { this.setNonExceptionedRetryableFailure(true); return null; } blob.updateEtagAndLastModifiedFromResponse(this.getConnection()); return null; } }; return putRequest; } /** * Returns a collection of page ranges and their starting and ending byte offsets. *

* The start and end byte offsets for each page range are inclusive. * * @return An ArrayList object that represents the set of page ranges and their starting and ending * byte offsets. * * @throws StorageException * If a storage service error occurred. */ @DoesServiceRequest public ArrayList downloadPageRanges() throws StorageException { return this.downloadPageRanges(null /* accessCondition */, null /* options */, null /* opContext */); } /** * Returns a collection of page ranges and their starting and ending byte offsets using the specified request * options and operation context. * * @param accessCondition * An {@link AccessCondition} object that represents the access conditions for the blob. * @param options * A {@link BlobRequestOptions} object that specifies any additional options for the request. Specifying * null will use the default request options from the associated service client ( * {@link CloudBlobClient}). * @param opContext * An {@link OperationContext} object that represents the context for the current operation. This object * is used to track requests to the storage service, and to provide additional runtime information about * the operation. * * @return An ArrayList object that represents the set of page ranges and their starting and ending * byte offsets. * * @throws StorageException * If a storage service error occurred. */ @DoesServiceRequest public ArrayList downloadPageRanges(final AccessCondition accessCondition, BlobRequestOptions options, OperationContext opContext) throws StorageException { if (opContext == null) { opContext = new OperationContext(); } options = BlobRequestOptions.applyDefaults(options, BlobType.PAGE_BLOB, this.blobServiceClient); return ExecutionEngine.executeWithRetry(this.blobServiceClient, this, this.downloadPageRangesImpl(accessCondition, options), options.getRetryPolicyFactory(), opContext); } private StorageRequest> downloadPageRangesImpl( final AccessCondition accessCondition, final BlobRequestOptions options) throws StorageException { final StorageRequest> getRequest = new StorageRequest>( options, this.getStorageUri()) { @Override public void setRequestLocationMode() { this.setRequestLocationMode(RequestLocationMode.PRIMARY_OR_SECONDARY); } @Override public HttpURLConnection buildRequest(CloudBlobClient client, CloudBlob blob, OperationContext context) throws Exception { return BlobRequest.getPageRanges(blob.getTransformedAddress(context).getUri(this.getCurrentLocation()), options.getTimeoutIntervalInMs(), blob.snapshotID, accessCondition, options, context); } @Override public void signRequest(HttpURLConnection connection, CloudBlobClient client, OperationContext context) throws Exception { StorageRequest.signBlobAndQueueRequest(connection, client, -1L, null); } @Override public ArrayList preProcessResponse(CloudBlob parentObject, CloudBlobClient client, OperationContext context) throws Exception { if (this.getResult().getStatusCode() != HttpURLConnection.HTTP_OK) { this.setNonExceptionedRetryableFailure(true); } return null; } @Override public ArrayList postProcessResponse(HttpURLConnection connection, CloudBlob blob, CloudBlobClient client, OperationContext context, ArrayList storageObject) throws Exception { blob.updateEtagAndLastModifiedFromResponse(this.getConnection()); blob.updateLengthFromResponse(this.getConnection()); final GetPageRangesResponse response = new GetPageRangesResponse(this.getConnection().getInputStream()); return response.getPageRanges(); } }; return getRequest; } /** * Opens an output stream object to write data to the page blob. * * @param length * The length, in bytes, of the stream to create. This value must be a multiple of 512. * * @return A {@link BlobOutputStream} object used to write data to the blob. * * @throws StorageException * If a storage service error occurred. */ @DoesServiceRequest public BlobOutputStream openOutputStream(final long length) throws StorageException { return this.openOutputStream(length, null /* accessCondition */, null /* options */, null /* opContext */); } /** * Opens an output stream object to write data to the page blob, using the specified lease ID, request options and * operation context. * * @param length * The length, in bytes, of the stream to create. This value must be a multiple of 512. * @param accessCondition * An {@link AccessCondition} object that represents the access conditions for the blob. * @param options * A {@link BlobRequestOptions} object that specifies any additional options for the request. Specifying * null will use the default request options from the associated service client ( * {@link CloudBlobClient}). * @param opContext * An {@link OperationContext} object that represents the context for the current operation. This object * is used to track requests to the storage service, and to provide additional runtime information about * the operation. * * @return A {@link BlobOutputStream} object used to write data to the blob. * * @throws StorageException * If a storage service error occurred. */ @DoesServiceRequest public BlobOutputStream openOutputStream(final long length, AccessCondition accessCondition, BlobRequestOptions options, OperationContext opContext) throws StorageException { if (opContext == null) { opContext = new OperationContext(); } assertNoWriteOperationForSnapshot(); options = BlobRequestOptions.applyDefaults(options, BlobType.PAGE_BLOB, this.blobServiceClient); if (options.getStoreBlobContentMD5()) { throw new IllegalArgumentException(SR.BLOB_MD5_NOT_SUPPORTED_FOR_PAGE_BLOBS); } if (length % BlobConstants.PAGE_SIZE != 0) { throw new IllegalArgumentException(SR.INVALID_PAGE_BLOB_LENGTH); } if (options.getStoreBlobContentMD5()) { throw new IllegalArgumentException(SR.BLOB_MD5_NOT_SUPPORTED_FOR_PAGE_BLOBS); } this.create(length, accessCondition, options, opContext); if (accessCondition != null) { accessCondition = AccessCondition.generateLeaseCondition(accessCondition.getLeaseID()); } return new BlobOutputStream(this, length, accessCondition, options, opContext); } /** * Used for both uploadPages and clearPages. * * @param pageProperties * The page properties. * @param data * The data to write. * @param length * The number of bytes to write. * @param md5 * the MD5 hash for the data. * @param accessCondition * An {@link AccessCondition} object that represents the access conditions for the blob. * @param options * A {@link BlobRequestOptions} object that specifies any additional options for the request. Specifying * null will use the default request options from the associated service client ( * {@link CloudBlobClient}). * @param opContext * An {@link OperationContext} object that represents the context for the current operation. This object * is used to track requests to the storage service, and to provide additional runtime information about * the operation. * * @throws StorageException * If a storage service error occurred. */ @DoesServiceRequest private void putPagesInternal(final PageProperties pageProperties, final byte[] data, final long length, final String md5, final AccessCondition accessCondition, final BlobRequestOptions options, final OperationContext opContext) throws StorageException { ExecutionEngine.executeWithRetry(this.blobServiceClient, this, putPagesImpl(pageProperties, data, length, md5, accessCondition, options, opContext), options.getRetryPolicyFactory(), opContext); } private StorageRequest putPagesImpl(final PageProperties pageProperties, final byte[] data, final long length, final String md5, final AccessCondition accessCondition, final BlobRequestOptions options, final OperationContext opContext) throws StorageException { final StorageRequest putRequest = new StorageRequest( options, this.getStorageUri()) { @Override public HttpURLConnection buildRequest(CloudBlobClient client, CloudBlob blob, OperationContext context) throws Exception { if (pageProperties.getPageOperation() == PageOperationType.UPDATE) { this.setSendStream(new ByteArrayInputStream(data)); this.setLength(length); } return BlobRequest.putPage(blob.getTransformedAddress(opContext).getUri(this.getCurrentLocation()), options.getTimeoutIntervalInMs(), pageProperties, accessCondition, options, opContext); } @Override public void setHeaders(HttpURLConnection connection, CloudBlob blob, OperationContext context) { if (pageProperties.getPageOperation() == PageOperationType.UPDATE) { if (options.getUseTransactionalContentMD5()) { connection.setRequestProperty(Constants.HeaderConstants.CONTENT_MD5, md5); } } } @Override public void signRequest(HttpURLConnection connection, CloudBlobClient client, OperationContext context) throws Exception { if (pageProperties.getPageOperation() == PageOperationType.UPDATE) { StorageRequest.signBlobAndQueueRequest(connection, client, length, null); } else { StorageRequest.signBlobAndQueueRequest(connection, client, 0L, null); } } @Override public Void preProcessResponse(CloudBlob blob, CloudBlobClient client, OperationContext context) throws Exception { if (this.getResult().getStatusCode() != HttpURLConnection.HTTP_CREATED) { this.setNonExceptionedRetryableFailure(true); return null; } blob.updateEtagAndLastModifiedFromResponse(this.getConnection()); return null; } }; return putRequest; } /** * Uploads the source stream data to the page blob. * * @param sourceStream * An IntputStream object to read from. * @param length * The length, in bytes, of the stream data, must be non zero and a multiple of 512. * * @throws IOException * If an I/O exception occurred. * @throws StorageException * If a storage service error occurred. */ @Override @DoesServiceRequest public void upload(final InputStream sourceStream, final long length) throws StorageException, IOException { this.upload(sourceStream, length, null /* accessCondition */, null /* options */, null /* opContext */); } /** * Uploads the source stream data to the page blob using the specified lease ID, request options, and operation * context. * * @param sourceStream * An IntputStream object to read from. * @param length * The length, in bytes, of the stream data. This must be great than zero and a multiple of 512. * @param accessCondition * An {@link AccessCondition} object that represents the access conditions for the blob. * @param options * A {@link BlobRequestOptions} object that specifies any additional options for the request. Specifying * null will use the default request options from the associated service client ( * {@link CloudBlobClient}). * @param opContext * An {@link OperationContext} object that represents the context for the current operation. This object * is used to track requests to the storage service, and to provide additional runtime information about * the operation. * * @throws IOException * If an I/O exception occurred. * @throws StorageException * If a storage service error occurred. */ @Override @DoesServiceRequest public void upload(final InputStream sourceStream, final long length, final AccessCondition accessCondition, BlobRequestOptions options, OperationContext opContext) throws StorageException, IOException { assertNoWriteOperationForSnapshot(); if (opContext == null) { opContext = new OperationContext(); } options = BlobRequestOptions.applyDefaults(options, BlobType.PAGE_BLOB, this.blobServiceClient); if (length <= 0 || length % BlobConstants.PAGE_SIZE != 0) { throw new IllegalArgumentException(SR.INVALID_PAGE_BLOB_LENGTH); } if (options.getStoreBlobContentMD5()) { throw new IllegalArgumentException(SR.BLOB_MD5_NOT_SUPPORTED_FOR_PAGE_BLOBS); } if (sourceStream.markSupported()) { // Mark sourceStream for current position. sourceStream.mark(Constants.MAX_MARK_LENGTH); } final OutputStream streamRef = this.openOutputStream(length, accessCondition, options, opContext); Utility.writeToOutputStream(sourceStream, streamRef, length, false, false, opContext); streamRef.close(); } /** * Uploads a range of contiguous pages, up to 4 MB in size, at the specified offset in the page blob. * * @param sourceStream * An InputStream object that represents the input stream to write to the page blob. * @param offset * The offset, in number of bytes, at which to begin writing the data. This value must be a multiple of * 512. * @param length * The length, in bytes, of the data to write. This value must be a multiple of 512. * * @throws IllegalArgumentException * If the offset or length are not multiples of 512, or if the length is greater than 4 MB. * @throws IOException * If an I/O exception occurred. * @throws StorageException * If a storage service error occurred. */ @DoesServiceRequest public void uploadPages(final InputStream sourceStream, final long offset, final long length) throws StorageException, IOException { this.uploadPages(sourceStream, offset, length, null /* accessCondition */, null /* options */, null /* opContext */); } /** * Uploads a range of contiguous pages, up to 4 MB in size, at the specified offset in the page blob, using the * specified lease ID, request options, and operation context. * * @param sourceStream * An InputStream object that represents the input stream to write to the page blob. * @param offset * The offset, in number of bytes, at which to begin writing the data. This value must be a multiple of * 512. * @param length * The length, in bytes, of the data to write. This value must be a multiple of 512. * @param accessCondition * An {@link AccessCondition} object that represents the access conditions for the blob. * @param options * A {@link BlobRequestOptions} object that specifies any additional options for the request. Specifying * null will use the default request options from the associated service client ( * {@link CloudBlobClient}). * @param opContext * An {@link OperationContext} object that represents the context for the current operation. This object * is used to track requests to the storage service, and to provide additional runtime information about * the operation. * * @throws IllegalArgumentException * If the offset or length are not multiples of 512, or if the length is greater than 4 MB. * @throws IOException * If an I/O exception occurred. * @throws StorageException * If a storage service error occurred. */ @DoesServiceRequest public void uploadPages(final InputStream sourceStream, final long offset, final long length, final AccessCondition accessCondition, BlobRequestOptions options, OperationContext opContext) throws StorageException, IOException { if (offset % BlobConstants.PAGE_SIZE != 0) { throw new IllegalArgumentException(SR.INVALID_PAGE_START_OFFSET); } if (length == 0 || length % BlobConstants.PAGE_SIZE != 0) { throw new IllegalArgumentException(SR.INVALID_PAGE_BLOB_LENGTH); } if (length > 4 * Constants.MB) { throw new IllegalArgumentException(SR.INVALID_MAX_WRITE_SIZE); } assertNoWriteOperationForSnapshot(); if (opContext == null) { opContext = new OperationContext(); } options = BlobRequestOptions.applyDefaults(options, BlobType.PAGE_BLOB, this.blobServiceClient); final PageProperties pageProps = new PageProperties(); pageProps.setPageOperation(PageOperationType.UPDATE); pageProps.getRange().setStartOffset(offset); pageProps.getRange().setEndOffset(offset + length - 1); final byte[] data = new byte[(int) length]; String md5 = null; int count = 0; int total = 0; while (total < length) { count = sourceStream.read(data, total, (int) Math.min(length - total, Integer.MAX_VALUE)); total += count; } if (options.getUseTransactionalContentMD5()) { try { final MessageDigest digest = MessageDigest.getInstance("MD5"); digest.update(data, 0, data.length); md5 = Base64.encode(digest.digest()); } catch (final NoSuchAlgorithmException e) { // This wont happen, throw fatal. throw Utility.generateNewUnexpectedStorageException(e); } } this.putPagesInternal(pageProps, data, length, md5, accessCondition, options, opContext); } /** * Sets the number of bytes to buffer when writing to a {@link BlobOutputStream}. * * @param pageBlobStreamWriteSizeInBytes * The maximum number of bytes to buffer when writing to a page blob stream. This value must be a * multiple of 512 and * less than or equal to 4 MB. * * @throws IllegalArgumentException * If streamWriteSizeInBytes is less than 512, greater than 4 MB, or not a multiple or 512. */ @Override public void setStreamWriteSizeInBytes(final int streamWriteSizeInBytes) { if (streamWriteSizeInBytes > BlobConstants.MAX_COMMIT_SIZE_4_MB || streamWriteSizeInBytes < BlobConstants.PAGE_SIZE || streamWriteSizeInBytes % BlobConstants.PAGE_SIZE != 0) { throw new IllegalArgumentException("StreamWriteSizeInBytes"); } this.streamWriteSizeInBytes = streamWriteSizeInBytes; } }





© 2015 - 2025 Weber Informatics LLC | Privacy Policy