Interface | Description |
---|---|
ExceptionHandler<E extends Throwable> |
Interface to be implemented by classes that handle exceptions.
|
IndexedSortable | |
IndexedSorter | |
InMemorySorter<T> | |
InMemorySorterFactory<T> |
Factory for
InMemorySorter . |
PushSorter<E> |
A push-based
Sorter . |
Sorter<E> |
The SortMerger interface representing the public interface to all specific Sort-Merge
implementations.
|
StageRunner |
An interface for different stages of the sorting process.
|
StageRunner.StageMessageDispatcher<E> |
A dispatcher for inter-stage communication.
|
Class | Description |
---|---|
AbstractMergeInnerJoinIterator<T1,T2,O> |
An implementation of the
JoinTaskIterator that
realizes the joining through a sort-merge join strategy. |
AbstractMergeIterator<T1,T2,O> | |
AbstractMergeOuterJoinIterator<T1,T2,O> |
An implementation of the
JoinTaskIterator that
realizes the outer join through a sort-merge join strategy. |
DefaultInMemorySorterFactory<T> |
Default factory for
InMemorySorter . |
ExternalSorter<E> |
The
ExternalSorter is a full fledged sorter. |
ExternalSorterBuilder<T> |
A builder for an
ExternalSorter . |
FixedLengthRecordSorter<T> | |
HeapSort | |
LargeRecordHandler<T> | |
MergeIterator<E> |
An iterator that returns a sorted merge of the sequences of elements from a set of iterators,
assuming those sequences are ordered themselves.
|
NonReusingMergeInnerJoinIterator<T1,T2,O> | |
NonReusingMergeOuterJoinIterator<T1,T2,O> | |
NonReusingSortMergeCoGroupIterator<T1,T2> | |
NormalizedKeySorter<T> | |
PartialOrderPriorityQueue<T> |
This class implements a priority-queue, which maintains a partial ordering of its elements such
that the least element can always be found in constant time.
|
QuickSort | |
ReusingMergeInnerJoinIterator<T1,T2,O> | |
ReusingMergeOuterJoinIterator<T1,T2,O> | |
ReusingSortMergeCoGroupIterator<T1,T2> |
Enum | Description |
---|---|
StageRunner.SortStage |
A marker interface for sending messages to different stages.
|
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.