Class DataFileRewriteCommitter
java.lang.Object
org.apache.flink.streaming.api.operators.AbstractStreamOperator<Trigger>
org.apache.iceberg.flink.maintenance.operator.DataFileRewriteCommitter
- All Implemented Interfaces:
- Serializable,- org.apache.flink.api.common.state.CheckpointListener,- org.apache.flink.streaming.api.operators.Input<DataFileRewriteRunner.ExecutedGroup>,- org.apache.flink.streaming.api.operators.KeyContext,- org.apache.flink.streaming.api.operators.KeyContextHandler,- org.apache.flink.streaming.api.operators.OneInputStreamOperator<DataFileRewriteRunner.ExecutedGroup,,- Trigger> - org.apache.flink.streaming.api.operators.StreamOperator<Trigger>,- org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator,- org.apache.flink.streaming.api.operators.YieldingOperator<Trigger>
@Internal
public class DataFileRewriteCommitter
extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<Trigger>
implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<DataFileRewriteRunner.ExecutedGroup,Trigger> 
Commits the rewrite changes using 
RewriteDataFilesCommitManager. The input is a DataFileRewriteRunner.ExecutedGroup. Only Watermark is emitted which is chained to
 TaskResultAggregator input 1.- See Also:
- 
Field SummaryFields inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperatorcombinedWatermark, config, lastRecordAttributes1, lastRecordAttributes2, latencyStats, metrics, output, processingTimeService, stateHandler, stateKeySelector1, stateKeySelector2, timeServiceManager
- 
Constructor SummaryConstructorsConstructorDescriptionDataFileRewriteCommitter(String tableName, String taskName, int taskIndex, TableLoader tableLoader) 
- 
Method SummaryModifier and TypeMethodDescriptionvoidclose()voidopen()voidprocessElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<DataFileRewriteRunner.ExecutedGroup> streamRecord) voidprocessWatermark(org.apache.flink.streaming.api.watermark.Watermark mark) Methods inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperatorbeforeInitializeStateHandler, finish, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getStateKeySelector1, getStateKeySelector2, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, initializeState, isAsyncStateProcessingEnabled, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark, processWatermark1, processWatermark1, processWatermark2, processWatermark2, processWatermarkStatus, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setMailboxExecutor, setProcessingTimeService, setup, snapshotState, snapshotState, useSplittableTimersMethods inherited from class java.lang.Objectclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface org.apache.flink.api.common.state.CheckpointListenernotifyCheckpointAborted, notifyCheckpointCompleteMethods inherited from interface org.apache.flink.streaming.api.operators.InputprocessLatencyMarker, processRecordAttributes, processWatermark, processWatermarkStatusMethods inherited from interface org.apache.flink.streaming.api.operators.KeyContextgetCurrentKey, setCurrentKeyMethods inherited from interface org.apache.flink.streaming.api.operators.KeyContextHandlerhasKeyContextMethods inherited from interface org.apache.flink.streaming.api.operators.OneInputStreamOperatorsetKeyContextElementMethods inherited from interface org.apache.flink.streaming.api.operators.StreamOperatorfinish, getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
- 
Constructor Details- 
DataFileRewriteCommitterpublic DataFileRewriteCommitter(String tableName, String taskName, int taskIndex, TableLoader tableLoader) 
 
- 
- 
Method Details- 
open
- 
processElementpublic void processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<DataFileRewriteRunner.ExecutedGroup> streamRecord) - Specified by:
- processElementin interface- org.apache.flink.streaming.api.operators.Input<DataFileRewriteRunner.ExecutedGroup>
 
- 
processWatermarkpublic void processWatermark(org.apache.flink.streaming.api.watermark.Watermark mark) throws Exception - Specified by:
- processWatermarkin interface- org.apache.flink.streaming.api.operators.Input<DataFileRewriteRunner.ExecutedGroup>
- Overrides:
- processWatermarkin class- org.apache.flink.streaming.api.operators.AbstractStreamOperator<Trigger>
- Throws:
- Exception
 
- 
close- Specified by:
- closein interface- org.apache.flink.streaming.api.operators.StreamOperator<Trigger>
- Overrides:
- closein class- org.apache.flink.streaming.api.operators.AbstractStreamOperator<Trigger>
- Throws:
- IOException
 
 
-