| Package | Description |
|---|---|
| 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 | Class and Description |
|---|---|
class |
DDBPathMetadata
DDBPathMetadata wraps PathMetadata and adds the
isAuthoritativeDir flag to provide support for authoritative directory
listings in DynamoDBMetadataStore. |
| Modifier and Type | Field and Description |
|---|---|
static Collection<PathMetadata> |
DirListingMetadata.EMPTY_DIR
Convenience parameter for passing into constructor.
|
| Modifier and Type | Method and Description |
|---|---|
PathMetadata |
DirListingMetadata.get(org.apache.hadoop.fs.Path childPath)
Lookup entry within this directory listing.
|
PathMetadata |
MetadataStore.get(org.apache.hadoop.fs.Path path)
Gets metadata for a path.
|
PathMetadata |
NullMetadataStore.get(org.apache.hadoop.fs.Path path) |
PathMetadata |
LocalMetadataStore.get(org.apache.hadoop.fs.Path p) |
PathMetadata |
MetadataStore.get(org.apache.hadoop.fs.Path path,
boolean wantEmptyDirectoryFlag)
Gets metadata for a path.
|
PathMetadata |
NullMetadataStore.get(org.apache.hadoop.fs.Path path,
boolean wantEmptyDirectoryFlag) |
PathMetadata |
LocalMetadataStore.get(org.apache.hadoop.fs.Path p,
boolean wantEmptyDirectoryFlag) |
PathMetadata |
LocalMetadataEntry.getFileMeta() |
static PathMetadata |
PathMetadata.tombstone(org.apache.hadoop.fs.Path path)
Create a tombstone from the current time.
|
| Modifier and Type | Method and Description |
|---|---|
Collection<PathMetadata> |
DirListingMetadata.getListing() |
| Modifier and Type | Method and Description |
|---|---|
void |
MetadataStore.put(PathMetadata meta)
Saves metadata for exactly one path.
|
void |
NullMetadataStore.put(PathMetadata meta) |
void |
DynamoDBMetadataStore.put(PathMetadata meta) |
void |
LocalMetadataStore.put(PathMetadata meta) |
void |
LocalMetadataEntry.setPathMetadata(PathMetadata pathMetadata) |
| Modifier and Type | Method and Description |
|---|---|
static void |
S3Guard.addMoveAncestors(MetadataStore ms,
Collection<org.apache.hadoop.fs.Path> srcPaths,
Collection<PathMetadata> dstMetas,
org.apache.hadoop.fs.Path srcRoot,
org.apache.hadoop.fs.Path srcPath,
org.apache.hadoop.fs.Path dstPath,
String owner)
Helper method that records the move of all ancestors of a path.
|
static void |
S3Guard.addMoveDir(MetadataStore ms,
Collection<org.apache.hadoop.fs.Path> srcPaths,
Collection<PathMetadata> dstMetas,
org.apache.hadoop.fs.Path srcPath,
org.apache.hadoop.fs.Path dstPath,
String owner)
Helper function that records the move of directory paths, adding
resulting metadata to the supplied lists.
|
static void |
S3Guard.addMoveFile(MetadataStore ms,
Collection<org.apache.hadoop.fs.Path> srcPaths,
Collection<PathMetadata> dstMetas,
org.apache.hadoop.fs.Path srcPath,
org.apache.hadoop.fs.Path dstPath,
long size,
long blockSize,
String owner)
Like
S3Guard.addMoveDir(MetadataStore, Collection, Collection, Path,
Path, String) (), but for files. |
void |
MetadataStore.move(Collection<org.apache.hadoop.fs.Path> pathsToDelete,
Collection<PathMetadata> pathsToCreate)
Record the effects of a
FileSystem.rename(Path, Path) in the
MetadataStore. |
void |
NullMetadataStore.move(Collection<org.apache.hadoop.fs.Path> pathsToDelete,
Collection<PathMetadata> pathsToCreate) |
void |
DynamoDBMetadataStore.move(Collection<org.apache.hadoop.fs.Path> pathsToDelete,
Collection<PathMetadata> pathsToCreate) |
void |
LocalMetadataStore.move(Collection<org.apache.hadoop.fs.Path> pathsToDelete,
Collection<PathMetadata> pathsToCreate) |
void |
MetadataStore.put(Collection<PathMetadata> metas)
Saves metadata for any number of paths.
|
void |
NullMetadataStore.put(Collection<PathMetadata> meta) |
void |
DynamoDBMetadataStore.put(Collection<PathMetadata> metas) |
void |
LocalMetadataStore.put(Collection<PathMetadata> metas) |
| Constructor and Description |
|---|
DDBPathMetadata(PathMetadata pmd) |
DDBPathMetadata(PathMetadata pmd,
boolean isAuthoritativeDir) |
DescendantsIterator(MetadataStore ms,
PathMetadata meta)
Creates a new
DescendantsIterator. |
MetadataStoreListFilesIterator(MetadataStore ms,
PathMetadata meta,
boolean allowAuthoritative) |
| Constructor and Description |
|---|
DirListingMetadata(org.apache.hadoop.fs.Path path,
Collection<PathMetadata> listing,
boolean isAuthoritative)
Create a directory listing metadata container.
|
Copyright © 2008–2021 Apache Software Foundation. All rights reserved.