Modifier and Type | Class and Description |
---|---|
class |
ChannelReaderInputViewIterator<E>
A simple iterator over the input read though an I/O channel.
|
class |
InputViewIterator<E> |
Modifier and Type | Class and Description |
---|---|
class |
HashPartitionIterator<BT,PT>
Iterator over the build side entries of a HashPartition . |
Modifier and Type | Field and Description |
---|---|
protected MutableObjectIterator<?>[] |
BatchTask.inputIterators
The inputs reader, wrapped in an iterator.
|
protected MutableObjectIterator<?>[] |
BatchTask.inputs
The inputs to the operator.
|
Modifier and Type | Method and Description |
---|---|
protected MutableObjectIterator<?> |
BatchTask.createInputIterator(MutableReader<?> inputReader,
TypeSerializerFactory<?> serializerFactory) |
<X> MutableObjectIterator<X> |
BatchTask.getInput(int index) |
<X> MutableObjectIterator<X> |
TaskContext.getInput(int index) |
MutableObjectIterator<T> |
TempBarrier.getIterator()
This method resets the input!
|
Constructor and Description |
---|
SimpleIterable(IN reuse,
MutableObjectIterator<IN> iterator) |
SimpleIterator(IN reuse,
MutableObjectIterator<IN> iterator) |
TempBarrier(AbstractInvokable owner,
MutableObjectIterator<T> input,
TypeSerializerFactory<T> serializerFactory,
MemoryManager memManager,
IOManager ioManager,
int numPages,
List<MemorySegment> preAllocated) |
Modifier and Type | Class and Description |
---|---|
class |
CompactingHashTable.EntryIterator
Iterator that traverses the whole hash table once
If entries are inserted during iteration they may be overlooked by the iterator
|
class |
InPlaceMutableHashTable.EntryIterator
WARNING: Doing any other operation on the table invalidates the iterator!
|
static class |
MutableHashTable.HashBucketIterator<BT,PT> |
static class |
MutableHashTable.UnmatchedBuildIterator<BT,PT>
Iterate all the elements in memory which has not been probed during probe phase.
|
Modifier and Type | Method and Description |
---|---|
MutableObjectIterator<BT> |
MutableHashTable.getBuildSideIterator() |
MutableObjectIterator<T> |
CompactingHashTable.getEntryIterator() |
abstract MutableObjectIterator<T> |
AbstractMutableHashTable.getEntryIterator() |
Modifier and Type | Method and Description |
---|---|
protected void |
MutableHashTable.buildInitialTable(MutableObjectIterator<BT> input)
Creates the initial hash table.
|
void |
CompactingHashTable.buildTableWithUniqueKey(MutableObjectIterator<T> input) |
void |
MutableHashTable.open(MutableObjectIterator<BT> buildSide,
MutableObjectIterator<PT> probeSide)
Opens the hash join.
|
void |
MutableHashTable.open(MutableObjectIterator<BT> buildSide,
MutableObjectIterator<PT> probeSide)
Opens the hash join.
|
void |
MutableHashTable.open(MutableObjectIterator<BT> buildSide,
MutableObjectIterator<PT> probeSide,
boolean buildOuterJoin)
Opens the hash join.
|
void |
MutableHashTable.open(MutableObjectIterator<BT> buildSide,
MutableObjectIterator<PT> probeSide,
boolean buildOuterJoin)
Opens the hash join.
|
void |
ReOpenableMutableHashTable.open(MutableObjectIterator<BT> buildSide,
MutableObjectIterator<PT> probeSide,
boolean buildSideOuterJoin) |
void |
ReOpenableMutableHashTable.open(MutableObjectIterator<BT> buildSide,
MutableObjectIterator<PT> probeSide,
boolean buildSideOuterJoin) |
void |
ReOpenableMutableHashTable.reopenProbe(MutableObjectIterator<PT> probeInput) |
void |
NonReusingBuildSecondReOpenableHashJoinIterator.reopenProbe(MutableObjectIterator<V1> probeInput)
Set new input for probe side
|
void |
ReusingBuildSecondReOpenableHashJoinIterator.reopenProbe(MutableObjectIterator<V1> probeInput)
Set new input for probe side
|
void |
NonReusingBuildFirstReOpenableHashJoinIterator.reopenProbe(MutableObjectIterator<V2> probeInput)
Set new input for probe side
|
void |
ReusingBuildFirstReOpenableHashJoinIterator.reopenProbe(MutableObjectIterator<V2> probeInput)
Set new input for probe side
|
Constructor and Description |
---|
NonReusingBuildFirstHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V2,V1> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
NonReusingBuildFirstHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V2,V1> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
NonReusingBuildFirstReOpenableHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V2,V1> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
NonReusingBuildFirstReOpenableHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V2,V1> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
NonReusingBuildSecondHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V1,V2> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
NonReusingBuildSecondHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V1,V2> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
NonReusingBuildSecondReOpenableHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V1,V2> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
NonReusingBuildSecondReOpenableHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V1,V2> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
ReusingBuildFirstHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V2,V1> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
ReusingBuildFirstHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V2,V1> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
ReusingBuildFirstReOpenableHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V2,V1> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
ReusingBuildFirstReOpenableHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V2,V1> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
ReusingBuildSecondHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V1,V2> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
ReusingBuildSecondHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V1,V2> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
ReusingBuildSecondReOpenableHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V1,V2> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
ReusingBuildSecondReOpenableHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V1,V2> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
Modifier and Type | Class and Description |
---|---|
class |
BlockResettableMutableObjectIterator<T>
Implementation of an iterator that fetches a block of data into main memory and offers resettable
access to the data in that block.
|
class |
SpillingResettableMutableObjectIterator<T>
Implementation of a resettable iterator.
|
Modifier and Type | Field and Description |
---|---|
protected MutableObjectIterator<T> |
SpillingResettableMutableObjectIterator.input |
Constructor and Description |
---|
BlockResettableMutableObjectIterator(MemoryManager memoryManager,
MutableObjectIterator<T> input,
TypeSerializer<T> serializer,
int numMemoryPages,
AbstractInvokable ownerTask) |
SpillingResettableMutableObjectIterator(MutableObjectIterator<T> input,
TypeSerializer<T> serializer,
MemoryManager memoryManager,
IOManager ioManager,
int numPages,
AbstractInvokable parentTask) |
SpillingResettableMutableObjectIterator(MutableObjectIterator<T> input,
TypeSerializer<T> serializer,
MemoryManager memoryManager,
IOManager ioManager,
List<MemorySegment> memory) |
Modifier and Type | Class and Description |
---|---|
class |
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.
|
Modifier and Type | Method and Description |
---|---|
MutableObjectIterator<T> |
LargeRecordHandler.finishWriteAndSortKeys(List<MemorySegment> memory) |
MutableObjectIterator<T> |
FixedLengthRecordSorter.getIterator()
Gets an iterator over all records in this buffer in their logical order.
|
MutableObjectIterator<E> |
ExternalSorter.getIterator() |
MutableObjectIterator<T> |
InMemorySorter.getIterator()
Gets an iterator over all records in this buffer in their logical order.
|
MutableObjectIterator<T> |
NormalizedKeySorter.getIterator()
Gets an iterator over all records in this buffer in their logical order.
|
Modifier and Type | Method and Description |
---|---|
ExternalSorter<T> |
ExternalSorterBuilder.build(MutableObjectIterator<T> input)
Creates a pull-based
Sorter . |
protected <T> KeyGroupedIterator<T> |
NonReusingMergeInnerJoinIterator.createKeyGroupedIterator(MutableObjectIterator<T> input,
TypeSerializer<T> serializer,
TypeComparator<T> comparator) |
protected abstract <T> KeyGroupedIterator<T> |
AbstractMergeIterator.createKeyGroupedIterator(MutableObjectIterator<T> input,
TypeSerializer<T> serializer,
TypeComparator<T> comparator) |
protected <T> KeyGroupedIterator<T> |
ReusingMergeOuterJoinIterator.createKeyGroupedIterator(MutableObjectIterator<T> input,
TypeSerializer<T> serializer,
TypeComparator<T> comparator) |
protected <T> KeyGroupedIterator<T> |
NonReusingMergeOuterJoinIterator.createKeyGroupedIterator(MutableObjectIterator<T> input,
TypeSerializer<T> serializer,
TypeComparator<T> comparator) |
protected <T> KeyGroupedIterator<T> |
ReusingMergeInnerJoinIterator.createKeyGroupedIterator(MutableObjectIterator<T> input,
TypeSerializer<T> serializer,
TypeComparator<T> comparator) |
void |
StageRunner.StageMessageDispatcher.sendResult(MutableObjectIterator<E> result)
Sends a result to the corresponding
Sorter . |
Constructor and Description |
---|
MergeIterator(List<MutableObjectIterator<E>> iterators,
TypeComparator<E> comparator) |
Modifier and Type | Class and Description |
---|---|
class |
ReaderIterator<T>
A
MutableObjectIterator that wraps a reader from an input channel and produces the
reader's records. |
Modifier and Type | Method and Description |
---|---|
MutableObjectIterator<E> |
SimpleCloseableInputProvider.getIterator() |
MutableObjectIterator<E> |
CloseableInputProvider.getIterator()
Gets the iterator over this input.
|
Constructor and Description |
---|
SimpleCloseableInputProvider(MutableObjectIterator<E> iterator)
Creates a new simple input provider that will return the given iterator.
|
Modifier and Type | Class and Description |
---|---|
class |
CountingMutableObjectIterator<IN> |
Constructor and Description |
---|
CountingMutableObjectIterator(MutableObjectIterator<IN> iterator,
Counter numRecordsIn) |
Modifier and Type | Interface and Description |
---|---|
interface |
ResettableMutableObjectIterator<E>
The resettable iterator is a specialization of the iterator, allowing to reset the iterator and
re-retrieve elements.
|
Modifier and Type | Class and Description |
---|---|
class |
EmptyMutableObjectIterator<E>
An empty mutable object iterator that never returns anything.
|
class |
RegularToMutableObjectIterator<T> |
Modifier and Type | Method and Description |
---|---|
static <E> MutableObjectIterator<E> |
EmptyMutableObjectIterator.get()
Gets a singleton instance of the empty iterator.
|
Constructor and Description |
---|
NonReusingKeyGroupedIterator(MutableObjectIterator<E> iterator,
TypeComparator<E> comparator)
Initializes the KeyGroupedIterator.
|
NonReusingMutableToRegularIteratorWrapper(MutableObjectIterator<T> source,
TypeSerializer<T> serializer) |
ReusingKeyGroupedIterator(MutableObjectIterator<E> iterator,
TypeSerializer<E> serializer,
TypeComparator<E> comparator)
Initializes the KeyGroupedIterator.
|
ReusingMutableToRegularIteratorWrapper(MutableObjectIterator<T> source,
TypeSerializer<T> serializer) |
Constructor and Description |
---|
WrappedRowIterator(MutableObjectIterator<T> iterator,
T reuse) |
Modifier and Type | Class and Description |
---|---|
class |
BinaryRowChannelInputViewIterator
A simple iterator over the input read though an I/O channel.
|
class |
LongHashPartitionChannelReaderInputViewIterator
A simple iterator over the input read though an I/O channel.
|
Modifier and Type | Class and Description |
---|---|
class |
BinaryMergeIterator<Entry>
Binary version of
MergeIterator . |
class |
ChannelReaderKVInputViewIterator<K,V>
Key-Value style channel reader input view iterator.
|
Modifier and Type | Method and Description |
---|---|
void |
BinaryExternalSorter.write(MutableObjectIterator<BinaryRowData> iterator) |
protected void |
BinaryExternalMerger.writeMergingOutput(MutableObjectIterator<BinaryRowData> mergeIterator,
AbstractPagedOutputView output) |
protected abstract void |
AbstractBinaryExternalMerger.writeMergingOutput(MutableObjectIterator<Entry> mergeIterator,
AbstractPagedOutputView output)
read the merged stream and write the data back.
|
protected void |
BinaryKVExternalMerger.writeMergingOutput(MutableObjectIterator<Tuple2<BinaryRowData,BinaryRowData>> mergeIterator,
AbstractPagedOutputView output) |
Constructor and Description |
---|
BinaryMergeIterator(List<MutableObjectIterator<Entry>> iterators,
List<Entry> reusableEntries,
Comparator<Entry> comparator) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.