Package | Description |
---|---|
org.apache.paimon.append | |
org.apache.paimon.flink.compact | |
org.apache.paimon.flink.sink | |
org.apache.paimon.flink.source | |
org.apache.paimon.table.sink |
Modifier and Type | Class and Description |
---|---|
class |
MultiTableAppendCompactTask
Compaction task for multi table .
|
Modifier and Type | Method and Description |
---|---|
List<AppendCompactTask> |
AppendCompactCoordinator.run() |
Modifier and Type | Method and Description |
---|---|
void |
AppendTableCompactor.processElement(AppendCompactTask task) |
Modifier and Type | Method and Description |
---|---|
void |
AppendPreCommitCompactWorkerOperator.processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<org.apache.flink.types.Either<Committable,org.apache.flink.api.java.tuple.Tuple2<Long,AppendCompactTask>>> record) |
Modifier and Type | Method and Description |
---|---|
AppendCompactTask |
CompactionTaskSimpleSerializer.deserialize(int compactionTaskVersion,
byte[] bytes) |
Modifier and Type | Method and Description |
---|---|
org.apache.flink.api.common.typeutils.TypeSerializer<AppendCompactTask> |
CompactionTaskTypeInfo.createSerializer(org.apache.flink.api.common.ExecutionConfig config)
Do not annotate with
@override here to maintain compatibility with Flink 2.0+. |
org.apache.flink.api.common.typeutils.TypeSerializer<AppendCompactTask> |
CompactionTaskTypeInfo.createSerializer(SerializerConfig config)
Do not annotate with
@override here to maintain compatibility with Flink 1.18-. |
protected org.apache.flink.streaming.api.operators.OneInputStreamOperatorFactory<AppendCompactTask,Committable> |
AppendTableCompactSink.createWriteOperatorFactory(StoreSinkWrite.Provider writeProvider,
String commitUser) |
Class<AppendCompactTask> |
CompactionTaskTypeInfo.getTypeClass() |
Modifier and Type | Method and Description |
---|---|
byte[] |
CompactionTaskSimpleSerializer.serialize(AppendCompactTask compactionTask) |
Modifier and Type | Method and Description |
---|---|
void |
AppendOnlySingleTableCompactionWorkerOperator.processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<AppendCompactTask> element) |
void |
AppendBypassCompactWorkerOperator.processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<org.apache.flink.types.Either<Committable,AppendCompactTask>> element) |
static org.apache.flink.streaming.api.datastream.DataStreamSink<?> |
AppendTableCompactSink.sink(FileStoreTable table,
org.apache.flink.streaming.api.datastream.DataStream<AppendCompactTask> input) |
Modifier and Type | Method and Description |
---|---|
<T extends org.apache.flink.streaming.api.operators.StreamOperator<org.apache.flink.types.Either<CommitT,AppendCompactTask>>> |
AppendBypassCoordinateOperatorFactory.createStreamOperator(org.apache.flink.streaming.api.operators.StreamOperatorParameters<org.apache.flink.types.Either<CommitT,AppendCompactTask>> parameters) |
Modifier and Type | Method and Description |
---|---|
static org.apache.flink.streaming.api.datastream.DataStreamSource<AppendCompactTask> |
AppendTableCompactSource.buildSource(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env,
AppendTableCompactSource source,
String tableIdentifier) |
org.apache.flink.api.connector.source.SourceReader<AppendCompactTask,SimpleSourceSplit> |
AppendTableCompactSource.createReader(org.apache.flink.api.connector.source.SourceReaderContext readerContext) |
Modifier and Type | Method and Description |
---|---|
<T extends org.apache.flink.streaming.api.operators.StreamOperator<org.apache.flink.types.Either<CommitT,AppendCompactTask>>> |
AppendBypassCoordinateOperatorFactory.createStreamOperator(org.apache.flink.streaming.api.operators.StreamOperatorParameters<org.apache.flink.types.Either<CommitT,AppendCompactTask>> parameters) |
org.apache.flink.core.io.InputStatus |
AppendTableCompactSource.CompactSourceReader.pollNext(org.apache.flink.api.connector.source.ReaderOutput<AppendCompactTask> readerOutput) |
Constructor and Description |
---|
AppendBypassCoordinateOperator(org.apache.flink.streaming.api.operators.StreamOperatorParameters<org.apache.flink.types.Either<CommitT,AppendCompactTask>> parameters,
FileStoreTable table,
org.apache.flink.streaming.runtime.tasks.ProcessingTimeService processingTimeService) |
Modifier and Type | Method and Description |
---|---|
AppendCompactTask |
AppendCompactTaskSerializer.deserialize(int version,
byte[] serialized) |
Modifier and Type | Method and Description |
---|---|
List<AppendCompactTask> |
AppendCompactTaskSerializer.deserializeList(int version,
DataInputView view) |
Modifier and Type | Method and Description |
---|---|
byte[] |
AppendCompactTaskSerializer.serialize(AppendCompactTask obj) |
Modifier and Type | Method and Description |
---|---|
void |
AppendCompactTaskSerializer.serializeList(List<AppendCompactTask> list,
DataOutputView view) |
Copyright © 2023–2025 The Apache Software Foundation. All rights reserved.