OUT
- The type of elements accepted by the chain, i.e., the input type of the chain's
head operator.@Internal public class OperatorChain<OUT,OP extends StreamOperator<OUT>> extends Object implements StreamStatusMaintainer
OperatorChain
contains all operators that are executed as one chain within a single
StreamTask
.Modifier and Type | Class and Description |
---|---|
static interface |
OperatorChain.WatermarkGaugeExposingOutput<T>
An
Output that measures the last emitted watermark with a WatermarkGauge . |
Constructor and Description |
---|
OperatorChain(StreamTask<OUT,OP> containingTask,
List<StreamRecordWriter<SerializationDelegate<StreamRecord<OUT>>>> streamRecordWriters) |
Modifier and Type | Method and Description |
---|---|
void |
broadcastCheckpointBarrier(long id,
long timestamp,
CheckpointOptions checkpointOptions) |
void |
broadcastCheckpointCancelMarker(long id) |
void |
flushOutputs()
This method should be called before finishing the record emission, to make sure any data
that is still buffered will be sent.
|
StreamOperator<?>[] |
getAllOperators() |
OperatorChain.WatermarkGaugeExposingOutput<StreamRecord<OUT>> |
getChainEntryPoint() |
int |
getChainLength() |
OP |
getHeadOperator() |
RecordWriterOutput<?>[] |
getStreamOutputs() |
StreamStatus |
getStreamStatus()
Returns the current stream status.
|
void |
releaseOutputs()
This method releases all resources of the record writer output.
|
void |
toggleStreamStatus(StreamStatus status)
Toggles the current stream status.
|
public OperatorChain(StreamTask<OUT,OP> containingTask, List<StreamRecordWriter<SerializationDelegate<StreamRecord<OUT>>>> streamRecordWriters)
public StreamStatus getStreamStatus()
StreamStatusProvider
getStreamStatus
in interface StreamStatusProvider
public void toggleStreamStatus(StreamStatus status)
StreamStatusMaintainer
toggleStreamStatus
in interface StreamStatusMaintainer
status
- the new status to toggle topublic void broadcastCheckpointBarrier(long id, long timestamp, CheckpointOptions checkpointOptions) throws IOException
IOException
public void broadcastCheckpointCancelMarker(long id) throws IOException
IOException
public RecordWriterOutput<?>[] getStreamOutputs()
public StreamOperator<?>[] getAllOperators()
public OperatorChain.WatermarkGaugeExposingOutput<StreamRecord<OUT>> getChainEntryPoint()
public void flushOutputs() throws IOException
IOException
- Thrown, if the buffered data cannot be pushed into the output streams.public void releaseOutputs()
This method should never fail.
public OP getHeadOperator()
public int getChainLength()
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.