public class OutputOperator<T> extends org.apache.flink.streaming.api.operators.AbstractStreamOperator<T> implements org.apache.flink.streaming.api.operators.OneInputStreamOperator<IterationRecord<T>,T>
IterationRecord into user record, and desert all the event
records.| 构造器和说明 |
|---|
OutputOperator() |
| 限定符和类型 | 方法和说明 |
|---|---|
void |
open() |
void |
processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<T>> streamRecord) |
close, finish, getChainingStrategy, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getTimeServiceManager, getUserCodeClassloader, initializeState, initializeState, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, prepareSnapshotPreBarrier, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processWatermark, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setCurrentKey, setKeyContextElement1, setKeyContextElement2, setProcessingTimeService, setup, snapshotState, snapshotStateclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitclose, finish, getMetricGroup, getOperatorID, initializeState, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotStatepublic void open()
throws Exception
public void processElement(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<T>> streamRecord) throws Exception
processElement 在接口中 org.apache.flink.streaming.api.operators.Input<IterationRecord<T>>ExceptionCopyright © 2019–2022 The Apache Software Foundation. All rights reserved.