public abstract class AbstractWrapperOperator<T> extends Object implements org.apache.flink.streaming.api.operators.StreamOperator<IterationRecord<T>>, OperatorEpochWatermarkTrackerListener, org.apache.flink.streaming.api.operators.BoundedMultiInput
| 限定符和类型 | 字段和说明 |
|---|---|
protected org.apache.flink.streaming.runtime.tasks.StreamTask<?,?> |
containingTask |
protected org.apache.flink.iteration.operator.AbstractWrapperOperator.EpochSupplier |
epochWatermarkSupplier |
protected OperatorEpochWatermarkTracker |
epochWatermarkTracker |
protected BroadcastOutput<IterationRecord<T>> |
eventBroadcastOutput |
protected org.apache.flink.iteration.operator.AbstractWrapperOperator.IterationContext |
iterationContext |
protected org.apache.flink.runtime.metrics.groups.InternalOperatorMetricGroup |
metrics
Metric group for the operator.
|
protected org.apache.flink.streaming.api.operators.StreamOperatorFactory<T> |
operatorFactory |
protected org.apache.flink.streaming.api.operators.Output<org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<T>>> |
output |
protected org.apache.flink.streaming.api.operators.StreamOperatorParameters<IterationRecord<T>> |
parameters |
protected ProxyOutput<T> |
proxyOutput |
protected org.apache.flink.streaming.api.graph.StreamConfig |
streamConfig |
protected String |
uniqueSenderId |
| 构造器和说明 |
|---|
AbstractWrapperOperator(org.apache.flink.streaming.api.operators.StreamOperatorParameters<IterationRecord<T>> parameters,
org.apache.flink.streaming.api.operators.StreamOperatorFactory<T> operatorFactory) |
| 限定符和类型 | 方法和说明 |
|---|---|
protected void |
clearIterationContextRound() |
void |
endInput(int i) |
protected void |
notifyEpochWatermarkIncrement(IterationListener<?> listener,
int epochWatermark) |
protected void |
onEpochWatermarkEvent(int inputIndex,
IterationRecord<?> iterationRecord) |
void |
onEpochWatermarkIncrement(int epochWatermark)
Notifies a new round is aligned to a new epoch watermark.
|
protected void |
setIterationContextRound(Integer contextRound) |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitclose, finish, getMetricGroup, getOperatorID, initializeState, open, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotStateprotected final org.apache.flink.streaming.api.operators.StreamOperatorParameters<IterationRecord<T>> parameters
protected final org.apache.flink.streaming.api.graph.StreamConfig streamConfig
protected final org.apache.flink.streaming.runtime.tasks.StreamTask<?,?> containingTask
protected final org.apache.flink.streaming.api.operators.Output<org.apache.flink.streaming.runtime.streamrecord.StreamRecord<IterationRecord<T>>> output
protected final org.apache.flink.streaming.api.operators.StreamOperatorFactory<T> operatorFactory
protected final org.apache.flink.iteration.operator.AbstractWrapperOperator.IterationContext iterationContext
protected final ProxyOutput<T> proxyOutput
protected final org.apache.flink.iteration.operator.AbstractWrapperOperator.EpochSupplier epochWatermarkSupplier
protected final org.apache.flink.runtime.metrics.groups.InternalOperatorMetricGroup metrics
protected final OperatorEpochWatermarkTracker epochWatermarkTracker
protected final String uniqueSenderId
protected final BroadcastOutput<IterationRecord<T>> eventBroadcastOutput
public AbstractWrapperOperator(org.apache.flink.streaming.api.operators.StreamOperatorParameters<IterationRecord<T>> parameters, org.apache.flink.streaming.api.operators.StreamOperatorFactory<T> operatorFactory)
protected void onEpochWatermarkEvent(int inputIndex,
IterationRecord<?> iterationRecord)
throws IOException
IOExceptionprotected void notifyEpochWatermarkIncrement(IterationListener<?> listener, int epochWatermark) throws Exception
Exceptionpublic void onEpochWatermarkIncrement(int epochWatermark)
throws IOException
OperatorEpochWatermarkTrackerListeneronEpochWatermarkIncrement 在接口中 OperatorEpochWatermarkTrackerListenerepochWatermark - The new epoch watermark.IOExceptionprotected void setIterationContextRound(Integer contextRound)
protected void clearIterationContextRound()
Copyright © 2019–2022 The Apache Software Foundation. All rights reserved.