public static final class RecordsWindowBuffer.Factory extends Object implements WindowBuffer.Factory
RecordsWindowBuffer
with RecordsCombiner.Factory
.Constructor and Description |
---|
Factory(PagedTypeSerializer<RowData> keySer,
AbstractRowDataSerializer<RowData> inputSer,
RecordsCombiner.Factory combinerFactory) |
Modifier and Type | Method and Description |
---|---|
WindowBuffer |
create(Object operatorOwner,
MemoryManager memoryManager,
long memorySize,
RuntimeContext runtimeContext,
WindowTimerService<Long> timerService,
KeyedStateBackend<RowData> stateBackend,
WindowState<Long> windowState,
boolean isEventTime,
ZoneId shiftTimeZone)
Creates a
WindowBuffer that buffers elements in memory before flushing. |
public Factory(PagedTypeSerializer<RowData> keySer, AbstractRowDataSerializer<RowData> inputSer, RecordsCombiner.Factory combinerFactory)
public WindowBuffer create(Object operatorOwner, MemoryManager memoryManager, long memorySize, RuntimeContext runtimeContext, WindowTimerService<Long> timerService, KeyedStateBackend<RowData> stateBackend, WindowState<Long> windowState, boolean isEventTime, ZoneId shiftTimeZone) throws Exception
WindowBuffer.Factory
WindowBuffer
that buffers elements in memory before flushing.create
in interface WindowBuffer.Factory
operatorOwner
- the owner of the operatormemoryManager
- the manager that governs memory by Flink frameworkmemorySize
- the managed memory size can be used by this operatorruntimeContext
- the current RuntimeContext
timerService
- the service to register event-time and processing-time timersstateBackend
- the state backend to accessing stateswindowState
- the window state to flush buffered data into.isEventTime
- indicates whether the operator works in event-time or processing-time
mode, used for register corresponding timers.shiftTimeZone
- the shift timezone of the windowIOException
- thrown if the buffer can't be openedException
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.