Class StreamingFileSinkHelper<IN>
- java.lang.Object
-
- org.apache.flink.streaming.api.functions.sink.filesystem.StreamingFileSinkHelper<IN>
-
- All Implemented Interfaces:
ProcessingTimeService.ProcessingTimeCallback
@Internal public class StreamingFileSinkHelper<IN> extends Object implements ProcessingTimeService.ProcessingTimeCallback
-
-
Constructor Summary
Constructors Constructor Description StreamingFileSinkHelper(Buckets<IN,?> buckets, boolean isRestored, OperatorStateStore stateStore, ProcessingTimeService procTimeService, long bucketCheckInterval)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
close()
void
commitUpToCheckpoint(long checkpointId)
void
onElement(IN value, long currentProcessingTime, Long elementTimestamp, long currentWatermark)
void
onProcessingTime(long timestamp)
This method is invoked with the time which the callback register for.void
snapshotState(long checkpointId)
-
-
-
Constructor Detail
-
StreamingFileSinkHelper
public StreamingFileSinkHelper(Buckets<IN,?> buckets, boolean isRestored, OperatorStateStore stateStore, ProcessingTimeService procTimeService, long bucketCheckInterval) throws Exception
- Throws:
Exception
-
-
Method Detail
-
commitUpToCheckpoint
public void commitUpToCheckpoint(long checkpointId) throws Exception
- Throws:
Exception
-
onProcessingTime
public void onProcessingTime(long timestamp) throws Exception
Description copied from interface:ProcessingTimeService.ProcessingTimeCallback
This method is invoked with the time which the callback register for.- Specified by:
onProcessingTime
in interfaceProcessingTimeService.ProcessingTimeCallback
- Parameters:
timestamp
- The time this callback was registered for.- Throws:
Exception
-
onElement
public void onElement(IN value, long currentProcessingTime, @Nullable Long elementTimestamp, long currentWatermark) throws Exception
- Throws:
Exception
-
close
public void close()
-
-