Modifier and Type | Method and Description |
---|---|
void |
CepOperator.onEventTime(InternalTimer<KEY,VoidNamespace> timer) |
void |
CepOperator.onProcessingTime(InternalTimer<KEY,VoidNamespace> timer) |
Modifier and Type | Method and Description |
---|---|
void |
VoidTriggerable.onEventTime(InternalTimer<K,N> timer) |
void |
VoidTriggerable.onProcessingTime(InternalTimer<K,N> timer) |
Modifier and Type | Class and Description |
---|---|
class |
TimerHeapInternalTimer<K,N>
Implementation of
InternalTimer to use with a HeapPriorityQueueSet . |
Modifier and Type | Field and Description |
---|---|
static KeyExtractorFunction<InternalTimer<?,?>> |
InternalTimer.KEY_EXTRACTOR_FUNCTION
Function to extract the key from a
InternalTimer . |
static PriorityComparator<InternalTimer<?,?>> |
InternalTimer.TIMER_COMPARATOR
Function to compare instances of
InternalTimer . |
Modifier and Type | Method and Description |
---|---|
int |
TimerHeapInternalTimer.comparePriorityTo(InternalTimer<?,?> other) |
void |
BatchGroupedReduceOperator.onEventTime(InternalTimer<KEY,VoidNamespace> timer) |
void |
Triggerable.onEventTime(InternalTimer<K,N> timer)
Invoked when an event-time timer fires.
|
void |
LegacyKeyedProcessOperator.onEventTime(InternalTimer<K,VoidNamespace> timer)
Deprecated.
|
void |
KeyedProcessOperator.onEventTime(InternalTimer<K,VoidNamespace> timer) |
void |
BatchGroupedReduceOperator.onProcessingTime(InternalTimer<KEY,VoidNamespace> timer) |
void |
Triggerable.onProcessingTime(InternalTimer<K,N> timer)
Invoked when a processing-time timer fires.
|
void |
LegacyKeyedProcessOperator.onProcessingTime(InternalTimer<K,VoidNamespace> timer)
Deprecated.
|
void |
KeyedProcessOperator.onProcessingTime(InternalTimer<K,VoidNamespace> timer) |
Modifier and Type | Method and Description |
---|---|
void |
IntervalJoinOperator.onEventTime(InternalTimer<K,String> timer) |
void |
CoBroadcastWithKeyedOperator.onEventTime(InternalTimer<KS,VoidNamespace> timer) |
void |
KeyedCoProcessOperator.onEventTime(InternalTimer<K,VoidNamespace> timer) |
void |
LegacyKeyedCoProcessOperator.onEventTime(InternalTimer<K,VoidNamespace> timer)
Deprecated.
|
void |
IntervalJoinOperator.onProcessingTime(InternalTimer<K,String> timer) |
void |
CoBroadcastWithKeyedOperator.onProcessingTime(InternalTimer<KS,VoidNamespace> timer) |
void |
KeyedCoProcessOperator.onProcessingTime(InternalTimer<K,VoidNamespace> timer) |
void |
LegacyKeyedCoProcessOperator.onProcessingTime(InternalTimer<K,VoidNamespace> timer)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
EmbeddedPythonKeyedProcessOperator.onEventTime(InternalTimer<K,VoidNamespace> timer) |
void |
EmbeddedPythonKeyedCoProcessOperator.onEventTime(InternalTimer<K,VoidNamespace> timer) |
void |
EmbeddedPythonWindowOperator.onEventTime(InternalTimer<K,W> timer) |
void |
EmbeddedPythonKeyedProcessOperator.onProcessingTime(InternalTimer<K,VoidNamespace> timer) |
void |
EmbeddedPythonKeyedCoProcessOperator.onProcessingTime(InternalTimer<K,VoidNamespace> timer) |
void |
EmbeddedPythonWindowOperator.onProcessingTime(InternalTimer<K,W> timer) |
Modifier and Type | Method and Description |
---|---|
void |
ExternalPythonKeyedProcessOperator.onEventTime(InternalTimer<Row,Object> timer) |
void |
ExternalPythonKeyedCoProcessOperator.onEventTime(InternalTimer<Row,VoidNamespace> timer) |
void |
ExternalPythonKeyedProcessOperator.onProcessingTime(InternalTimer<Row,Object> timer) |
void |
ExternalPythonKeyedCoProcessOperator.onProcessingTime(InternalTimer<Row,VoidNamespace> timer) |
Modifier and Type | Method and Description |
---|---|
void |
EvictingWindowOperator.onEventTime(InternalTimer<K,W> timer) |
void |
WindowOperator.onEventTime(InternalTimer<K,W> timer) |
void |
EvictingWindowOperator.onProcessingTime(InternalTimer<K,W> timer) |
void |
WindowOperator.onProcessingTime(InternalTimer<K,W> timer) |
Modifier and Type | Method and Description |
---|---|
void |
TemporalRowTimeJoinOperator.onEventTime(InternalTimer<Object,VoidNamespace> timer) |
void |
TemporalProcessTimeJoinOperator.onEventTime(InternalTimer<Object,VoidNamespace> timer)
Invoked when an event-time timer fires.
|
void |
BaseTwoInputStreamOperatorWithStateRetention.onProcessingTime(InternalTimer<Object,VoidNamespace> timer)
The users of this class are not allowed to use processing time timers.
|
Modifier and Type | Method and Description |
---|---|
void |
WindowJoinOperator.onEventTime(InternalTimer<RowData,Long> timer) |
void |
WindowJoinOperator.onProcessingTime(InternalTimer<RowData,Long> timer) |
Modifier and Type | Method and Description |
---|---|
void |
PythonStreamGroupWindowAggregateOperator.onEventTime(InternalTimer<K,W> timer) |
void |
AbstractPythonStreamGroupAggregateOperator.onEventTime(InternalTimer<RowData,VoidNamespace> timer)
Invoked when an event-time timer fires.
|
void |
PythonStreamGroupWindowAggregateOperator.onProcessingTime(InternalTimer<K,W> timer) |
void |
AbstractPythonStreamGroupAggregateOperator.onProcessingTime(InternalTimer<RowData,VoidNamespace> timer)
Invoked when a processing-time timer fires.
|
Modifier and Type | Method and Description |
---|---|
void |
AbstractStreamArrowPythonBoundedRangeOperator.onEventTime(InternalTimer<K,VoidNamespace> timer) |
void |
AbstractStreamArrowPythonBoundedRowsOperator.onEventTime(InternalTimer<K,VoidNamespace> timer) |
void |
StreamArrowPythonGroupWindowAggregateFunctionOperator.onEventTime(InternalTimer<K,W> timer) |
void |
AbstractStreamArrowPythonBoundedRangeOperator.onProcessingTime(InternalTimer<K,VoidNamespace> timer) |
void |
AbstractStreamArrowPythonBoundedRowsOperator.onProcessingTime(InternalTimer<K,VoidNamespace> timer) |
void |
StreamArrowPythonGroupWindowAggregateFunctionOperator.onProcessingTime(InternalTimer<K,W> timer) |
Modifier and Type | Method and Description |
---|---|
void |
ProcTimeSortOperator.onEventTime(InternalTimer<RowData,VoidNamespace> timer) |
void |
RowTimeSortOperator.onEventTime(InternalTimer<RowData,VoidNamespace> timer) |
void |
ProcTimeSortOperator.onProcessingTime(InternalTimer<RowData,VoidNamespace> timer) |
void |
RowTimeSortOperator.onProcessingTime(InternalTimer<RowData,VoidNamespace> timer) |
Modifier and Type | Method and Description |
---|---|
void |
WindowOperator.onEventTime(InternalTimer<K,W> timer) |
void |
WindowOperator.onProcessingTime(InternalTimer<K,W> timer) |
Modifier and Type | Method and Description |
---|---|
void |
SlicingWindowOperator.onEventTime(InternalTimer<K,W> timer) |
void |
SlicingWindowOperator.onProcessingTime(InternalTimer<K,W> timer) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.