Modifier and Type | Method and Description |
---|---|
protected org.apache.flink.streaming.api.operators.OneInputStreamOperator<ManifestEntry,Committable> |
RewriteFileIndexSink.createWriteOperator(StoreSinkWrite.Provider writeProvider,
String commitUser) |
Modifier and Type | Method and Description |
---|---|
org.apache.flink.api.connector.source.SourceReader<ManifestEntry,RewriteFileIndexSource.Split> |
RewriteFileIndexSource.createReader(org.apache.flink.api.connector.source.SourceReaderContext sourceReaderContext) |
Constructor and Description |
---|
Split(ManifestEntry manifestEntry) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractIcebergCommitCallback.call(List<ManifestEntry> committedEntries,
Snapshot snapshot) |
Modifier and Type | Method and Description |
---|---|
ManifestEntry |
ManifestEntrySerializer.convertFrom(int version,
InternalRow row) |
ManifestEntry |
ManifestEntry.fromBytes(byte[] bytes) |
Modifier and Type | Method and Description |
---|---|
RollingFileWriter<ManifestEntry,ManifestFileMeta> |
ManifestFile.createRollingWriter() |
static Iterable<ManifestEntry> |
FileEntry.readManifestEntries(ManifestFile manifestFile,
List<ManifestFileMeta> manifestFiles,
Integer manifestReadParallelism) |
Modifier and Type | Method and Description |
---|---|
InternalRow |
ManifestEntrySerializer.convertTo(ManifestEntry entry) |
static SimpleFileEntry |
SimpleFileEntry.from(ManifestEntry entry) |
static PartitionEntry |
PartitionEntry.fromManifestEntry(ManifestEntry entry) |
static BucketEntry |
BucketEntry.fromManifestEntry(ManifestEntry entry) |
Modifier and Type | Method and Description |
---|---|
static List<SimpleFileEntry> |
SimpleFileEntry.from(List<ManifestEntry> entries) |
static Collection<PartitionEntry> |
PartitionEntry.merge(Collection<ManifestEntry> fileEntries) |
static Collection<BucketEntry> |
BucketEntry.merge(Collection<ManifestEntry> fileEntries) |
static void |
FileEntry.mergeEntries(ManifestFile manifestFile,
List<ManifestFileMeta> manifestFiles,
Map<FileEntry.Identifier,ManifestEntry> map,
Integer manifestReadParallelism) |
static long |
ManifestEntry.recordCount(List<ManifestEntry> manifestEntries) |
static long |
ManifestEntry.recordCountAdd(List<ManifestEntry> manifestEntries) |
static long |
ManifestEntry.recordCountDelete(List<ManifestEntry> manifestEntries) |
List<ManifestFileMeta> |
ManifestFile.write(List<ManifestEntry> entries)
Write several
ManifestEntry s into manifest files. |
Modifier and Type | Method and Description |
---|---|
void |
TagPreviewCommitCallback.call(List<ManifestEntry> committedEntries,
Snapshot snapshot) |
void |
AddPartitionCommitCallback.call(List<ManifestEntry> committedEntries,
Snapshot snapshot) |
Modifier and Type | Method and Description |
---|---|
java.util.function.Predicate<ManifestEntry> |
FileDeletionBase.createDataFileSkipperForTags(List<Snapshot> taggedSnapshots,
long expiringSnapshotId) |
java.util.function.Predicate<ManifestEntry> |
TagDeletion.dataFileSkipper(List<Snapshot> fromSnapshots) |
java.util.function.Predicate<ManifestEntry> |
TagDeletion.dataFileSkipper(Snapshot fromSnapshot) |
List<ManifestEntry> |
FileStoreScan.Plan.files()
Result
ManifestEntry files. |
default List<ManifestEntry> |
FileStoreScan.Plan.files(FileKind kind)
Result
ManifestEntry files with specific file kind. |
protected abstract List<ManifestEntry> |
AbstractFileStoreScan.filterWholeBucketByStats(List<ManifestEntry> entries)
Note: Keep this thread-safe.
|
protected List<ManifestEntry> |
KeyValueFileStoreScan.filterWholeBucketByStats(List<ManifestEntry> entries)
Note: Keep this thread-safe.
|
protected List<ManifestEntry> |
AppendOnlyFileStoreScan.filterWholeBucketByStats(List<ManifestEntry> entries) |
Iterator<ManifestEntry> |
FileStoreScan.readFileIterator() |
Iterator<ManifestEntry> |
AbstractFileStoreScan.readFileIterator() |
List<ManifestEntry> |
FileStoreScan.readManifest(ManifestFileMeta manifest) |
List<ManifestEntry> |
AbstractFileStoreScan.readManifest(ManifestFileMeta manifest)
Note: Keep this thread-safe.
|
protected Collection<ManifestEntry> |
FileDeletionBase.readMergedDataFiles(Snapshot snapshot) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
FileDeletionBase.containsDataFile(Map<BinaryRow,Map<Integer,Set<String>>> dataFiles,
ManifestEntry testee) |
protected abstract boolean |
AbstractFileStoreScan.filterByStats(ManifestEntry entry)
Note: Keep this thread-safe.
|
protected boolean |
KeyValueFileStoreScan.filterByStats(ManifestEntry entry)
Note: Keep this thread-safe.
|
protected boolean |
AppendOnlyFileStoreScan.filterByStats(ManifestEntry entry)
Note: Keep this thread-safe.
|
protected void |
FileDeletionBase.recordDeletionBuckets(ManifestEntry entry) |
Modifier and Type | Method and Description |
---|---|
void |
ChangelogDeletion.cleanUnusedDataFiles(Changelog changelog,
java.util.function.Predicate<ManifestEntry> skipper) |
void |
SnapshotDeletion.cleanUnusedDataFiles(Snapshot snapshot,
java.util.function.Predicate<ManifestEntry> skipper) |
void |
TagDeletion.cleanUnusedDataFiles(Snapshot taggedSnapshot,
java.util.function.Predicate<ManifestEntry> skipper) |
void |
FileDeletionBase.cleanUnusedDataFiles(String manifestList,
java.util.function.Predicate<ManifestEntry> skipper) |
abstract void |
FileDeletionBase.cleanUnusedDataFiles(T snapshot,
java.util.function.Predicate<ManifestEntry> skipper)
Clean data files that will not be used anymore in the snapshot.
|
protected void |
FileDeletionBase.doCleanUnusedDataFile(Map<Path,Pair<ManifestEntry,List<Path>>> dataFileToDelete,
java.util.function.Predicate<ManifestEntry> skipper) |
protected void |
FileDeletionBase.doCleanUnusedDataFile(Map<Path,Pair<ManifestEntry,List<Path>>> dataFileToDelete,
java.util.function.Predicate<ManifestEntry> skipper) |
protected abstract List<ManifestEntry> |
AbstractFileStoreScan.filterWholeBucketByStats(List<ManifestEntry> entries)
Note: Keep this thread-safe.
|
protected List<ManifestEntry> |
KeyValueFileStoreScan.filterWholeBucketByStats(List<ManifestEntry> entries)
Note: Keep this thread-safe.
|
protected List<ManifestEntry> |
AppendOnlyFileStoreScan.filterWholeBucketByStats(List<ManifestEntry> entries) |
protected void |
FileDeletionBase.getDataFileToDelete(Map<Path,Pair<ManifestEntry,List<Path>>> dataFileToDelete,
List<ManifestEntry> dataFileEntries) |
protected void |
FileDeletionBase.getDataFileToDelete(Map<Path,Pair<ManifestEntry,List<Path>>> dataFileToDelete,
List<ManifestEntry> dataFileEntries) |
static Map<BinaryRow,Map<Integer,List<DataFileMeta>>> |
FileStoreScan.Plan.groupByPartFiles(List<ManifestEntry> files)
Return a map group by partition and bucket.
|
FileStoreScan |
FileStoreScan.withManifestEntryFilter(Filter<ManifestEntry> filter) |
FileStoreScan |
AbstractFileStoreScan.withManifestEntryFilter(Filter<ManifestEntry> filter) |
Constructor and Description |
---|
CommitStats(List<ManifestEntry> appendTableFiles,
List<ManifestEntry> appendChangelogFiles,
List<ManifestEntry> compactTableFiles,
List<ManifestEntry> compactChangelogFiles,
long commitDuration,
int generatedSnapshots,
int attempts) |
CommitStats(List<ManifestEntry> appendTableFiles,
List<ManifestEntry> appendChangelogFiles,
List<ManifestEntry> compactTableFiles,
List<ManifestEntry> compactChangelogFiles,
long commitDuration,
int generatedSnapshots,
int attempts) |
CommitStats(List<ManifestEntry> appendTableFiles,
List<ManifestEntry> appendChangelogFiles,
List<ManifestEntry> compactTableFiles,
List<ManifestEntry> compactChangelogFiles,
long commitDuration,
int generatedSnapshots,
int attempts) |
CommitStats(List<ManifestEntry> appendTableFiles,
List<ManifestEntry> appendChangelogFiles,
List<ManifestEntry> compactTableFiles,
List<ManifestEntry> compactChangelogFiles,
long commitDuration,
int generatedSnapshots,
int attempts) |
Modifier and Type | Method and Description |
---|---|
SimpleFileReader<ManifestEntry> |
Table.manifestFileReader()
Reader to read manifest entry from manifest file.
|
default SimpleFileReader<ManifestEntry> |
FormatTable.manifestFileReader() |
default SimpleFileReader<ManifestEntry> |
ReadonlyTable.manifestFileReader() |
SimpleFileReader<ManifestEntry> |
DelegatedFileStoreTable.manifestFileReader() |
Modifier and Type | Method and Description |
---|---|
void |
CommitCallback.call(List<ManifestEntry> committedEntries,
Snapshot snapshot) |
Modifier and Type | Method and Description |
---|---|
Iterator<ManifestEntry> |
SnapshotReader.readFileIterator() |
Iterator<ManifestEntry> |
SnapshotReaderImpl.readFileIterator() |
List<ManifestEntry> |
SnapshotReader.readManifest(ManifestFileMeta manifest) |
List<ManifestEntry> |
SnapshotReaderImpl.readManifest(ManifestFileMeta manifest) |
Modifier and Type | Method and Description |
---|---|
SnapshotReader |
SnapshotReader.withManifestEntryFilter(Filter<ManifestEntry> filter) |
SnapshotReader |
SnapshotReaderImpl.withManifestEntryFilter(Filter<ManifestEntry> filter) |
Modifier and Type | Method and Description |
---|---|
SimpleFileReader<ManifestEntry> |
FileMonitorTable.manifestFileReader() |
SimpleFileReader<ManifestEntry> |
CompactBucketsTable.manifestFileReader() |
SimpleFileReader<ManifestEntry> |
AuditLogTable.manifestFileReader() |
SimpleFileReader<ManifestEntry> |
ReadOptimizedTable.manifestFileReader() |
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.