Package | Description |
---|---|
org.apache.flink.state.api.input.operator | |
org.apache.flink.streaming.api | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.api.operators.python.process.timer | |
org.apache.flink.streaming.api.operators.sorted.state | |
org.apache.flink.streaming.api.utils | |
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.window.slicing |
Modifier and Type | Method and Description |
---|---|
protected InternalTimerService<N> |
StateReaderOperator.getInternalTimerService(String name) |
Constructor and Description |
---|
SimpleTimerService(InternalTimerService<VoidNamespace> internalTimerService) |
Modifier and Type | Class and Description |
---|---|
class |
InternalTimerServiceImpl<K,N>
InternalTimerService that stores timers on the Java heap. |
Modifier and Type | Method and Description |
---|---|
<N> InternalTimerService<N> |
InternalTimeServiceManager.getInternalTimerService(String name,
TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
Triggerable<K,N> triggerable)
Creates an
InternalTimerService for handling a group of timers identified by the
given name . |
<N> InternalTimerService<N> |
InternalTimeServiceManagerImpl.getInternalTimerService(String name,
TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
Triggerable<K,N> triggerable) |
<K,N> InternalTimerService<N> |
AbstractStreamOperatorV2.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. |
<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. |
Constructor and Description |
---|
TimerRegistration(KeyedStateBackend<Row> keyedStateBackend,
InternalTimerService internalTimerService,
KeyContext keyContext,
TypeSerializer namespaceSerializer,
TypeSerializer<Row> timerDataSerializer) |
Modifier and Type | Class and Description |
---|---|
class |
BatchExecutionInternalTimeService<K,N>
An implementation of a
InternalTimerService that manages timers with a single active key
at a time. |
Modifier and Type | Method and Description |
---|---|
<N> InternalTimerService<N> |
BatchExecutionInternalTimeServiceManager.getInternalTimerService(String name,
TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
Triggerable<K,N> triggerable) |
Modifier and Type | Method and Description |
---|---|
static <K,N> void |
PythonOperatorUtils.setCurrentKeyForTimerService(InternalTimerService<N> internalTimerService,
K currentKey)
Set the current key for the timer service.
|
Modifier and Type | Field and Description |
---|---|
protected InternalTimerService<W> |
WindowOperator.internalTimerService |
Modifier and Type | Method and Description |
---|---|
InternalTimerService<W> |
SlicingWindowProcessor.Context.getTimerService()
Returns the current
InternalTimerService . |
Modifier and Type | Method and Description |
---|---|
static ClockService |
ClockService.of(InternalTimerService<?> timerService)
Creates a
ClockService from the given InternalTimerService . |
Constructor and Description |
---|
WindowTimerServiceImpl(InternalTimerService<Long> internalTimerService,
ZoneId shiftTimeZone) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.