Uses of Class
org.apache.flink.table.runtime.util.WindowKey
-
-
Uses of WindowKey in org.apache.flink.table.runtime.operators.aggregate.window.combines
Methods in org.apache.flink.table.runtime.operators.aggregate.window.combines with parameters of type WindowKey Modifier and Type Method Description void
AggCombiner. combine(WindowKey windowKey, Iterator<org.apache.flink.table.data.RowData> records)
void
GlobalAggCombiner. combine(WindowKey windowKey, Iterator<org.apache.flink.table.data.RowData> localAccs)
void
LocalAggCombiner. combine(WindowKey windowKey, Iterator<org.apache.flink.table.data.RowData> records)
-
Uses of WindowKey in org.apache.flink.table.runtime.operators.deduplicate.window.combines
Methods in org.apache.flink.table.runtime.operators.deduplicate.window.combines with parameters of type WindowKey Modifier and Type Method Description void
RowTimeDeduplicateRecordsCombiner. combine(WindowKey windowKey, Iterator<org.apache.flink.table.data.RowData> records)
-
Uses of WindowKey in org.apache.flink.table.runtime.operators.rank.window.combines
Methods in org.apache.flink.table.runtime.operators.rank.window.combines with parameters of type WindowKey Modifier and Type Method Description void
TopNRecordsCombiner. combine(WindowKey windowKey, Iterator<org.apache.flink.table.data.RowData> records)
-
Uses of WindowKey in org.apache.flink.table.runtime.operators.window.tvf.combines
Methods in org.apache.flink.table.runtime.operators.window.tvf.combines with parameters of type WindowKey Modifier and Type Method Description void
RecordsCombiner. combine(WindowKey windowKey, Iterator<org.apache.flink.table.data.RowData> records)
Combines the buffered data into state based on the given window-key pair. -
Uses of WindowKey in org.apache.flink.table.runtime.typeutils
Methods in org.apache.flink.table.runtime.typeutils that return WindowKey Modifier and Type Method Description WindowKey
WindowKeySerializer. copy(WindowKey from)
WindowKey
WindowKeySerializer. copy(WindowKey from, WindowKey reuse)
WindowKey
WindowKeySerializer. createInstance()
WindowKey
WindowKeySerializer. deserialize(org.apache.flink.core.memory.DataInputView source)
WindowKey
WindowKeySerializer. deserialize(WindowKey reuse, org.apache.flink.core.memory.DataInputView source)
WindowKey
WindowKeySerializer. deserializeFromPages(org.apache.flink.runtime.memory.AbstractPagedInputView source)
WindowKey
WindowKeySerializer. deserializeFromPages(WindowKey reuse, org.apache.flink.runtime.memory.AbstractPagedInputView source)
WindowKey
WindowKeySerializer. mapFromPages(WindowKey reuse, org.apache.flink.runtime.memory.AbstractPagedInputView source)
Methods in org.apache.flink.table.runtime.typeutils that return types with arguments of type WindowKey Modifier and Type Method Description org.apache.flink.api.common.typeutils.TypeSerializer<WindowKey>
WindowKeySerializer. duplicate()
org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<WindowKey>
WindowKeySerializer. snapshotConfiguration()
Methods in org.apache.flink.table.runtime.typeutils with parameters of type WindowKey Modifier and Type Method Description WindowKey
WindowKeySerializer. copy(WindowKey from)
WindowKey
WindowKeySerializer. copy(WindowKey from, WindowKey reuse)
WindowKey
WindowKeySerializer. deserialize(WindowKey reuse, org.apache.flink.core.memory.DataInputView source)
WindowKey
WindowKeySerializer. deserializeFromPages(WindowKey reuse, org.apache.flink.runtime.memory.AbstractPagedInputView source)
WindowKey
WindowKeySerializer. mapFromPages(WindowKey reuse, org.apache.flink.runtime.memory.AbstractPagedInputView source)
void
WindowKeySerializer. serialize(WindowKey record, org.apache.flink.core.memory.DataOutputView target)
int
WindowKeySerializer. serializeToPages(WindowKey record, org.apache.flink.runtime.memory.AbstractPagedOutputView target)
Actually, the return value is just for saving checkSkipReadForFixLengthPart in the mapFromPages, the cost is very small. -
Uses of WindowKey in org.apache.flink.table.runtime.util
Methods in org.apache.flink.table.runtime.util that return WindowKey Modifier and Type Method Description WindowKey
WindowKey. replace(long window, org.apache.flink.table.data.RowData key)
Replace the currently stored key and window by the given new key and new window.
-