public abstract class TableWriteOperator<IN> extends PrepareCommitOperator<IN,Committable>
Modifier and Type | Field and Description |
---|---|
protected FileStoreTable |
table |
protected StoreSinkWrite |
write |
memoryPool
Constructor and Description |
---|
TableWriteOperator(FileStoreTable table,
StoreSinkWrite.Provider storeSinkWriteProvider,
String initialCommitUser) |
Modifier and Type | Method and Description |
---|---|
void |
close() |
protected abstract boolean |
containLogSystem() |
protected StoreSinkWriteState |
createState(org.apache.flink.runtime.state.StateInitializationContext context,
StoreSinkWriteState.StateValueFilter stateFilter) |
protected String |
getCommitUser(org.apache.flink.runtime.state.StateInitializationContext context) |
StoreSinkWrite |
getWrite() |
void |
initializeState(org.apache.flink.runtime.state.StateInitializationContext context) |
protected List<Committable> |
prepareCommit(boolean waitCompaction,
long checkpointId) |
void |
processRecordAttributes(RecordAttributes recordAttributes) |
void |
snapshotState(org.apache.flink.runtime.state.StateSnapshotContext context) |
endInput, prepareSnapshotPreBarrier, setup
finish, 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, notifyCheckpointAborted, notifyCheckpointComplete, open, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes1, processRecordAttributes2, processWatermark, 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
finish, getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, open, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted, notifyCheckpointComplete
getCurrentKey, setCurrentKey
protected FileStoreTable table
protected transient StoreSinkWrite write
public TableWriteOperator(FileStoreTable table, 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 org.apache.flink.streaming.api.operators.AbstractStreamOperator<Committable>
Exception
protected StoreSinkWriteState createState(org.apache.flink.runtime.state.StateInitializationContext context, StoreSinkWriteState.StateValueFilter stateFilter) throws Exception
Exception
protected String getCommitUser(org.apache.flink.runtime.state.StateInitializationContext context) throws Exception
Exception
public void processRecordAttributes(RecordAttributes recordAttributes) throws Exception
processRecordAttributes
in interface org.apache.flink.streaming.api.operators.Input<IN>
processRecordAttributes
in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<Committable>
Exception
protected abstract boolean containLogSystem()
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 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 PrepareCommitOperator<IN,Committable>
Exception
protected List<Committable> prepareCommit(boolean waitCompaction, long checkpointId) throws IOException
prepareCommit
in class PrepareCommitOperator<IN,Committable>
IOException
@VisibleForTesting public StoreSinkWrite getWrite()
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.