Package | Description |
---|---|
org.apache.flink.storm.wrappers | |
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.
|
Modifier and Type | Field and Description |
---|---|
protected TimestampedCollector<OUT> |
BoltWrapper.flinkCollector
We have to use this because Operators must output
StreamRecord . |
Modifier and Type | Method and Description |
---|---|
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. |
protected TimestampedCollector<OUT> |
NonKeyedWindowOperator.timestampedCollector
This is given to the
WindowFunction for emitting elements with a given timestamp. |
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.