Package | Description |
---|---|
org.apache.flink.runtime.operators.sort | |
org.apache.flink.table.runtime.operators.sort |
Class and Description |
---|
AbstractMergeInnerJoinIterator
An implementation of the
JoinTaskIterator that
realizes the joining through a sort-merge join strategy. |
AbstractMergeIterator |
AbstractMergeOuterJoinIterator
An implementation of the
JoinTaskIterator that
realizes the outer join through a sort-merge join strategy. |
ExceptionHandler
Interface to be implemented by classes that handle exceptions.
|
IndexedSortable |
IndexedSorter |
InMemorySorter |
InMemorySorterFactory
Factory for
InMemorySorter . |
LargeRecordHandler |
MergeIterator
An iterator that returns a sorted merge of the sequences of elements from a set of iterators,
assuming those sequences are ordered themselves.
|
Sorter
The SortMerger interface representing the public interface to all specific Sort-Merge
implementations.
|
UnilateralSortMerger
The
UnilateralSortMerger is a full fledged sorter. |
UnilateralSortMerger.ChannelWithBlockCount |
UnilateralSortMerger.CircularElement
Class representing buffers that circulate between the reading, sorting and spilling thread.
|
UnilateralSortMerger.CircularQueues
Collection of queues that are used for the communication between the threads.
|
UnilateralSortMerger.SpillingThread
The thread that handles the spilling of intermediate results and sets up the merging.
|
UnilateralSortMerger.ThreadBase
Base class for all working threads in this sort-merger.
|
Class and Description |
---|
IndexedSortable |
Sorter
The SortMerger interface representing the public interface to all specific Sort-Merge
implementations.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.