public class CommitterOperator<CommitT,GlobalCommitT>
extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<CommitT>
implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<CommitT,CommitT>, org.apache.flink.streaming.api.operators.BoundedOneInput
Committables for each snapshot.| Modifier and Type | Field and Description |
|---|---|
protected NavigableMap<Long,GlobalCommitT> |
committablesPerCheckpoint
Group the committable by the checkpoint id.
|
protected Committer<CommitT,GlobalCommitT> |
committer
Aggregate committables to global committables and commit the global committables to the
external system.
|
| Constructor and Description |
|---|
CommitterOperator(boolean streamingCheckpointEnabled,
boolean forceSingleParallelism,
boolean chaining,
String initialCommitUser,
Committer.Factory<CommitT,GlobalCommitT> committerFactory,
CommittableStateManager<GlobalCommitT> committableStateManager) |
CommitterOperator(boolean streamingCheckpointEnabled,
boolean forceSingleParallelism,
boolean chaining,
String initialCommitUser,
Committer.Factory<CommitT,GlobalCommitT> committerFactory,
CommittableStateManager<GlobalCommitT> committableStateManager,
Long endInputWatermark) |
| Modifier and Type | Method and Description |
|---|---|
void |
close() |
void |
endInput() |
String |
getCommitUser() |
void |
initializeState(org.apache.flink.runtime.state.StateInitializationContext context) |
void |
notifyCheckpointComplete(long checkpointId) |
void |
processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<CommitT> element) |
void |
processWatermark(org.apache.flink.streaming.api.watermark.Watermark mark) |
void |
snapshotState(org.apache.flink.runtime.state.StateSnapshotContext context) |
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, open, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setMailboxExecutor, setProcessingTimeService, setup, snapshotState, useSplittableTimersclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitsetKeyContextElementfinish, getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, open, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotStatenotifyCheckpointAbortedgetCurrentKey, setCurrentKeyprotected final NavigableMap<Long,GlobalCommitT> committablesPerCheckpoint
protected Committer<CommitT,GlobalCommitT> committer
public CommitterOperator(boolean streamingCheckpointEnabled,
boolean forceSingleParallelism,
boolean chaining,
String initialCommitUser,
Committer.Factory<CommitT,GlobalCommitT> committerFactory,
CommittableStateManager<GlobalCommitT> committableStateManager)
public CommitterOperator(boolean streamingCheckpointEnabled,
boolean forceSingleParallelism,
boolean chaining,
String initialCommitUser,
Committer.Factory<CommitT,GlobalCommitT> committerFactory,
CommittableStateManager<GlobalCommitT> committableStateManager,
Long endInputWatermark)
public void initializeState(org.apache.flink.runtime.state.StateInitializationContext context)
throws Exception
public void processWatermark(org.apache.flink.streaming.api.watermark.Watermark mark)
throws Exception
public void snapshotState(org.apache.flink.runtime.state.StateSnapshotContext context)
throws Exception
public void endInput()
throws Exception
endInput in interface org.apache.flink.streaming.api.operators.BoundedOneInputExceptionpublic void notifyCheckpointComplete(long checkpointId)
throws Exception
public void processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<CommitT> element)
processElement in interface org.apache.flink.streaming.api.operators.Input<CommitT>public void close()
throws Exception
public String getCommitUser()
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.