Modifier and Type | Method and Description |
---|---|
KeyValue |
KeyValue.copy(InternalRowSerializer keySerializer,
InternalRowSerializer valueSerializer) |
static CoreOptions.StreamingReadMode |
CoreOptions.StreamingReadMode.fromValue(String value) |
static CoreOptions.IncrementalBetweenScanMode |
CoreOptions.IncrementalBetweenScanMode.fromValue(String value) |
String |
KeyValue.toString(RowType keyType,
RowType valueType) |
Modifier and Type | Method and Description |
---|---|
RowBuffer |
AppendOnlyWriter.getWriteBuffer() |
Modifier and Type | Method and Description |
---|---|
protected CompactResult |
CompactFutureManager.obtainCompactResult() |
Modifier and Type | Method and Description |
---|---|
DeletionVectorsMaintainer |
DeletionVectorsMaintainer.Factory.createOrRestore(Long snapshotId,
BinaryRow partition) |
Map<String,DeletionVector> |
DeletionVectorsMaintainer.deletionVectors() |
Modifier and Type | Method and Description |
---|---|
List<ChannelWithMeta> |
ExternalBuffer.getSpillChannels() |
Modifier and Type | Method and Description |
---|---|
static FlinkGenericCatalog |
FlinkGenericCatalogFactory.createCatalog(ClassLoader cl,
Map<String,String> optionMap,
String name,
org.apache.flink.table.catalog.Catalog flinkCatalog) |
org.apache.flink.table.factories.CatalogFactory.Context |
FlinkGenericCatalogFactory.filterContextOptions(org.apache.flink.table.factories.CatalogFactory.Context context,
org.apache.flink.table.factories.CatalogFactory catalogFactory) |
Modifier and Type | Method and Description |
---|---|
Map<String,String> |
ActionBase.catalogConfig() |
Modifier and Type | Method and Description |
---|---|
FileStoreTable |
SyncTableActionBase.fileStoreTable() |
Map<String,String> |
SynchronizationActionBase.tableConfig() |
Modifier and Type | Method and Description |
---|---|
List<Identifier> |
MySqlSyncDatabaseAction.excludedTables() |
List<Identifier> |
MySqlSyncDatabaseAction.monitoredTables() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Void> |
RemoteTableQuery.cancel() |
Modifier and Type | Method and Description |
---|---|
CommitterMetrics |
StoreCommitter.getCommitterMetrics() |
org.apache.flink.metrics.Counter |
CommitterMetrics.getNumBytesOutCounter() |
org.apache.flink.metrics.Counter |
CommitterMetrics.getNumRecordsOutCounter() |
StoreSinkWrite |
TableWriteOperator.getWrite() |
TableWriteImpl<?> |
StoreSinkWriteImpl.getWrite() |
Modifier and Type | Method and Description |
---|---|
String |
CdcRecordStoreMultiWriteOperator.commitUser() |
Map<Identifier,FileStoreTable> |
CdcRecordStoreMultiWriteOperator.tables() |
Map<Identifier,StoreSinkWrite> |
CdcRecordStoreMultiWriteOperator.writes() |
Modifier and Type | Method and Description |
---|---|
SplitAssigner |
StaticFileStoreSplitEnumerator.getSplitAssigner() |
Constructor and Description |
---|
FormatContext(Options options,
int readBatchSize,
int writeBatchSize) |
Modifier and Type | Method and Description |
---|---|
protected OrcFile.WriterOptions |
OrcWriterFactory.getWriterOptions() |
Properties |
OrcFileFormat.orcProperties() |
int |
OrcFileFormat.readBatchSize() |
Modifier and Type | Method and Description |
---|---|
void |
HadoopFileIO.setFileSystem(Path path,
org.apache.hadoop.fs.FileSystem fs) |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.hive.metastore.IMetaStoreClient |
HiveCatalog.getHmsClient() |
Modifier and Type | Method and Description |
---|---|
boolean |
HashIndexMaintainer.isEmpty() |
Modifier and Type | Method and Description |
---|---|
DataFilePathFactory |
KeyValueFileWriterFactory.pathFactory(int level) |
long |
RollingFileWriter.targetFileSize() |
String |
DataFilePathFactory.uuid() |
Modifier and Type | Method and Description |
---|---|
Cache |
CacheManager.cache() |
Modifier and Type | Method and Description |
---|---|
JdbcClientPool |
JdbcCatalog.getConnections() |
Modifier and Type | Method and Description |
---|---|
long |
ManifestFile.suggestedFileSize() |
Modifier and Type | Method and Description |
---|---|
Iterable<MemoryOwner> |
MemoryPoolFactory.memoryOwners() |
Modifier and Type | Method and Description |
---|---|
void |
SortedRun.validate(Comparator<InternalRow> comparator) |
Modifier and Type | Method and Description |
---|---|
Levels |
MergeTreeCompactManager.levels() |
Modifier and Type | Class and Description |
---|---|
static class |
AbstractFileStoreWrite.WriterContainer<T>
RecordWriter with the snapshot id it is created upon and the identifier of its last
modified commit. |
Modifier and Type | Method and Description |
---|---|
boolean |
KeyValueFileStoreWrite.bufferSpillable() |
AbstractFileStoreWrite.WriterContainer<T> |
AbstractFileStoreWrite.createWriterContainer(BinaryRow partition,
int bucket,
boolean ignorePreviousFiles) |
ExecutorService |
AbstractFileStoreWrite.getCompactExecutor() |
Modifier and Type | Method and Description |
---|---|
protected static Map<BinaryRow,Set<Integer>> |
CommitStats.changedPartBuckets(List<ManifestEntry>... changes) |
protected static List<BinaryRow> |
CommitStats.changedPartitions(List<ManifestEntry>... changes) |
protected int |
CommitStats.getAttempts() |
protected long |
CommitStats.getChangelogFilesAppended() |
protected long |
CommitStats.getChangelogFilesCompacted() |
protected long |
CommitStats.getChangelogRecordsAppended() |
protected long |
CommitStats.getChangelogRecordsCompacted() |
protected long |
CommitStats.getDeltaRecordsAppended() |
protected long |
CommitStats.getDeltaRecordsCompacted() |
protected long |
CommitStats.getDuration() |
protected long |
ScanStats.getDuration() |
protected long |
CommitStats.getGeneratedSnapshots() |
MetricGroup |
CommitMetrics.getMetricGroup() |
MetricGroup |
CompactionMetrics.getMetricGroup() |
MetricGroup |
ScanMetrics.getMetricGroup() |
protected long |
CommitStats.getNumBucketsWritten() |
protected long |
CommitStats.getNumPartitionsWritten() |
protected long |
ScanStats.getResultedTableFiles() |
protected long |
ScanStats.getScannedManifests() |
protected long |
ScanStats.getSkippedByPartitionAndStats() |
protected long |
ScanStats.getSkippedByWholeBucketFiles() |
protected long |
ScanStats.getSkippedTableFiles() |
protected long |
CommitStats.getTableFilesAdded() |
protected long |
CommitStats.getTableFilesAppended() |
protected long |
CommitStats.getTableFilesCompacted() |
protected long |
CommitStats.getTableFilesDeleted() |
protected static long |
CommitStats.numChangedBuckets(List<ManifestEntry>... changes) |
protected static long |
CommitStats.numChangedPartitions(List<ManifestEntry>... changes) |
Modifier and Type | Method and Description |
---|---|
Path |
SchemaManager.toSchemaPath(long schemaId) |
Modifier and Type | Method and Description |
---|---|
void |
BinaryExternalSortBuffer.write(MutableObjectIterator<BinaryRow> iterator) |
Modifier and Type | Method and Description |
---|---|
int |
ExpireSnapshotsImpl.expireUntil(long earliestId,
long endExclusiveId) |
SnapshotDeletion |
ExpireSnapshotsImpl.snapshotDeletion() |
Modifier and Type | Method and Description |
---|---|
ExecutorService |
TableCommitImpl.getExpireMainExecutor() |
FileStoreWrite<T> |
TableWriteImpl.getWrite() |
Constructor and Description |
---|
CommitMessageImpl(BinaryRow partition,
int bucket,
DataIncrement dataIncrement,
CompactIncrement compactIncrement) |
Modifier and Type | Method and Description |
---|---|
AbstractDataTableScan |
AbstractDataTableScan.withBucket(int bucket) |
Modifier and Type | Method and Description |
---|---|
List<String> |
TagManager.allTagNames() |
static RoaringBitmap32 |
RoaringBitmap32.bitmapOf(int... dat) |
static RoaringBitmap64 |
RoaringBitmap64.bitmapOf(long... dat) |
BloomFilter |
BloomFilter.Builder.getFilter() |
static InternalRowPartitionComputer |
FileStorePathFactory.getPartitionComputer(RowType partitionType,
String defaultPartValue,
boolean legacyPartitionName) |
static byte[] |
HllSketchUtil.sketchOf(int... values) |
static byte[] |
ThetaSketch.sketchOf(int... values) |
String |
FileStorePathFactory.uuid() |
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.