Interface | Description |
---|---|
CommittableStateManager<GlobalCommitT> |
Helper interface for
CommitterOperator . |
Committer<CommitT,GlobalCommitT> |
The
Committer is responsible for creating and committing an aggregated committable, which
we call committable (see Committer.combine(long, long, java.util.List<CommitT>) ). |
Committer.Context |
Context to create
Committer . |
Committer.Factory<CommitT,GlobalCommitT> |
Factory to create
Committer . |
LogSinkFunction |
Log
SinkFunction with LogSinkFunction.WriteCallback . |
LogSinkFunction.WriteCallback |
A callback interface that the user can implement to know the offset of the bucket when the
request is complete.
|
StoreSinkWrite |
Helper class of
PrepareCommitOperator for different types of paimon sinks. |
StoreSinkWrite.Provider |
Provider of
StoreSinkWrite . |
StoreSinkWrite.WithWriteBufferProvider |
Provider of
StoreSinkWrite that uses given write buffer. |
StoreSinkWriteState |
States for
StoreSinkWrite s. |
StoreSinkWriteState.StateValueFilter |
Given the table name, partition and bucket of a
StoreSinkWriteState.StateValue in a union list state,
decide whether to keep this StoreSinkWriteState.StateValue in this subtask. |
Class | Description |
---|---|
AdaptiveParallelism |
Get adaptive config from Flink.
|
AppendBypassCompactWorkerOperator |
A
AppendCompactWorkerOperator to bypass Committable inputs. |
AppendCompactWorkerOperator<IN> |
An abstract Operator to execute
UnawareAppendCompactionTask passed from BucketUnawareCompactSource for compacting table. |
AppendOnlyMultiTableCompactionWorkerOperator |
Operator to execute
UnawareAppendCompactionTask passed for support compacting multi
unaware bucket tables in combined mode. |
AppendOnlySingleTableCompactionWorkerOperator |
Operator to execute
UnawareAppendCompactionTask passed from BucketUnawareCompactSource for compacting single unaware bucket tables in divided mode. |
AsyncLookupSinkWrite |
StoreSinkWrite for tables with lookup changelog producer and CoreOptions.LOOKUP_WAIT set to false. |
AutoTagForSavepointCommitterOperator<CommitT,GlobalCommitT> |
Commit
Committable for each snapshot using the CommitterOperator . |
BatchWriteGeneratorTagOperator<CommitT,GlobalCommitT> |
Commit
Committable for snapshot using the CommitterOperator . |
BucketsRowChannelComputer | |
CombinedTableCompactorSink |
A sink for processing multi-tables in dedicated compaction job.
|
Committable |
Committable produced by
PrepareCommitOperator . |
CommittableSerializer |
SimpleVersionedSerializer for Committable . |
CommittableTypeInfo |
Type information of
Committable . |
CommitterMetrics |
Flink metrics for
Committer . |
CommitterOperator<CommitT,GlobalCommitT> |
Operator to commit
Committable s for each snapshot. |
CompactionTaskSimpleSerializer |
SimpleVersionedSerializer for UnawareAppendCompactionTask . |
CompactionTaskTypeInfo |
Type information of
UnawareAppendCompactionTask . |
CompactorSink |
FlinkSink for dedicated compact jobs. |
CompactorSinkBuilder |
Builder for
CompactorSink . |
DynamicBucketCompactSink |
This class is only used for generate compact sink topology for dynamic bucket table.
|
DynamicBucketRowWriteOperator |
A
PrepareCommitOperator to write InternalRow with bucket. |
DynamicBucketSink<T> |
Sink for dynamic bucket table.
|
FixedBucketSink |
FlinkSink for writing records into fixed bucket Paimon table. |
FlinkSink<T> |
Abstract sink of paimon.
|
FlinkSinkBuilder |
DataStream API for building Flink Sink.
|
FlinkStreamPartitioner<T> |
A
StreamPartitioner which wraps a ChannelComputer . |
FlinkTableSink |
Table sink to create sink.
|
FlinkTableSinkBase |
Table sink to create sink.
|
FlinkWriteSink<T> |
A
FlinkSink to write records. |
GlobalFullCompactionSinkWrite |
StoreSinkWrite for execute full compaction globally. |
HashBucketAssignerOperator<T> |
Assign bucket for the input record, output record with bucket.
|
LocalMergeOperator |
AbstractStreamOperator which buffer input record and apply merge function when the buffer
is full. |
LogFlinkSinkBuilder |
A special version
FlinkSinkBuilder with log sink. |
LogOffsetCommittable |
Log offset committable for a bucket.
|
MultiTableCommittable |
MultiTableCommittable produced by
PrepareCommitOperator . |
MultiTableCommittableChannelComputer | |
MultiTableCommittableSerializer |
SimpleVersionedSerializer for MultiTableCommittable . |
MultiTableCommittableTypeInfo |
Type information of
MultiTableCommittable . |
MultiTableCompactionTaskTypeInfo |
Type information of
MultiTableUnawareAppendCompactionTask . |
MultiTablesStoreCompactOperator |
A dedicated operator for manual triggered compaction.
|
NoneCopyVersionedSerializerTypeSerializerProxy<T> |
No copy
SimpleVersionedSerializerTypeSerializerProxy . |
NoopCommittableStateManager |
A
CommittableStateManager which does nothing. |
NoopStoreSinkWriteState |
A
StoreSinkWriteState which stores nothing. |
PrepareCommitOperator<IN,OUT> |
Prepare commit operator to emit
Committable s. |
RestoreAndFailCommittableStateManager<GlobalCommitT> |
A
CommittableStateManager which stores uncommitted ManifestCommittable s in state. |
RewriteFileIndexSink |
File index sink for
RewriteFileIndexProcedure . |
RewriteFileIndexSink.FileIndexProcessor |
Does the file index rewrite.
|
RowAssignerChannelComputer |
Hash key of a
RowData . |
RowDataChannelComputer | |
RowDataKeyAndBucketExtractor |
KeyAndBucketExtractor for RowData . |
RowDataStoreWriteOperator |
A
PrepareCommitOperator to write InternalRow . |
RowDynamicBucketSink |
Sink for dynamic bucket table.
|
RowUnawareBucketSink |
An
UnawareBucketSink which handles InternalRow . |
RowWithBucketChannelComputer |
Hash key of a
RowData with bucket. |
SortCompactSinkBuilder |
A special version
FlinkSinkBuilder for sort compact. |
StateUtils |
Utility class for sink state manipulation.
|
StoreCommitter |
Committer for dynamic store. |
StoreCompactOperator |
A dedicated operator for manual triggered compaction.
|
StoreMultiCommitter |
StoreMultiCommitter for multiple dynamic store. |
StoreSinkWriteImpl |
Default implementation of
StoreSinkWrite . |
StoreSinkWriteState.StateValue |
A state value for
StoreSinkWrite . |
StoreSinkWriteStateImpl |
Default implementation for
StoreSinkWriteState . |
StreamMapWithForwardingRecordAttributes<IN,OUT> |
A
StreamMap that forwards received RecordAttributes to downstream operators. |
SupportsRowLevelOperationFlinkTableSink |
Flink table sink that supports row level update and delete.
|
TableWriteOperator<IN> |
An abstract class for table write operator.
|
UnawareBucketCompactionSink |
Compaction Sink for unaware-bucket table.
|
UnawareBucketSink<T> |
Sink for unaware-bucket table.
|
WrappedManifestCommittableSerializer |
Enum | Description |
---|---|
Committable.Kind |
Kind of the produced Committable.
|
MultiTableCommittable.Kind |
Kind of the produced Committable.
|
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.