Package | Description |
---|---|
org.apache.flink.streaming.api.operators.async.queue | |
org.apache.flink.streaming.api.operators.co | |
org.apache.flink.streaming.runtime.operators.windowing |
This package contains the operators that implement the various window operations on data streams.
|
org.apache.flink.table.runtime.operators.join.stream | |
org.apache.flink.table.runtime.operators.window |
Modifier and Type | Method and Description |
---|---|
void |
UnorderedStreamElementQueue.emitCompletedElement(TimestampedCollector<OUT> output) |
void |
OrderedStreamElementQueue.emitCompletedElement(TimestampedCollector<OUT> output) |
void |
StreamElementQueue.emitCompletedElement(TimestampedCollector<OUT> output)
Emits one completed element from the head of this queue into the given output.
|
Modifier and Type | Method and Description |
---|---|
protected TimestampedCollector<OUT> |
LegacyKeyedCoProcessOperator.getCollector()
Deprecated.
|
protected TimestampedCollector<OUT> |
KeyedCoProcessOperator.getCollector() |
protected TimestampedCollector<OUT> |
CoStreamFlatMap.getCollector() |
Modifier and Type | Field and Description |
---|---|
protected TimestampedCollector<OUT> |
WindowOperator.timestampedCollector
This is given to the
InternalWindowFunction for emitting elements with a given
timestamp. |
Modifier and Type | Field and Description |
---|---|
protected TimestampedCollector<RowData> |
AbstractStreamingJoinOperator.collector |
Modifier and Type | Field and Description |
---|---|
protected TimestampedCollector<RowData> |
WindowOperator.collector
This is used for emitting elements with a given timestamp.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.