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 Summary
Fields inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperator
combinedWatermark, config, lastRecordAttributes1, lastRecordAttributes2, latencyStats, metrics, output, processingTimeService, stateHandler, stateKeySelector1, stateKeySelector2, timeServiceManager
-
Constructor Summary
ConstructorsConstructorDescriptionDataFileRewriteCommitter
(String tableName, String taskName, int taskIndex, TableLoader tableLoader) -
Method Summary
Modifier and TypeMethodDescriptionvoid
close()
void
open()
void
processElement
(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<DataFileRewriteRunner.ExecutedGroup> streamRecord) void
processWatermark
(org.apache.flink.streaming.api.watermark.Watermark mark) Methods inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperator
beforeInitializeStateHandler, 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, useSplittableTimers
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
Methods inherited from interface org.apache.flink.api.common.state.CheckpointListener
notifyCheckpointAborted, notifyCheckpointComplete
Methods inherited from interface org.apache.flink.streaming.api.operators.Input
processLatencyMarker, processRecordAttributes, processWatermark, processWatermarkStatus
Methods inherited from interface org.apache.flink.streaming.api.operators.KeyContext
getCurrentKey, setCurrentKey
Methods inherited from interface org.apache.flink.streaming.api.operators.KeyContextHandler
hasKeyContext
Methods inherited from interface org.apache.flink.streaming.api.operators.OneInputStreamOperator
setKeyContextElement
Methods inherited from interface org.apache.flink.streaming.api.operators.StreamOperator
finish, getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
-
Constructor Details
-
DataFileRewriteCommitter
public DataFileRewriteCommitter(String tableName, String taskName, int taskIndex, TableLoader tableLoader)
-
-
Method Details
-
open
-
processElement
public void processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<DataFileRewriteRunner.ExecutedGroup> streamRecord) - Specified by:
processElement
in interfaceorg.apache.flink.streaming.api.operators.Input<DataFileRewriteRunner.ExecutedGroup>
-
processWatermark
public void processWatermark(org.apache.flink.streaming.api.watermark.Watermark mark) throws Exception - Specified by:
processWatermark
in interfaceorg.apache.flink.streaming.api.operators.Input<DataFileRewriteRunner.ExecutedGroup>
- Overrides:
processWatermark
in classorg.apache.flink.streaming.api.operators.AbstractStreamOperator<Trigger>
- Throws:
Exception
-
close
- Specified by:
close
in interfaceorg.apache.flink.streaming.api.operators.StreamOperator<Trigger>
- Overrides:
close
in classorg.apache.flink.streaming.api.operators.AbstractStreamOperator<Trigger>
- Throws:
IOException
-