| Package | Description |
|---|---|
| org.apache.hadoop.fs.s3a |
S3A Filesystem.
|
| org.apache.hadoop.fs.s3a.s3guard |
This package contains classes related to S3Guard: a feature of S3A to mask
the eventual consistency behavior of S3 and optimize access patterns by
coordinating with a strongly consistent external store for file system
metadata.
|
| Modifier and Type | Method and Description |
|---|---|
void |
WriteOperationHelper.abortMultipartCommit(String destKey,
String uploadId)
Abort a multipart commit operation.
|
void |
WriteOperationHelper.abortMultipartUpload(com.amazonaws.services.s3.model.MultipartUpload upload)
Abort a multipart commit operation.
|
void |
WriteOperationHelper.abortMultipartUpload(String destKey,
String uploadId,
Invoker.Retried retrying)
Abort a multipart upload operation.
|
int |
WriteOperationHelper.abortMultipartUploadsUnderPath(String prefix)
Abort multipart uploads under a path: limited to the first
few hundred.
|
void |
S3AFileSystem.abortOutstandingMultipartUploads(long seconds)
Abort all outstanding MPUs older than a given age.
|
com.amazonaws.services.s3.model.CompleteMultipartUploadResult |
WriteOperationHelper.completeMPUwithRetries(String destKey,
String uploadId,
List<com.amazonaws.services.s3.model.PartETag> partETags,
long length,
AtomicInteger errorCount)
This completes a multipart upload to the destination key via
finalizeMultipartUpload(). |
boolean |
S3AFileSystem.delete(org.apache.hadoop.fs.Path f,
boolean recursive)
Delete a Path.
|
String |
S3AFileSystem.getBucketLocation()
Get the region of a bucket.
|
String |
S3AFileSystem.getBucketLocation(String bucketName)
Get the region of a bucket.
|
org.apache.hadoop.fs.store.EtagChecksum |
S3AFileSystem.getFileChecksum(org.apache.hadoop.fs.Path f,
long length)
When enabled, get the etag of a object at the path via HEAD request and
return it as a checksum object.
|
org.apache.hadoop.fs.FileStatus |
S3AFileSystem.getFileStatus(org.apache.hadoop.fs.Path f)
Return a file status object that represents the path.
|
String |
WriteOperationHelper.initiateMultiPartUpload(String destKey)
Start the multipart upload process.
|
List<com.amazonaws.services.s3.model.MultipartUpload> |
S3AFileSystem.listMultipartUploads(String prefix)
Listing all multipart uploads; limited to the first few hundred.
|
com.amazonaws.services.s3.model.PutObjectResult |
WriteOperationHelper.putObject(com.amazonaws.services.s3.model.PutObjectRequest putObjectRequest)
PUT an object directly (i.e.
|
int |
S3AInputStream.read() |
int |
S3AInputStream.read(byte[] buf,
int off,
int len)
This updates the statistics on read operations started and whether
or not the read operation "completed", that is: returned the exact
number of bytes requested.
|
void |
S3AInputStream.readFully(long position,
byte[] buffer,
int offset,
int length)
Subclass
readFully() operation which only seeks at the start
of the series of operations; seeking back at the end. |
<T> T |
Invoker.retry(String action,
String path,
boolean idempotent,
Invoker.Operation<T> operation)
Execute a function with the default retry callback invoked.
|
<T> T |
Invoker.retry(String action,
String path,
boolean idempotent,
Invoker.Retried retrying,
Invoker.Operation<T> operation)
Execute a function with retry processing.
|
void |
Invoker.retry(String action,
String path,
boolean idempotent,
Invoker.Retried retrying,
Invoker.VoidOperation operation)
Execute a void operation with retry processing.
|
void |
Invoker.retry(String action,
String path,
boolean idempotent,
Invoker.VoidOperation operation)
Execute a void operation with the default retry callback invoked.
|
void |
WriteOperationHelper.revertCommit(String destKey)
Revert a commit by deleting the file.
|
com.amazonaws.services.s3.model.UploadPartResult |
WriteOperationHelper.uploadPart(com.amazonaws.services.s3.model.UploadPartRequest request)
Upload part of a multi-partition file.
|
protected void |
S3AFileSystem.verifyBucketExists()
Verify that the bucket exists.
|
| Constructor and Description |
|---|
UploadIterator(com.amazonaws.services.s3.AmazonS3 s3,
Invoker invoker,
String bucketName,
int maxKeys,
String prefix) |
| Modifier and Type | Method and Description |
|---|---|
void |
DynamoDBMetadataStore.delete(org.apache.hadoop.fs.Path path) |
void |
DynamoDBMetadataStore.deleteSubtree(org.apache.hadoop.fs.Path path) |
void |
DynamoDBMetadataStore.destroy() |
void |
DynamoDBMetadataStore.forgetMetadata(org.apache.hadoop.fs.Path path) |
DDBPathMetadata |
DynamoDBMetadataStore.get(org.apache.hadoop.fs.Path path) |
DDBPathMetadata |
DynamoDBMetadataStore.get(org.apache.hadoop.fs.Path path,
boolean wantEmptyDirectoryFlag) |
DirListingMetadata |
DynamoDBMetadataStore.listChildren(org.apache.hadoop.fs.Path path) |
void |
DynamoDBMetadataStore.move(Collection<org.apache.hadoop.fs.Path> pathsToDelete,
Collection<PathMetadata> pathsToCreate) |
void |
DynamoDBMetadataStore.prune(long modTime) |
void |
DynamoDBMetadataStore.prune(long modTime,
String keyPrefix)
Prune files, in batches.
|
void |
DynamoDBMetadataStore.put(Collection<PathMetadata> metas) |
void |
DynamoDBMetadataStore.put(DirListingMetadata meta)
Save directory listing metadata.
|
void |
DynamoDBMetadataStore.put(PathMetadata meta) |
Copyright © 2008–2021 Apache Software Foundation. All rights reserved.