public class BatchWriteGeneratorTagOperator<CommitT,GlobalCommitT> extends Object implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<CommitT,CommitT>, org.apache.flink.streaming.api.operators.SetupableStreamOperator, org.apache.flink.streaming.api.operators.BoundedOneInput
Committable
for snapshot using the CommitterOperator
. When the task is
completed, the corresponding tag is generated.Modifier and Type | Field and Description |
---|---|
protected FileStoreTable |
table |
Constructor and Description |
---|
BatchWriteGeneratorTagOperator(CommitterOperator<CommitT,GlobalCommitT> commitOperator,
FileStoreTable table) |
Modifier and Type | Method and Description |
---|---|
void |
close() |
void |
endInput() |
void |
finish() |
org.apache.flink.streaming.api.operators.ChainingStrategy |
getChainingStrategy() |
Object |
getCurrentKey() |
org.apache.flink.metrics.groups.OperatorMetricGroup |
getMetricGroup() |
org.apache.flink.runtime.jobgraph.OperatorID |
getOperatorID() |
void |
initializeState(org.apache.flink.streaming.api.operators.StreamTaskStateInitializer streamTaskStateManager) |
void |
notifyCheckpointAborted(long checkpointId) |
void |
notifyCheckpointComplete(long checkpointId) |
void |
open() |
void |
prepareSnapshotPreBarrier(long checkpointId) |
void |
processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<CommitT> element) |
void |
processLatencyMarker(org.apache.flink.streaming.runtime.streamrecord.LatencyMarker latencyMarker) |
void |
processWatermark(org.apache.flink.streaming.api.watermark.Watermark watermark) |
void |
processWatermarkStatus(org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus watermarkStatus) |
void |
setChainingStrategy(org.apache.flink.streaming.api.operators.ChainingStrategy strategy) |
void |
setCurrentKey(Object key) |
void |
setKeyContextElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<CommitT> record) |
void |
setKeyContextElement1(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<?> record) |
void |
setKeyContextElement2(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<?> record) |
void |
setup(org.apache.flink.streaming.runtime.tasks.StreamTask containingTask,
org.apache.flink.streaming.api.graph.StreamConfig config,
org.apache.flink.streaming.api.operators.Output output) |
org.apache.flink.streaming.api.operators.OperatorSnapshotFutures |
snapshotState(long checkpointId,
long timestamp,
org.apache.flink.runtime.checkpoint.CheckpointOptions checkpointOptions,
org.apache.flink.runtime.state.CheckpointStreamFactory storageLocation) |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
protected final FileStoreTable table
public BatchWriteGeneratorTagOperator(CommitterOperator<CommitT,GlobalCommitT> commitOperator, FileStoreTable table)
public void initializeState(org.apache.flink.streaming.api.operators.StreamTaskStateInitializer streamTaskStateManager) throws Exception
public org.apache.flink.streaming.api.operators.OperatorSnapshotFutures snapshotState(long checkpointId, long timestamp, org.apache.flink.runtime.checkpoint.CheckpointOptions checkpointOptions, org.apache.flink.runtime.state.CheckpointStreamFactory storageLocation) throws Exception
public void notifyCheckpointComplete(long checkpointId) throws Exception
notifyCheckpointComplete
in interface org.apache.flink.api.common.state.CheckpointListener
Exception
public void notifyCheckpointAborted(long checkpointId) throws Exception
notifyCheckpointAborted
in interface org.apache.flink.api.common.state.CheckpointListener
Exception
public void open() throws Exception
public void processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<CommitT> element) throws Exception
public void processWatermark(org.apache.flink.streaming.api.watermark.Watermark watermark) throws Exception
public void processWatermarkStatus(org.apache.flink.streaming.runtime.watermarkstatus.WatermarkStatus watermarkStatus) throws Exception
public void processLatencyMarker(org.apache.flink.streaming.runtime.streamrecord.LatencyMarker latencyMarker) throws Exception
public void finish() throws Exception
public void close() throws Exception
public void prepareSnapshotPreBarrier(long checkpointId) throws Exception
public void setKeyContextElement1(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<?> record) throws Exception
public void setKeyContextElement2(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<?> record) throws Exception
public org.apache.flink.metrics.groups.OperatorMetricGroup getMetricGroup()
getMetricGroup
in interface org.apache.flink.streaming.api.operators.StreamOperator<CommitT>
public org.apache.flink.runtime.jobgraph.OperatorID getOperatorID()
getOperatorID
in interface org.apache.flink.streaming.api.operators.StreamOperator<CommitT>
public void setCurrentKey(Object key)
setCurrentKey
in interface org.apache.flink.streaming.api.operators.KeyContext
public Object getCurrentKey()
getCurrentKey
in interface org.apache.flink.streaming.api.operators.KeyContext
public void setKeyContextElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<CommitT> record) throws Exception
public void endInput() throws Exception
endInput
in interface org.apache.flink.streaming.api.operators.BoundedOneInput
Exception
public void setup(org.apache.flink.streaming.runtime.tasks.StreamTask containingTask, org.apache.flink.streaming.api.graph.StreamConfig config, org.apache.flink.streaming.api.operators.Output output)
setup
in interface org.apache.flink.streaming.api.operators.SetupableStreamOperator
public org.apache.flink.streaming.api.operators.ChainingStrategy getChainingStrategy()
getChainingStrategy
in interface org.apache.flink.streaming.api.operators.SetupableStreamOperator
public void setChainingStrategy(org.apache.flink.streaming.api.operators.ChainingStrategy strategy)
setChainingStrategy
in interface org.apache.flink.streaming.api.operators.SetupableStreamOperator
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.