public class RowDataStoreWriteOperator extends TableWriteOperator<InternalRow>
PrepareCommitOperator to write InternalRow. Record schema is fixed.table, writememoryPool| Constructor and Description |
|---|
RowDataStoreWriteOperator(FileStoreTable table,
LogSinkFunction logSinkFunction,
StoreSinkWrite.Provider storeSinkWriteProvider,
String initialCommitUser) |
| Modifier and Type | Method and Description |
|---|---|
void |
close() |
protected boolean |
containLogSystem() |
void |
finish() |
void |
initializeState(org.apache.flink.runtime.state.StateInitializationContext context) |
void |
notifyCheckpointAborted(long checkpointId) |
void |
notifyCheckpointComplete(long checkpointId) |
void |
open() |
protected List<Committable> |
prepareCommit(boolean waitCompaction,
long checkpointId) |
void |
processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<InternalRow> element) |
void |
processWatermark(org.apache.flink.streaming.api.watermark.Watermark mark) |
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<org.apache.flink.streaming.runtime.streamrecord.StreamRecord<Committable>> output) |
void |
snapshotState(org.apache.flink.runtime.state.StateSnapshotContext context) |
getWriteendInput, prepareSnapshotPreBarriergetChainingStrategy, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getStateKeySelector1, getStateKeySelector2, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, isUsingCustomRawKeyedState, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setMailboxExecutor, setProcessingTimeService, snapshotState, useSplittableTimersclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitsetKeyContextElementgetMetricGroup, getOperatorAttributes, getOperatorID, initializeState, setKeyContextElement1, setKeyContextElement2, snapshotStategetCurrentKey, setCurrentKeypublic RowDataStoreWriteOperator(FileStoreTable table, @Nullable LogSinkFunction logSinkFunction, StoreSinkWrite.Provider storeSinkWriteProvider, String initialCommitUser)
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<org.apache.flink.streaming.runtime.streamrecord.StreamRecord<Committable>> output)
setup in interface org.apache.flink.streaming.api.operators.SetupableStreamOperator<Committable>setup in class PrepareCommitOperator<InternalRow,Committable>public void initializeState(org.apache.flink.runtime.state.StateInitializationContext context)
throws Exception
initializeState in interface org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperatorinitializeState in class TableWriteOperator<InternalRow>Exceptionprotected boolean containLogSystem()
containLogSystem in class TableWriteOperator<InternalRow>public void open()
throws Exception
open in interface org.apache.flink.streaming.api.operators.StreamOperator<Committable>open in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<Committable>Exceptionpublic void processWatermark(org.apache.flink.streaming.api.watermark.Watermark mark)
throws Exception
processWatermark in interface org.apache.flink.streaming.api.operators.Input<InternalRow>processWatermark in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<Committable>Exceptionpublic void processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<InternalRow> element) throws Exception
Exceptionpublic void snapshotState(org.apache.flink.runtime.state.StateSnapshotContext context)
throws Exception
snapshotState in interface org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperatorsnapshotState in class TableWriteOperator<InternalRow>Exceptionpublic void finish()
throws Exception
finish in interface org.apache.flink.streaming.api.operators.StreamOperator<Committable>finish in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<Committable>Exceptionpublic void close()
throws Exception
close in interface org.apache.flink.streaming.api.operators.StreamOperator<Committable>close in class TableWriteOperator<InternalRow>Exceptionpublic void notifyCheckpointComplete(long checkpointId)
throws Exception
notifyCheckpointComplete in interface org.apache.flink.api.common.state.CheckpointListenernotifyCheckpointComplete in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<Committable>Exceptionpublic void notifyCheckpointAborted(long checkpointId)
throws Exception
notifyCheckpointAborted in interface org.apache.flink.api.common.state.CheckpointListenernotifyCheckpointAborted in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<Committable>Exceptionprotected List<Committable> prepareCommit(boolean waitCompaction, long checkpointId) throws IOException
prepareCommit in class TableWriteOperator<InternalRow>IOExceptionCopyright © 2023–2024 The Apache Software Foundation. All rights reserved.