Modifier and Type | Method and Description |
---|---|
List<Committable> |
UnawareBucketCompactor.prepareCommit(boolean waitCompaction,
long checkpointId) |
Modifier and Type | Method and Description |
---|---|
List<Committable> |
ChangelogCompactTask.doCompact(FileStoreTable table) |
Modifier and Type | Method and Description |
---|---|
void |
ChangelogCompactCoordinateOperator.processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<Committable> record) |
void |
ChangelogCompactWorkerOperator.processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<org.apache.flink.types.Either<Committable,ChangelogCompactTask>> record) |
Modifier and Type | Method and Description |
---|---|
Committable |
CommittableSerializer.deserialize(int committableVersion,
byte[] bytes) |
Committable |
MultiTableCommittableSerializer.deserializeCommittable(int committableVersion,
byte[] bytes) |
Modifier and Type | Method and Description |
---|---|
protected abstract Committer.Factory<Committable,ManifestCommittable> |
FlinkSink.createCommitterFactory() |
protected Committer.Factory<Committable,ManifestCommittable> |
UnawareBucketCompactionSink.createCommitterFactory() |
protected Committer.Factory<Committable,ManifestCommittable> |
CompactorSink.createCommitterFactory() |
protected Committer.Factory<Committable,ManifestCommittable> |
FlinkWriteSink.createCommitterFactory() |
org.apache.flink.api.common.typeutils.TypeSerializer<Committable> |
CommittableTypeInfo.createSerializer(org.apache.flink.api.common.ExecutionConfig config) |
protected org.apache.flink.streaming.api.operators.OneInputStreamOperator<InternalRow,Committable> |
RowUnawareBucketSink.createWriteOperator(StoreSinkWrite.Provider writeProvider,
String commitUser) |
protected org.apache.flink.streaming.api.operators.OneInputStreamOperator<ManifestEntry,Committable> |
RewriteFileIndexSink.createWriteOperator(StoreSinkWrite.Provider writeProvider,
String commitUser) |
protected abstract org.apache.flink.streaming.api.operators.OneInputStreamOperator<T,Committable> |
FlinkSink.createWriteOperator(StoreSinkWrite.Provider writeProvider,
String commitUser) |
protected org.apache.flink.streaming.api.operators.OneInputStreamOperator<InternalRow,Committable> |
FixedBucketSink.createWriteOperator(StoreSinkWrite.Provider writeProvider,
String commitUser) |
protected org.apache.flink.streaming.api.operators.OneInputStreamOperator<UnawareAppendCompactionTask,Committable> |
UnawareBucketCompactionSink.createWriteOperator(StoreSinkWrite.Provider writeProvider,
String commitUser) |
protected org.apache.flink.streaming.api.operators.OneInputStreamOperator<org.apache.flink.table.data.RowData,Committable> |
CompactorSink.createWriteOperator(StoreSinkWrite.Provider writeProvider,
String commitUser) |
protected org.apache.flink.streaming.api.operators.OneInputStreamOperator<org.apache.flink.api.java.tuple.Tuple2<InternalRow,Integer>,Committable> |
RowDynamicBucketSink.createWriteOperator(StoreSinkWrite.Provider writeProvider,
String commitUser) |
org.apache.flink.streaming.api.datastream.DataStream<Committable> |
FlinkSink.doWrite(org.apache.flink.streaming.api.datastream.DataStream<T> input,
String commitUser,
Integer parallelism) |
org.apache.flink.streaming.api.datastream.DataStream<Committable> |
UnawareBucketSink.doWrite(org.apache.flink.streaming.api.datastream.DataStream<T> input,
String initialCommitUser,
Integer parallelism) |
Class<Committable> |
CommittableTypeInfo.getTypeClass() |
Map<Long,List<Committable>> |
StoreCommitter.groupByCheckpoint(Collection<Committable> committables) |
protected List<Committable> |
StoreCompactOperator.prepareCommit(boolean waitCompaction,
long checkpointId) |
protected List<Committable> |
TableWriteOperator.prepareCommit(boolean waitCompaction,
long checkpointId) |
protected List<Committable> |
AppendCompactWorkerOperator.prepareCommit(boolean waitCompaction,
long checkpointId) |
List<Committable> |
StoreSinkWrite.prepareCommit(boolean waitCompaction,
long checkpointId) |
protected List<Committable> |
RowDataStoreWriteOperator.prepareCommit(boolean waitCompaction,
long checkpointId) |
List<Committable> |
GlobalFullCompactionSinkWrite.prepareCommit(boolean waitCompaction,
long checkpointId) |
List<Committable> |
StoreSinkWriteImpl.prepareCommit(boolean waitCompaction,
long checkpointId) |
Modifier and Type | Method and Description |
---|---|
static MultiTableCommittable |
MultiTableCommittable.fromCommittable(Identifier id,
Committable committable) |
byte[] |
CommittableSerializer.serialize(Committable committable) |
Modifier and Type | Method and Description |
---|---|
ManifestCommittable |
StoreCommitter.combine(long checkpointId,
long watermark,
List<Committable> committables) |
ManifestCommittable |
StoreCommitter.combine(long checkpointId,
long watermark,
ManifestCommittable manifestCommittable,
List<Committable> committables) |
protected org.apache.flink.streaming.api.datastream.DataStreamSink<?> |
FlinkSink.doCommit(org.apache.flink.streaming.api.datastream.DataStream<Committable> written,
String commitUser) |
Map<Long,List<Committable>> |
StoreCommitter.groupByCheckpoint(Collection<Committable> committables) |
void |
AppendBypassCompactWorkerOperator.processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<org.apache.flink.types.Either<Committable,UnawareAppendCompactionTask>> element) |
void |
RowDataStoreWriteOperator.setup(org.apache.flink.streaming.runtime.tasks.StreamTask<?,?> containingTask,
org.apache.flink.streaming.api.graph.StreamConfig config,
org.apache.flink.streaming.api.operators.Output<org.apache.flink.streaming.runtime.streamrecord.StreamRecord<Committable>> output) |
Modifier and Type | Method and Description |
---|---|
protected org.apache.flink.streaming.api.operators.OneInputStreamOperator<CdcRecord,Committable> |
CdcUnawareBucketSink.createWriteOperator(StoreSinkWrite.Provider writeProvider,
String commitUser) |
protected org.apache.flink.streaming.api.operators.OneInputStreamOperator<org.apache.flink.api.java.tuple.Tuple2<CdcRecord,Integer>,Committable> |
CdcDynamicBucketSink.createWriteOperator(StoreSinkWrite.Provider writeProvider,
String commitUser) |
protected org.apache.flink.streaming.api.operators.OneInputStreamOperator<CdcRecord,Committable> |
CdcFixedBucketSink.createWriteOperator(StoreSinkWrite.Provider writeProvider,
String commitUser) |
org.apache.flink.streaming.api.datastream.DataStream<Committable> |
CdcUnawareBucketSink.doWrite(org.apache.flink.streaming.api.datastream.DataStream<CdcRecord> input,
String initialCommitUser,
Integer parallelism) |
Modifier and Type | Method and Description |
---|---|
protected org.apache.flink.streaming.api.operators.OneInputStreamOperator<org.apache.flink.api.java.tuple.Tuple2<InternalRow,Integer>,Committable> |
GlobalDynamicBucketSink.createWriteOperator(StoreSinkWrite.Provider writeProvider,
String commitUser) |
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.