Modifier and Type | Method and Description |
---|---|
BucketMode |
AppendOnlyFileStore.bucketMode() |
BucketMode |
KeyValueFileStore.bucketMode() |
BucketMode |
FileStore.bucketMode() |
Modifier and Type | Field and Description |
---|---|
protected BucketMode |
ContinuousFileStoreSource.bucketMode |
Modifier and Type | Method and Description |
---|---|
protected SplitAssigner |
ContinuousFileSplitEnumerator.createSplitAssigner(BucketMode bucketMode) |
Constructor and Description |
---|
ContinuousFileSplitEnumerator(org.apache.flink.api.connector.source.SplitEnumeratorContext<FileStoreSourceSplit> context,
Collection<FileStoreSourceSplit> remainSplits,
Long nextSnapshotId,
long discoveryInterval,
StreamTableScan scan,
BucketMode bucketMode,
int splitMaxPerTask,
boolean shuffleBucketWithPartition) |
ContinuousFileStoreSource(ReadBuilder readBuilder,
Map<String,String> options,
Long limit,
BucketMode bucketMode) |
Modifier and Type | Method and Description |
---|---|
protected SplitAssigner |
AlignedContinuousFileSplitEnumerator.createSplitAssigner(BucketMode bucketMode) |
Constructor and Description |
---|
AlignedContinuousFileSplitEnumerator(org.apache.flink.api.connector.source.SplitEnumeratorContext<FileStoreSourceSplit> context,
Collection<FileStoreSourceSplit> remainSplits,
Long nextSnapshotId,
long discoveryInterval,
StreamTableScan scan,
BucketMode bucketMode,
long alignTimeout,
int splitPerTaskMax,
boolean shuffleBucketWithPartition) |
AlignedContinuousFileStoreSource(ReadBuilder readBuilder,
Map<String,String> options,
Long limit,
BucketMode bucketMode) |
Modifier and Type | Method and Description |
---|---|
static org.apache.flink.streaming.api.datastream.DataStream<org.apache.flink.table.data.RowData> |
MonitorFunction.buildSource(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env,
String name,
org.apache.flink.api.common.typeinfo.TypeInformation<org.apache.flink.table.data.RowData> typeInfo,
ReadBuilder readBuilder,
long monitorInterval,
boolean emitSnapshotWatermark,
boolean shuffleBucketWithPartition,
BucketMode bucketMode) |
Modifier and Type | Method and Description |
---|---|
String |
IndexManifestFile.writeIndexFiles(String previousIndexManifest,
List<IndexManifestEntry> newIndexFiles,
BucketMode bucketMode)
Write new index files to index manifest.
|
Constructor and Description |
---|
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) |
Modifier and Type | Method and Description |
---|---|
BucketMode |
PrivilegedFileStore.bucketMode() |
Modifier and Type | Method and Description |
---|---|
default BucketMode |
FileStoreTable.bucketMode() |
BucketMode |
BucketSpec.getBucketMode() |
static BucketMode |
BucketMode.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static BucketMode[] |
BucketMode.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Constructor and Description |
---|
BucketSpec(BucketMode bucketMode,
List<String> bucketKeys,
int numBuckets) |
Modifier and Type | Method and Description |
---|---|
TableWriteImpl<T> |
TableWriteImpl.withBucketMode(BucketMode bucketMode) |
Constructor and Description |
---|
AppendOnlySplitGenerator(long targetSplitSize,
long openFileCost,
BucketMode bucketMode) |
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.