Class StreamingFileWriter<IN>
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.AbstractStreamOperator<OUT>
-
- org.apache.flink.connector.file.table.stream.AbstractStreamingWriter<IN,PartitionCommitInfo>
-
- org.apache.flink.connector.file.table.stream.StreamingFileWriter<IN>
-
- All Implemented Interfaces:
Serializable
,CheckpointListener
,BoundedOneInput
,Input<IN>
,KeyContext
,KeyContextHandler
,OneInputStreamOperator<IN,PartitionCommitInfo>
,StreamOperator<PartitionCommitInfo>
,StreamOperatorStateHandler.CheckpointedStreamOperator
,YieldingOperator<PartitionCommitInfo>
@Internal public class StreamingFileWriter<IN> extends AbstractStreamingWriter<IN,PartitionCommitInfo>
Writer for emittingPartitionCommitInfo
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
config, lastRecordAttributes1, lastRecordAttributes2, latencyStats, LOG, metrics, output, processingTimeService, stateHandler, stateKeySelector1, stateKeySelector2, timeServiceManager
-
-
Constructor Summary
Constructors Constructor Description StreamingFileWriter(long bucketCheckInterval, StreamingFileSink.BucketsBuilder<IN,String,? extends StreamingFileSink.BucketsBuilder<IN,String,?>> bucketsBuilder, List<String> partitionKeys, Configuration conf)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected void
commitUpToCheckpoint(long checkpointId)
Commit up to this checkpoint id.void
initializeState(StateInitializationContext context)
Stream operators with state which can be restored need to override this hook method.protected void
onPartFileOpened(String s, 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.void
snapshotState(StateSnapshotContext context)
Stream operators with state, which want to participate in a snapshot need to override this hook method.-
Methods inherited from class org.apache.flink.connector.file.table.stream.AbstractStreamingWriter
close, endInput, notifyCheckpointComplete, processElement, processWatermark
-
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, isUsingCustomRawKeyedState, notifyCheckpointAborted, open, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark1, processWatermark2, 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
-
StreamingFileWriter
public StreamingFileWriter(long bucketCheckInterval, StreamingFileSink.BucketsBuilder<IN,String,? extends StreamingFileSink.BucketsBuilder<IN,String,?>> bucketsBuilder, List<String> partitionKeys, Configuration conf)
-
-
Method Detail
-
initializeState
public void initializeState(StateInitializationContext context) throws Exception
Description copied from class:AbstractStreamOperator
Stream operators with state which can be restored need to override this hook method.- Specified by:
initializeState
in interfaceStreamOperatorStateHandler.CheckpointedStreamOperator
- Overrides:
initializeState
in classAbstractStreamingWriter<IN,PartitionCommitInfo>
- Parameters:
context
- context that allows to register different states.- Throws:
Exception
-
partitionCreated
protected void partitionCreated(String partition)
Description copied from class:AbstractStreamingWriter
Notifies a partition created.- Specified by:
partitionCreated
in classAbstractStreamingWriter<IN,PartitionCommitInfo>
-
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<IN,PartitionCommitInfo>
-
onPartFileOpened
protected void onPartFileOpened(String s, 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<IN,PartitionCommitInfo>
-
snapshotState
public void snapshotState(StateSnapshotContext context) throws Exception
Description copied from class:AbstractStreamOperator
Stream operators with state, which want to participate in a snapshot need to override this hook method.- Specified by:
snapshotState
in interfaceStreamOperatorStateHandler.CheckpointedStreamOperator
- Overrides:
snapshotState
in classAbstractStreamingWriter<IN,PartitionCommitInfo>
- Parameters:
context
- context that provides information and means required for taking a snapshot- Throws:
Exception
-
commitUpToCheckpoint
protected void commitUpToCheckpoint(long checkpointId) throws Exception
Description copied from class:AbstractStreamingWriter
Commit up to this checkpoint id.- Overrides:
commitUpToCheckpoint
in classAbstractStreamingWriter<IN,PartitionCommitInfo>
- Throws:
Exception
-
-