Interface | Description |
---|---|
ExceptionHandler<E extends Throwable> |
Interface to be implemented by classes that handle exceptions.
|
IndexedSortable | |
IndexedSorter | |
InMemorySorter<T> | |
Sorter<E> |
The SortMerger interface representing the public interface to all specific Sort-Merge implementations.
|
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. |
CombiningUnilateralSortMerger<E> |
The CombiningUnilateralSortMerger is part of a merge-sort implementation.
|
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> | |
UnilateralSortMerger<E> |
The
UnilateralSortMerger is a full fledged sorter. |
UnilateralSortMerger.ChannelWithBlockCount | |
UnilateralSortMerger.CircularElement<E> |
Class representing buffers that circulate between the reading, sorting and spilling thread.
|
UnilateralSortMerger.CircularQueues<E> |
Collection of queues that are used for the communication between the threads.
|
UnilateralSortMerger.ReadingThread<E> |
The thread that consumes the input data and puts it into a buffer that will be sorted.
|
UnilateralSortMerger.SortingThread<E> |
The thread that sorts filled buffers.
|
UnilateralSortMerger.ThreadBase<E> |
Base class for all working threads in this sort-merger.
|
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.