@Internal public class CompactFileWriter<T> extends AbstractStreamingWriter<T,CompactMessages.CoordinatorInput>
CompactMessages.InputFile
and CompactMessages.EndCheckpoint
to downstream.buckets, currentWatermark
chainingStrategy, config, latencyStats, LOG, metrics, output, processingTimeService
Constructor and Description |
---|
CompactFileWriter(long bucketCheckInterval,
StreamingFileSink.BucketsBuilder<T,String,? extends StreamingFileSink.BucketsBuilder<T,String,?>> bucketsBuilder) |
Modifier and Type | Method and 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.
|
close, endInput, initializeState, notifyCheckpointComplete, processElement, processWatermark, snapshotState
finish, getChainingStrategy, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, isUsingCustomRawKeyedState, notifyCheckpointAborted, open, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setProcessingTimeService, setup, snapshotState
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
setKeyContextElement
finish, getMetricGroup, getOperatorID, initializeState, open, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted
getCurrentKey, setCurrentKey
processLatencyMarker, processWatermarkStatus
hasKeyContext
public CompactFileWriter(long bucketCheckInterval, StreamingFileSink.BucketsBuilder<T,String,? extends StreamingFileSink.BucketsBuilder<T,String,?>> bucketsBuilder)
protected void partitionCreated(String partition)
AbstractStreamingWriter
partitionCreated
in class AbstractStreamingWriter<T,CompactMessages.CoordinatorInput>
protected void partitionInactive(String partition)
AbstractStreamingWriter
partitionInactive
in class AbstractStreamingWriter<T,CompactMessages.CoordinatorInput>
protected void onPartFileOpened(String partition, Path newPath)
AbstractStreamingWriter
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.
onPartFileOpened
in class AbstractStreamingWriter<T,CompactMessages.CoordinatorInput>
protected void commitUpToCheckpoint(long checkpointId) throws Exception
AbstractStreamingWriter
commitUpToCheckpoint
in class AbstractStreamingWriter<T,CompactMessages.CoordinatorInput>
Exception
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.