public final class FeedbackUnionOperator<T> extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<T> implements FeedbackConsumer<T>, org.apache.flink.streaming.api.operators.OneInputStreamOperator<T,T>
Modifier and Type | Method and Description |
---|---|
void |
close() |
void |
initializeState(org.apache.flink.runtime.state.StateInitializationContext context) |
protected boolean |
isUsingCustomRawKeyedState() |
void |
processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<T> streamRecord) |
void |
processFeedback(T element) |
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, getTimeServiceManager, getUserCodeClassloader, initializeState, notifyCheckpointAborted, notifyCheckpointComplete, open, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processWatermark, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setProcessingTimeService, setup, snapshotState
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
setKeyContextElement
finish, getMetricGroup, getOperatorID, initializeState, open, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted, notifyCheckpointComplete
public void processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<T> streamRecord)
processElement
in interface org.apache.flink.streaming.api.operators.Input<T>
public void processFeedback(T element)
processFeedback
in interface FeedbackConsumer<T>
public void initializeState(org.apache.flink.runtime.state.StateInitializationContext context) throws java.lang.Exception
initializeState
in interface org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
initializeState
in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<T>
java.lang.Exception
public void snapshotState(org.apache.flink.runtime.state.StateSnapshotContext context) throws java.lang.Exception
snapshotState
in interface org.apache.flink.streaming.api.operators.StreamOperatorStateHandler.CheckpointedStreamOperator
snapshotState
in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<T>
java.lang.Exception
protected boolean isUsingCustomRawKeyedState()
isUsingCustomRawKeyedState
in class org.apache.flink.streaming.api.operators.AbstractStreamOperator<T>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.