Modifier and Type | Method and Description |
---|---|
WindowBuffer |
WindowBuffer.Factory.create(Object operatorOwner,
MemoryManager memoryManager,
long memorySize,
RuntimeContext runtimeContext,
WindowTimerService<Long> timerService,
KeyedStateBackend<RowData> stateBackend,
WindowState<Long> windowState,
boolean isEventTime,
java.time.ZoneId shiftTimeZone)
Creates a
WindowBuffer that buffers elements in memory before flushing. |
WindowBuffer |
RecordsWindowBuffer.Factory.create(Object operatorOwner,
MemoryManager memoryManager,
long memorySize,
RuntimeContext runtimeContext,
WindowTimerService<Long> timerService,
KeyedStateBackend<RowData> stateBackend,
WindowState<Long> windowState,
boolean isEventTime,
java.time.ZoneId shiftTimeZone) |
Modifier and Type | Method and Description |
---|---|
RecordsCombiner |
AggCombiner.Factory.createRecordsCombiner(RuntimeContext runtimeContext,
WindowTimerService<Long> timerService,
KeyedStateBackend<RowData> stateBackend,
WindowState<Long> windowState,
boolean isEventTime) |
RecordsCombiner |
GlobalAggCombiner.Factory.createRecordsCombiner(RuntimeContext runtimeContext,
WindowTimerService<Long> timerService,
KeyedStateBackend<RowData> stateBackend,
WindowState<Long> windowState,
boolean isEventTime) |
Constructor and Description |
---|
AggCombiner(WindowTimerService<Long> timerService,
StateKeyContext keyContext,
WindowValueState<Long> accState,
NamespaceAggsHandleFunction<Long> aggregator,
boolean isEventTime) |
GlobalAggCombiner(WindowTimerService<Long> timerService,
StateKeyContext keyContext,
WindowValueState<Long> accState,
NamespaceAggsHandleFunction<Long> localAggregator,
NamespaceAggsHandleFunction<Long> globalAggregator) |
Modifier and Type | Field and Description |
---|---|
protected WindowTimerService<Long> |
AbstractWindowAggProcessor.windowTimerService |
Modifier and Type | Method and Description |
---|---|
RecordsCombiner |
RowTimeDeduplicateRecordsCombiner.Factory.createRecordsCombiner(RuntimeContext runtimeContext,
WindowTimerService<Long> timerService,
KeyedStateBackend<RowData> stateBackend,
WindowState<Long> windowState,
boolean isEventTime) |
Constructor and Description |
---|
RowTimeDeduplicateRecordsCombiner(WindowTimerService<Long> timerService,
StateKeyContext keyContext,
WindowValueState<Long> dataState,
int rowtimeIndex,
boolean keepLastRow,
TypeSerializer<RowData> recordSerializer) |
Modifier and Type | Method and Description |
---|---|
RecordsCombiner |
TopNRecordsCombiner.Factory.createRecordsCombiner(RuntimeContext runtimeContext,
WindowTimerService<Long> timerService,
KeyedStateBackend<RowData> stateBackend,
WindowState<Long> windowState,
boolean isEventTime) |
Constructor and Description |
---|
TopNRecordsCombiner(WindowTimerService<Long> timerService,
StateKeyContext keyContext,
WindowMapState<Long,List<RowData>> dataState,
Comparator<RowData> sortKeyComparator,
KeySelector<RowData,RowData> sortKeySelector,
long topN,
TypeSerializer<RowData> recordSerializer,
boolean isEventTime) |
Modifier and Type | Method and Description |
---|---|
RecordsCombiner |
RecordsCombiner.Factory.createRecordsCombiner(RuntimeContext runtimeContext,
WindowTimerService<Long> timerService,
KeyedStateBackend<RowData> stateBackend,
WindowState<Long> windowState,
boolean isEventTime)
Creates a
RecordsCombiner that can combine buffered data into states. |
Modifier and Type | Class and Description |
---|---|
class |
WindowTimerServiceImpl
Simple Implements of
WindowTimerService . |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.