Package | Description |
---|---|
org.apache.flink.cep.operator | |
org.apache.flink.streaming.api.operators | |
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 | Class and Description |
---|---|
class |
CepOperator<IN,KEY,OUT>
CEP pattern operator for a keyed input stream.
|
Modifier and Type | Class and Description |
---|---|
class |
KeyedProcessOperator<K,IN,OUT>
A
StreamOperator for executing KeyedProcessFunctions . |
class |
LegacyKeyedProcessOperator<K,IN,OUT>
Deprecated.
Replaced by
KeyedProcessOperator which takes KeyedProcessFunction |
Modifier and Type | Method and Description |
---|---|
<N> InternalTimerService<N> |
InternalTimeServiceManager.getInternalTimerService(String name,
TimerSerializer<K,N> timerSerializer,
Triggerable<K,N> triggerable) |
<K,N> InternalTimerService<N> |
AbstractStreamOperator.getInternalTimerService(String name,
TypeSerializer<N> namespaceSerializer,
Triggerable<K,N> triggerable)
Returns a
InternalTimerService that can be used to query current processing time
and event time and to set timers. |
void |
InternalTimerServiceImpl.startTimerService(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
Triggerable<K,N> triggerTarget)
Starts the local
InternalTimerServiceImpl by:
Setting the keySerialized and namespaceSerializer for the timers it will contain.
Setting the triggerTarget which contains the action to be performed when a timer fires.
Re-registering timers that were retrieved after recovering from a node failure, if any.
This method can be called multiple times, as long as it is called with the same serializers. |
Modifier and Type | Class and Description |
---|---|
class |
CoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT>
A
TwoInputStreamOperator for executing KeyedBroadcastProcessFunctions . |
class |
IntervalJoinOperator<K,T1,T2,OUT>
An
operator to execute time-bounded stream inner joins. |
class |
KeyedCoProcessOperator<K,IN1,IN2,OUT>
A
StreamOperator for executing keyed
CoProcessFunctions . |
Modifier and Type | Class and Description |
---|---|
class |
EvictingWindowOperator<K,IN,OUT,W extends Window>
A
WindowOperator that also allows an Evictor to be used. |
class |
WindowOperator<K,IN,ACC,OUT,W extends Window>
An operator that implements the logic for windowing based on a
WindowAssigner and
Trigger . |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.