Class CompactFileWriter<T>
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.AbstractStreamOperator<OUT>
-
- org.apache.flink.connector.file.table.stream.AbstractStreamingWriter<T,CompactMessages.CoordinatorInput>
-
- org.apache.flink.connector.file.table.stream.compact.CompactFileWriter<T>
-
- All Implemented Interfaces:
Serializable
,CheckpointListener
,BoundedOneInput
,Input<T>
,KeyContext
,KeyContextHandler
,OneInputStreamOperator<T,CompactMessages.CoordinatorInput>
,StreamOperator<CompactMessages.CoordinatorInput>
,StreamOperatorStateHandler.CheckpointedStreamOperator
,YieldingOperator<CompactMessages.CoordinatorInput>
@Internal public class CompactFileWriter<T> extends AbstractStreamingWriter<T,CompactMessages.CoordinatorInput>
Writer for emittingCompactMessages.InputFile
andCompactMessages.EndCheckpoint
to downstream.- See Also:
- Serialized Form
-
-
Field Summary
-
Fields inherited from class org.apache.flink.connector.file.table.stream.AbstractStreamingWriter
buckets, currentWatermark
-
Fields inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperator
combinedWatermark, config, lastRecordAttributes1, lastRecordAttributes2, latencyStats, LOG, metrics, output, processingTimeService, stateHandler, stateKeySelector1, stateKeySelector2, timeServiceManager
-
-
Constructor Summary
Constructors Constructor Description CompactFileWriter(long bucketCheckInterval, StreamingFileSink.BucketsBuilder<T,String,? extends StreamingFileSink.BucketsBuilder<T,String,?>> bucketsBuilder)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected void
commitUpToCheckpoint(long checkpointId)
Commit up to this checkpoint id.protected void
onPartFileOpened(String partition, Path newPath)
Notifies a new file has been opened.protected void
partitionCreated(String partition)
Notifies a partition created.protected void
partitionInactive(String partition)
Notifies a partition become inactive.-
Methods inherited from class org.apache.flink.connector.file.table.stream.AbstractStreamingWriter
close, endInput, initializeState, notifyCheckpointComplete, processElement, processWatermark, snapshotState
-
Methods inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperator
finish, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getStateKeySelector1, getStateKeySelector2, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, isAsyncStateProcessingEnabled, isUsingCustomRawKeyedState, notifyCheckpointAborted, open, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setMailboxExecutor, setProcessingTimeService, setup, 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
-
Methods inherited from interface org.apache.flink.streaming.api.operators.Input
processLatencyMarker, processRecordAttributes, 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, open, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
-
-
-
-
Constructor Detail
-
CompactFileWriter
public CompactFileWriter(long bucketCheckInterval, StreamingFileSink.BucketsBuilder<T,String,? extends StreamingFileSink.BucketsBuilder<T,String,?>> bucketsBuilder)
-
-
Method Detail
-
partitionCreated
protected void partitionCreated(String partition)
Description copied from class:AbstractStreamingWriter
Notifies a partition created.- Specified by:
partitionCreated
in classAbstractStreamingWriter<T,CompactMessages.CoordinatorInput>
-
partitionInactive
protected void partitionInactive(String partition)
Description copied from class:AbstractStreamingWriter
Notifies a partition become inactive. A partition becomes inactive after all the records received so far have been committed.- Specified by:
partitionInactive
in classAbstractStreamingWriter<T,CompactMessages.CoordinatorInput>
-
onPartFileOpened
protected void onPartFileOpened(String partition, Path newPath)
Description copied from class:AbstractStreamingWriter
Notifies a new file has been opened.Note that this does not mean that the file has been created in the file system. It is only created logically and the actual file will be generated after it is committed.
- Specified by:
onPartFileOpened
in classAbstractStreamingWriter<T,CompactMessages.CoordinatorInput>
-
commitUpToCheckpoint
protected void commitUpToCheckpoint(long checkpointId) throws Exception
Description copied from class:AbstractStreamingWriter
Commit up to this checkpoint id.- Overrides:
commitUpToCheckpoint
in classAbstractStreamingWriter<T,CompactMessages.CoordinatorInput>
- Throws:
Exception
-
-