public class RowDataStoreWriteOperator extends TableWriteOperator<InternalRow>
PrepareCommitOperator
to write InternalRow
. Record schema is fixed.Modifier and Type | Class and Description |
---|---|
static class |
RowDataStoreWriteOperator.Factory
StreamOperatorFactory of RowDataStoreWriteOperator . |
table, write
memoryPool
Modifier | Constructor and Description |
---|---|
protected |
RowDataStoreWriteOperator(org.apache.flink.streaming.api.operators.StreamOperatorParameters<Committable> parameters,
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 |
snapshotState(org.apache.flink.runtime.state.StateSnapshotContext context) |
createState, getCommitUser, getWrite, processRecordAttributes
endInput, prepareSnapshotPreBarrier, setup
getChainingStrategy, 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, processRecordAttributes1, processRecordAttributes2, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setMailboxExecutor, setProcessingTimeService, snapshotState, useSplittableTimers
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
setKeyContextElement
getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, setKeyContextElement1, setKeyContextElement2, snapshotState
getCurrentKey, setCurrentKey
protected RowDataStoreWriteOperator(org.apache.flink.streaming.api.operators.StreamOperatorParameters<Committable> parameters, FileStoreTable table, @Nullable LogSinkFunction logSinkFunction, StoreSinkWrite.Provider storeSinkWriteProvider, String initialCommitUser)
public void initializeState(org.apache.flink.runtime.state.StateInitializationContext context) throws Exception
initializeState
in interface org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
initializeState
in class TableWriteOperator<InternalRow>
Exception
protected 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>
Exception
public 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>
Exception
public void processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<InternalRow> element) throws Exception
Exception
public void snapshotState(org.apache.flink.runtime.state.StateSnapshotContext context) throws Exception
snapshotState
in interface org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
snapshotState
in class TableWriteOperator<InternalRow>
Exception
public 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>
Exception
public void close() throws Exception
close
in interface org.apache.flink.streaming.api.operators.StreamOperator<Committable>
close
in class TableWriteOperator<InternalRow>
Exception
public void notifyCheckpointComplete(long checkpointId) throws Exception
notifyCheckpointComplete
in interface org.apache.flink.api.common.state.CheckpointListener
notifyCheckpointComplete
in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<Committable>
Exception
public void notifyCheckpointAborted(long checkpointId) throws Exception
notifyCheckpointAborted
in interface org.apache.flink.api.common.state.CheckpointListener
notifyCheckpointAborted
in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<Committable>
Exception
protected List<Committable> prepareCommit(boolean waitCompaction, long checkpointId) throws IOException
prepareCommit
in class TableWriteOperator<InternalRow>
IOException
Copyright © 2023–2025 The Apache Software Foundation. All rights reserved.