Package | Description |
---|---|
org.apache.hadoop.fs.s3a |
S3A Filesystem.
|
org.apache.hadoop.fs.s3a.impl |
Implementation classes private to the S3A store.
|
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.
|
org.apache.hadoop.fs.s3a.select |
Support for S3 Select.
|
Constructor and Description |
---|
S3AInputStream(S3AReadOpContext ctx,
S3ObjectAttributes s3Attributes,
com.amazonaws.services.s3.AmazonS3 client)
Create the stream.
|
Modifier and Type | Method and Description |
---|---|
S3ObjectAttributes |
OperationCallbacks.createObjectAttributes(org.apache.hadoop.fs.Path path,
String eTag,
String versionId,
long len)
Create the attributes of an object for subsequent use.
|
S3ObjectAttributes |
OperationCallbacks.createObjectAttributes(S3AFileStatus fileStatus)
Create the attributes of an object for subsequent use.
|
Modifier and Type | Method and Description |
---|---|
com.amazonaws.services.s3.transfer.model.CopyResult |
OperationCallbacks.copyFile(String srcKey,
String destKey,
S3ObjectAttributes srcAttributes,
S3AReadOpContext readContext)
Copy a single object in the bucket via a COPY operation.
|
abstract String |
ChangeDetectionPolicy.getRevisionId(S3ObjectAttributes s3Attributes)
Like {
ChangeDetectionPolicy.getRevisionId(ObjectMetadata, String) }, but retrieves the
revision identifier from S3ObjectAttributes . |
Constructor and Description |
---|
ChangeTracker(String uri,
ChangeDetectionPolicy policy,
AtomicLong versionMismatches,
S3ObjectAttributes s3ObjectAttributes)
Create a change tracker.
|
Modifier and Type | Method and Description |
---|---|
abstract void |
RenameTracker.fileCopied(org.apache.hadoop.fs.Path childSource,
S3ObjectAttributes sourceAttributes,
S3ObjectAttributes destAttributes,
org.apache.hadoop.fs.Path destPath,
long blockSize,
boolean addAncestors)
A file has been copied.
|
void |
ProgressiveRenameTracker.fileCopied(org.apache.hadoop.fs.Path sourcePath,
S3ObjectAttributes sourceAttributes,
S3ObjectAttributes destAttributes,
org.apache.hadoop.fs.Path destPath,
long blockSize,
boolean addAncestors)
When a file is copied, any ancestors
are calculated and then the store is updated with
the destination entries.
|
void |
DelayedUpdateRenameTracker.fileCopied(org.apache.hadoop.fs.Path sourcePath,
S3ObjectAttributes sourceAttributes,
S3ObjectAttributes destAttributes,
org.apache.hadoop.fs.Path destPath,
long blockSize,
boolean addAncestors) |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.fs.FSDataInputStream |
SelectBinding.select(S3AReadOpContext readContext,
String expression,
org.apache.hadoop.conf.Configuration builderOptions,
Optional<com.amazonaws.services.s3.model.SSECustomerKey> sseKey,
S3ObjectAttributes objectAttributes)
Build and execute a select request.
|
Constructor and Description |
---|
SelectInputStream(S3AReadOpContext readContext,
S3ObjectAttributes objectAttributes,
com.amazonaws.services.s3.model.SelectObjectContentResult selectResponse)
Create the stream.
|
Copyright © 2008–2020 Apache Software Foundation. All rights reserved.