Modifier and Type | Method and Description |
---|---|
static Changelog |
Changelog.fromPath(FileIO fileIO,
Path path) |
static Snapshot |
Snapshot.fromPath(FileIO fileIO,
Path path) |
Constructor and Description |
---|
AppendOnlyFileStore(FileIO fileIO,
SchemaManager schemaManager,
TableSchema schema,
CoreOptions options,
RowType partitionType,
RowType bucketKeyType,
RowType rowType,
String tableName,
CatalogEnvironment catalogEnvironment) |
KeyValueFileStore(FileIO fileIO,
SchemaManager schemaManager,
TableSchema schema,
boolean crossPartitionUpdate,
CoreOptions options,
RowType partitionType,
RowType bucketKeyType,
RowType keyType,
RowType valueType,
KeyValueFieldsExtractor keyValueFieldsExtractor,
MergeFunctionFactory<KeyValue> mfFactory,
String tableName,
CatalogEnvironment catalogEnvironment) |
Constructor and Description |
---|
AppendOnlyWriter(FileIO fileIO,
IOManager ioManager,
long schemaId,
FileFormat fileFormat,
long targetFileSize,
RowType writeSchema,
long maxSequenceNumber,
CompactManager compactManager,
IOFunction<List<DataFileMeta>,RecordReaderIterator<InternalRow>> bucketFileRead,
boolean forceCompact,
DataFilePathFactory pathFactory,
CommitIncrement increment,
boolean useWriteBuffer,
boolean spillable,
String fileCompression,
CompressOptions spillCompression,
SimpleColStatsCollector.Factory[] statsCollectors,
MemorySize maxDiskSize,
FileIndexOptions fileIndexOptions,
boolean asyncFileWrite,
boolean statsDenseStore) |
Modifier and Type | Field and Description |
---|---|
protected FileIO |
AbstractCatalog.fileIO |
Modifier and Type | Method and Description |
---|---|
FileIO |
DelegateCatalog.fileIO() |
FileIO |
Catalog.fileIO() |
FileIO |
AbstractCatalog.fileIO() |
Modifier and Type | Method and Description |
---|---|
Catalog |
FileSystemCatalogFactory.create(FileIO fileIO,
Path warehouse,
CatalogContext context) |
default Catalog |
CatalogFactory.create(FileIO fileIO,
Path warehouse,
CatalogContext context) |
Constructor and Description |
---|
AbstractCatalog(FileIO fileIO) |
AbstractCatalog(FileIO fileIO,
Options options) |
FileSystemCatalog(FileIO fileIO,
Path warehouse) |
FileSystemCatalog(FileIO fileIO,
Path warehouse,
Options options) |
Modifier and Type | Method and Description |
---|---|
static Optional<Consumer> |
Consumer.fromPath(FileIO fileIO,
Path path) |
Constructor and Description |
---|
ConsumerManager(FileIO fileIO,
Path tablePath) |
ConsumerManager(FileIO fileIO,
Path tablePath,
String branchName) |
Modifier and Type | Method and Description |
---|---|
static DeletionVector.Factory |
DeletionVector.factory(FileIO fileIO,
List<DataFileMeta> files,
List<DeletionFile> deletionFiles) |
static DeletionVector |
DeletionVector.read(FileIO fileIO,
DeletionFile deletionFile) |
Constructor and Description |
---|
DeletionVectorIndexFileWriter(FileIO fileIO,
PathFactory pathFactory,
MemorySize targetSizePerIndexFile) |
DeletionVectorsIndexFile(FileIO fileIO,
PathFactory pathFactory,
MemorySize targetSizePerIndexFile) |
Constructor and Description |
---|
FileIndexPredicate(Path path,
FileIO fileIO,
RowType fileRowType) |
Modifier and Type | Class and Description |
---|---|
class |
FlinkFileIO
Flink
FileIO to use FileSystem . |
Modifier and Type | Method and Description |
---|---|
FileIO |
FlinkFileIOLoader.load(Path path) |
Modifier and Type | Method and Description |
---|---|
FileIO |
FormatReaderContext.fileIO() |
FileIO |
FormatReaderFactory.Context.fileIO() |
Modifier and Type | Method and Description |
---|---|
SimpleColStats[] |
SimpleStatsExtractor.extract(FileIO fileIO,
Path path) |
Pair<SimpleColStats[],SimpleStatsExtractor.FileInfo> |
SimpleStatsExtractor.extractWithFileInfo(FileIO fileIO,
Path path) |
Constructor and Description |
---|
FormatReaderContext(FileIO fileIO,
Path file,
long fileSize) |
OrcFormatReaderContext(FileIO fileIO,
Path filePath,
long fileSize,
int poolSize) |
Modifier and Type | Method and Description |
---|---|
SimpleColStats[] |
AvroSimpleStatsExtractor.extract(FileIO fileIO,
Path path) |
Pair<SimpleColStats[],SimpleStatsExtractor.FileInfo> |
AvroSimpleStatsExtractor.extractWithFileInfo(FileIO fileIO,
Path path) |
Constructor and Description |
---|
HadoopReadOnlyFileSystem(FileIO fileIO) |
Modifier and Type | Method and Description |
---|---|
static org.apache.orc.Reader |
OrcReaderFactory.createReader(org.apache.hadoop.conf.Configuration conf,
FileIO fileIO,
Path path) |
Modifier and Type | Method and Description |
---|---|
SimpleColStats[] |
OrcSimpleStatsExtractor.extract(FileIO fileIO,
Path path) |
Pair<SimpleColStats[],SimpleStatsExtractor.FileInfo> |
OrcSimpleStatsExtractor.extractWithFileInfo(FileIO fileIO,
Path path) |
Modifier and Type | Method and Description |
---|---|
SimpleColStats[] |
ParquetSimpleStatsExtractor.extract(FileIO fileIO,
Path path) |
static Pair<Map<String,org.apache.parquet.column.statistics.Statistics<?>>,SimpleStatsExtractor.FileInfo> |
ParquetUtil.extractColumnStats(FileIO fileIO,
Path path)
Extract stats from specified Parquet files path.
|
Pair<SimpleColStats[],SimpleStatsExtractor.FileInfo> |
ParquetSimpleStatsExtractor.extractWithFileInfo(FileIO fileIO,
Path path) |
static ParquetInputFile |
ParquetInputFile.fromPath(FileIO fileIO,
Path path) |
static ParquetFileReader |
ParquetUtil.getParquetReader(FileIO fileIO,
Path path)
Generate
ParquetFileReader instance to read the Parquet files at the given path. |
Modifier and Type | Class and Description |
---|---|
class |
PluginFileIO
A
FileIO for plugin jar. |
Modifier and Type | Method and Description |
---|---|
protected abstract FileIO |
PluginFileIO.createFileIO(Path path) |
static FileIO |
FileIO.get(Path path,
CatalogContext config)
Returns a reference to the
FileIO instance for accessing the file system identified
by the given path. |
FileIO |
FileIOLoader.load(Path path) |
Modifier and Type | Class and Description |
---|---|
class |
HadoopFileIO
Hadoop
FileIO . |
Modifier and Type | Class and Description |
---|---|
class |
LocalFileIO
FileIO for local file. |
Modifier and Type | Method and Description |
---|---|
void |
StorageLocationHelper.createPathIfRequired(Path dbPath,
FileIO fileIO) |
void |
LocationHelper.createPathIfRequired(Path dbPath,
FileIO fileIO) |
void |
TBPropertiesLocationHelper.createPathIfRequired(Path path,
FileIO fileIO) |
void |
StorageLocationHelper.dropPathIfRequired(Path path,
FileIO fileIO) |
void |
LocationHelper.dropPathIfRequired(Path path,
FileIO fileIO) |
void |
TBPropertiesLocationHelper.dropPathIfRequired(Path path,
FileIO fileIO) |
Constructor and Description |
---|
HiveCatalog(FileIO fileIO,
org.apache.hadoop.hive.conf.HiveConf hiveConf,
String clientClassName,
Options options,
String warehouse) |
HiveCatalog(FileIO fileIO,
org.apache.hadoop.hive.conf.HiveConf hiveConf,
String clientClassName,
String warehouse) |
Modifier and Type | Method and Description |
---|---|
HiveMigrator.MigrateTask |
HiveMigrator.importUnPartitionedTableTask(FileIO fileIO,
org.apache.hadoop.hive.metastore.api.Table sourceTable,
FileStoreTable paimonTable,
Map<Path,Path> rollback) |
Constructor and Description |
---|
MigrateTask(FileIO fileIO,
String format,
String location,
FileStoreTable paimonTable,
BinaryRow partitionRow,
Path newDir,
Map<Path,Path> rollback) |
Modifier and Type | Method and Description |
---|---|
java.util.stream.Stream<Path> |
IcebergPathFactory.getAllMetadataPathBefore(FileIO fileIO,
long snapshotId) |
Constructor and Description |
---|
IcebergManifestFile(FileIO fileIO,
RowType partitionType,
FormatReaderFactory readerFactory,
FormatWriterFactory writerFactory,
String compression,
PathFactory pathFactory,
MemorySize targetFileSize) |
IcebergManifestList(FileIO fileIO,
FormatReaderFactory readerFactory,
FormatWriterFactory writerFactory,
String compression,
PathFactory pathFactory) |
Modifier and Type | Method and Description |
---|---|
static IcebergMetadata |
IcebergMetadata.fromPath(FileIO fileIO,
Path path) |
Modifier and Type | Field and Description |
---|---|
protected FileIO |
IndexFile.fileIO |
Constructor and Description |
---|
HashIndexFile(FileIO fileIO,
PathFactory pathFactory) |
IndexFile(FileIO fileIO,
PathFactory pathFactory) |
Modifier and Type | Field and Description |
---|---|
protected FileIO |
SingleFileWriter.fileIO |
Modifier and Type | Method and Description |
---|---|
FileIO |
KeyValueFileReaderFactory.Builder.fileIO() |
FileIO |
KeyValueFileWriterFactory.getFileIO() |
Modifier and Type | Method and Description |
---|---|
static KeyValueFileWriterFactory.Builder |
KeyValueFileWriterFactory.builder(FileIO fileIO,
long schemaId,
RowType keyType,
RowType valueType,
FileFormat fileFormat,
Map<String,FileStorePathFactory> format2PathFactory,
long suggestedFileSize) |
static KeyValueFileReaderFactory.Builder |
KeyValueFileReaderFactory.builder(FileIO fileIO,
SchemaManager schemaManager,
TableSchema schema,
RowType keyType,
RowType valueType,
FileFormatDiscover formatDiscover,
FileStorePathFactory pathFactory,
KeyValueFieldsExtractor extractor,
CoreOptions options) |
static DataFileIndexWriter |
DataFileIndexWriter.create(FileIO fileIO,
Path path,
RowType rowType,
FileIndexOptions fileIndexOptions) |
static DataFileIndexWriter |
DataFileIndexWriter.create(FileIO fileIO,
Path path,
RowType rowType,
FileIndexOptions fileIndexOptions,
Map<String,String> colNameMapping) |
static boolean |
FileIndexSkipper.skip(FileIO fileIO,
TableSchema dataSchema,
List<Predicate> dataFilter,
DataFilePathFactory dataFilePathFactory,
DataFileMeta file) |
Constructor and Description |
---|
DataFileIndexWriter(FileIO fileIO,
Path path,
RowType rowType,
FileIndexOptions fileIndexOptions,
Map<String,String> colNameMapping) |
KeyValueDataFileWriter(FileIO fileIO,
FormatWriterFactory factory,
Path path,
java.util.function.Function<KeyValue,InternalRow> converter,
RowType keyType,
RowType valueType,
SimpleStatsExtractor simpleStatsExtractor,
long schemaId,
int level,
String compression,
CoreOptions options,
FileSource fileSource,
FileIndexOptions fileIndexOptions) |
RowDataFileWriter(FileIO fileIO,
FormatWriterFactory factory,
Path path,
RowType writeSchema,
SimpleStatsExtractor simpleStatsExtractor,
long schemaId,
LongCounter seqNumCounter,
String fileCompression,
SimpleColStatsCollector.Factory[] statsCollectors,
FileIndexOptions fileIndexOptions,
FileSource fileSource,
boolean asyncFileWrite,
boolean statsDenseStore) |
RowDataRollingFileWriter(FileIO fileIO,
long schemaId,
FileFormat fileFormat,
long targetFileSize,
RowType writeSchema,
DataFilePathFactory pathFactory,
LongCounter seqNumCounter,
String fileCompression,
SimpleColStatsCollector.Factory[] statsCollectors,
FileIndexOptions fileIndexOptions,
FileSource fileSource,
boolean asyncFileWrite,
boolean statsDenseStore) |
SingleFileWriter(FileIO fileIO,
FormatWriterFactory factory,
Path path,
java.util.function.Function<T,InternalRow> converter,
String compression,
boolean asyncWrite) |
StatsCollectingSingleFileWriter(FileIO fileIO,
FormatWriterFactory factory,
Path path,
java.util.function.Function<T,InternalRow> converter,
RowType writeSchema,
SimpleStatsExtractor simpleStatsExtractor,
String compression,
SimpleColStatsCollector.Factory[] statsCollectors,
boolean asyncWrite) |
Modifier and Type | Method and Description |
---|---|
Catalog |
JdbcCatalogFactory.create(FileIO fileIO,
Path warehouse,
CatalogContext context) |
Constructor and Description |
---|
JdbcCatalog(FileIO fileIO,
String catalogKey,
Options options,
String warehouse) |
Constructor and Description |
---|
Factory(FileIO fileIO,
FileFormat fileFormat,
String compression,
FileStorePathFactory pathFactory,
SegmentsCache<Path> cache) |
Factory(FileIO fileIO,
FileFormat fileFormat,
String compression,
FileStorePathFactory pathFactory,
SegmentsCache<Path> cache) |
Factory(FileIO fileIO,
SchemaManager schemaManager,
RowType partitionType,
FileFormat fileFormat,
String compression,
FileStorePathFactory pathFactory,
long suggestedFileSize,
SegmentsCache<Path> cache) |
Modifier and Type | Method and Description |
---|---|
static List<DataFileMeta> |
FileMetaUtils.construct(FileIO fileIO,
String format,
String location,
Table paimonTable,
java.util.function.Predicate<FileStatus> filter,
Path dir,
Map<Path,Path> rollback) |
Modifier and Type | Field and Description |
---|---|
protected FileIO |
FileDeletionBase.fileIO |
protected FileIO |
OrphanFilesClean.fileIO |
Modifier and Type | Method and Description |
---|---|
FileIO |
FileStoreCommitImpl.fileIO() |
FileIO |
FileStoreCommit.fileIO() |
Constructor and Description |
---|
AppendOnlyFileStoreWrite(FileIO fileIO,
RawFileSplitRead read,
long schemaId,
RowType rowType,
RowType partitionType,
FileStorePathFactory pathFactory,
SnapshotManager snapshotManager,
FileStoreScan scan,
CoreOptions options,
DeletionVectorsMaintainer.Factory dvMaintainerFactory,
String tableName) |
AppendOnlyFixedBucketFileStoreWrite(FileIO fileIO,
RawFileSplitRead read,
long schemaId,
String commitUser,
RowType rowType,
RowType partitionType,
FileStorePathFactory pathFactory,
SnapshotManager snapshotManager,
FileStoreScan scan,
CoreOptions options,
DeletionVectorsMaintainer.Factory dvMaintainerFactory,
String tableName) |
AppendOnlyUnawareBucketFileStoreWrite(FileIO fileIO,
RawFileSplitRead read,
long schemaId,
RowType rowType,
RowType partitionType,
FileStorePathFactory pathFactory,
SnapshotManager snapshotManager,
FileStoreScan scan,
CoreOptions options,
DeletionVectorsMaintainer.Factory dvMaintainerFactory,
String tableName) |
ChangelogDeletion(FileIO fileIO,
FileStorePathFactory pathFactory,
ManifestFile manifestFile,
ManifestList manifestList,
IndexFileHandler indexFileHandler,
StatsFileHandler statsFileHandler,
boolean cleanEmptyDirectories,
int deleteFileThreadNum) |
FileDeletionBase(FileIO fileIO,
FileStorePathFactory pathFactory,
ManifestFile manifestFile,
ManifestList manifestList,
IndexFileHandler indexFileHandler,
StatsFileHandler statsFileHandler,
boolean cleanEmptyDirectories,
int deleteFileThreadNum) |
FileStoreCommitImpl(FileIO fileIO,
SchemaManager schemaManager,
String tableName,
String commitUser,
RowType partitionType,
String partitionDefaultName,
FileStorePathFactory pathFactory,
SnapshotManager snapshotManager,
ManifestFile.Factory manifestFileFactory,
ManifestList.Factory manifestListFactory,
IndexManifestFile.Factory indexManifestFileFactory,
FileStoreScan scan,
int numBucket,
MemorySize manifestTargetSize,
MemorySize manifestFullCompactionSize,
int manifestMergeMinCount,
boolean dynamicPartitionOverwrite,
Comparator<InternalRow> keyComparator,
String branchName,
StatsFileHandler statsFileHandler,
BucketMode bucketMode,
Integer manifestReadParallelism,
List<CommitCallback> commitCallbacks,
int commitMaxRetries) |
KeyValueFileStoreWrite(FileIO fileIO,
SchemaManager schemaManager,
TableSchema schema,
String commitUser,
RowType partitionType,
RowType keyType,
RowType valueType,
java.util.function.Supplier<Comparator<InternalRow>> keyComparatorSupplier,
java.util.function.Supplier<FieldsComparator> udsComparatorSupplier,
java.util.function.Supplier<RecordEqualiser> logDedupEqualSupplier,
MergeFunctionFactory<KeyValue> mfFactory,
FileStorePathFactory pathFactory,
Map<String,FileStorePathFactory> format2PathFactory,
SnapshotManager snapshotManager,
FileStoreScan scan,
IndexMaintainer.Factory<KeyValue> indexFactory,
DeletionVectorsMaintainer.Factory deletionVectorsMaintainerFactory,
CoreOptions options,
KeyValueFieldsExtractor extractor,
String tableName) |
RawFileSplitRead(FileIO fileIO,
SchemaManager schemaManager,
TableSchema schema,
RowType rowType,
FileFormatDiscover formatDiscover,
FileStorePathFactory pathFactory,
boolean fileIndexReadEnabled) |
SnapshotDeletion(FileIO fileIO,
FileStorePathFactory pathFactory,
ManifestFile manifestFile,
ManifestList manifestList,
IndexFileHandler indexFileHandler,
StatsFileHandler statsFileHandler,
boolean produceChangelog,
boolean cleanEmptyDirectories,
int deleteFileThreadNum) |
TagDeletion(FileIO fileIO,
FileStorePathFactory pathFactory,
ManifestFile manifestFile,
ManifestList manifestList,
IndexFileHandler indexFileHandler,
StatsFileHandler statsFileHandler,
boolean cleanEmptyDirectories,
int deleteFileThreadNum) |
Modifier and Type | Class and Description |
---|---|
class |
OSSFileIO
OSS
FileIO . |
Modifier and Type | Method and Description |
---|---|
FileIO |
OSSLoader.load(Path path) |
Modifier and Type | Method and Description |
---|---|
static SuccessFile |
SuccessFileMarkDoneAction.safelyFromPath(FileIO fileIO,
Path path) |
Constructor and Description |
---|
SuccessFileMarkDoneAction(FileIO fileIO,
Path tablePath) |
Modifier and Type | Method and Description |
---|---|
static SuccessFile |
SuccessFile.fromPath(FileIO fileIO,
Path path) |
static SuccessFile |
SuccessFile.safelyFromPath(FileIO fileIO,
Path path) |
Constructor and Description |
---|
FileBasedPrivilegeManager(String warehouse,
FileIO fileIO,
String user,
String password) |
Modifier and Type | Class and Description |
---|---|
class |
HadoopCompliantFileIO
Hadoop
FileIO . |
class |
S3FileIO
S3
FileIO . |
Modifier and Type | Method and Description |
---|---|
FileIO |
S3Loader.load(Path path) |
Modifier and Type | Method and Description |
---|---|
static TableSchema |
SchemaManager.fromPath(FileIO fileIO,
Path path) |
static TableSchema |
TableSchema.fromPath(FileIO fileIO,
Path path) |
Constructor and Description |
---|
SchemaManager(FileIO fileIO,
Path tableRoot) |
SchemaManager(FileIO fileIO,
Path tableRoot,
String branch)
Specify the default branch for data writing.
|
Constructor and Description |
---|
ServiceManager(FileIO fileIO,
Path tablePath) |
Modifier and Type | Method and Description |
---|---|
static Statistics |
Statistics.fromPath(FileIO fileIO,
Path path) |
Constructor and Description |
---|
StatsFile(FileIO fileIO,
PathFactory pathFactory) |
Modifier and Type | Method and Description |
---|---|
FileIO |
DataTable.fileIO() |
FileIO |
DelegatedFileStoreTable.fileIO() |
Modifier and Type | Method and Description |
---|---|
static FileStoreTable |
FileStoreTableFactory.create(FileIO fileIO,
Options options) |
static FileStoreTable |
FileStoreTableFactory.create(FileIO fileIO,
Path path) |
static FileStoreTable |
FileStoreTableFactory.create(FileIO fileIO,
Path tablePath,
TableSchema tableSchema) |
static FileStoreTable |
FileStoreTableFactory.create(FileIO fileIO,
Path tablePath,
TableSchema tableSchema,
CatalogEnvironment catalogEnvironment) |
static FileStoreTable |
FileStoreTableFactory.create(FileIO fileIO,
Path tablePath,
TableSchema tableSchema,
Options dynamicOptions,
CatalogEnvironment catalogEnvironment) |
static FileStoreTable |
FileStoreTableFactory.createWithoutFallbackBranch(FileIO fileIO,
Path tablePath,
TableSchema tableSchema,
Options dynamicOptions,
CatalogEnvironment catalogEnvironment) |
Constructor and Description |
---|
RollbackHelper(SnapshotManager snapshotManager,
TagManager tagManager,
FileIO fileIO,
SnapshotDeletion snapshotDeletion,
ChangelogDeletion changelogDeletion,
TagDeletion tagDeletion) |
Modifier and Type | Method and Description |
---|---|
FileIO |
FileMonitorTable.fileIO() |
FileIO |
CompactBucketsTable.fileIO() |
FileIO |
AuditLogTable.fileIO() |
FileIO |
ReadOptimizedTable.fileIO() |
Modifier and Type | Method and Description |
---|---|
static Table |
SystemTableLoader.loadGlobal(String tableName,
FileIO fileIO,
java.util.function.Supplier<Map<String,Map<String,Path>>> allTablePaths,
Options catalogOptions,
LineageMetaFactory lineageMetaFactory) |
protected static Map<String,Map<String,Map<String,String>>> |
AllTableOptionsTable.options(FileIO fileIO,
Map<String,Map<String,Path>> allTablePaths) |
Constructor and Description |
---|
AggregationFieldsTable(FileIO fileIO,
Path location,
String branchName) |
AllTableOptionsTable(FileIO fileIO,
Map<String,Map<String,Path>> allTablePaths) |
BranchesTable(FileIO fileIO,
Path location) |
ConsumersTable(FileIO fileIO,
Path location,
String branchName) |
OptionsTable(FileIO fileIO,
Path location,
String branchName) |
SchemasTable(FileIO fileIO,
Path location,
String branchName) |
SnapshotsTable(FileIO fileIO,
Path location,
FileStoreTable dataTable,
String branchName) |
TagsTable(FileIO fileIO,
Path location,
String branchName) |
Modifier and Type | Method and Description |
---|---|
static Tag |
Tag.fromPath(FileIO fileIO,
Path path) |
static Tag |
Tag.safelyFromPath(FileIO fileIO,
Path path) |
Modifier and Type | Field and Description |
---|---|
protected FileIO |
ObjectsFile.fileIO |
Modifier and Type | Method and Description |
---|---|
FileIO |
ObjectsFile.fileIO() |
FileIO |
SnapshotManager.fileIO() |
Modifier and Type | Method and Description |
---|---|
static void |
FileUtils.checkExists(FileIO fileIO,
Path file) |
static RecordReader<InternalRow> |
FileUtils.createFormatReader(FileIO fileIO,
FormatReaderFactory format,
Path file,
Long fileSize) |
static java.util.stream.Stream<String> |
FileUtils.listOriginalVersionedFiles(FileIO fileIO,
Path dir,
String prefix)
List original versioned files for the directory.
|
static java.util.stream.Stream<FileStatus> |
FileUtils.listVersionedDirectories(FileIO fileIO,
Path dir,
String prefix)
List versioned directories for the directory.
|
static java.util.stream.Stream<Long> |
FileUtils.listVersionedFiles(FileIO fileIO,
Path dir,
String prefix)
List versioned files for the directory.
|
static java.util.stream.Stream<FileStatus> |
FileUtils.listVersionedFileStatus(FileIO fileIO,
Path dir,
String prefix)
List versioned file status for the directory.
|
static IntIterator |
IntFileUtils.readInts(FileIO fileIO,
Path path) |
static void |
IntFileUtils.writeInts(FileIO fileIO,
Path path,
IntIterator input) |
Constructor and Description |
---|
BranchManager(FileIO fileIO,
Path path,
SnapshotManager snapshotManager,
TagManager tagManager,
SchemaManager schemaManager) |
ObjectsFile(FileIO fileIO,
ObjectSerializer<T> serializer,
RowType formatType,
FormatReaderFactory readerFactory,
FormatWriterFactory writerFactory,
String compression,
PathFactory pathFactory,
SegmentsCache<Path> cache) |
SnapshotManager(FileIO fileIO,
Path tablePath) |
SnapshotManager(FileIO fileIO,
Path tablePath,
String branchName)
Specify the default branch for data writing.
|
TagManager(FileIO fileIO,
Path tablePath) |
TagManager(FileIO fileIO,
Path tablePath,
String branch)
Specify the default branch for data writing.
|
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.