Modifier and Type | Field and Description |
---|---|
static BinaryRowData |
BinaryRowDataUtil.EMPTY_ROW |
Modifier and Type | Method and Description |
---|---|
BinaryRowData |
BinaryRowData.copy() |
BinaryRowData |
BinaryRowData.copy(BinaryRowData reuse) |
Modifier and Type | Method and Description |
---|---|
BinaryRowData |
BinaryRowData.copy(BinaryRowData reuse) |
Constructor and Description |
---|
BinaryRowWriter(BinaryRowData row) |
BinaryRowWriter(BinaryRowData row,
int initialSize) |
Modifier and Type | Method and Description |
---|---|
BinaryRowData |
LongHashPartition.MatchIterator.getRow() |
BinaryRowData |
BuildSideIterator.getRow() |
BinaryRowData |
BuildSideIterator.BucketIterator.getRow() |
BinaryRowData |
LookupBucketIterator.getRow() |
BinaryRowData |
ProbeIterator.next() |
abstract BinaryRowData |
LongHybridHashTable.probeToBinary(RowData row)
For code gen probe side to BinaryRowData.
|
Modifier and Type | Method and Description |
---|---|
RowIterator<BinaryRowData> |
LongHybridHashTable.get(long probeKey)
This method is only used for operator fusion codegen to get build row from hash table.
|
RowIterator<BinaryRowData> |
BinaryHashTable.getBuildSideIterator() |
Modifier and Type | Method and Description |
---|---|
static void |
LongHashPartition.deserializeFromPages(BinaryRowData reuse,
ChannelReaderInputView inView,
BinaryRowDataSerializer buildSideSerializer) |
void |
LongHybridHashTable.putBuildRow(BinaryRowData row) |
void |
LongHashPartition.serializeToPages(BinaryRowData row) |
void |
ProbeIterator.setReuse(BinaryRowData reuse) |
Modifier and Type | Method and Description |
---|---|
void |
ProbeIterator.set(ChannelReaderInputViewIterator<BinaryRowData> source) |
Constructor and Description |
---|
ProbeIterator(BinaryRowData instance) |
Constructor and Description |
---|
BinaryHashTable(Object owner,
boolean compressionEnabled,
int compressionBlockSize,
AbstractRowDataSerializer buildSideSerializer,
AbstractRowDataSerializer probeSideSerializer,
Projection<RowData,BinaryRowData> buildSideProjection,
Projection<RowData,BinaryRowData> probeSideProjection,
MemoryManager memManager,
long reservedMemorySize,
IOManager ioManager,
int avgRecordLen,
long buildRowCount,
boolean useBloomFilters,
HashJoinType type,
JoinCondition condFunc,
boolean reverseJoin,
boolean[] filterNulls,
boolean tryDistinctBuildRow) |
BinaryHashTable(Object owner,
boolean compressionEnabled,
int compressionBlockSize,
AbstractRowDataSerializer buildSideSerializer,
AbstractRowDataSerializer probeSideSerializer,
Projection<RowData,BinaryRowData> buildSideProjection,
Projection<RowData,BinaryRowData> probeSideProjection,
MemoryManager memManager,
long reservedMemorySize,
IOManager ioManager,
int avgRecordLen,
long buildRowCount,
boolean useBloomFilters,
HashJoinType type,
JoinCondition condFunc,
boolean reverseJoin,
boolean[] filterNulls,
boolean tryDistinctBuildRow) |
Modifier and Type | Method and Description |
---|---|
BinaryRowData |
BinaryRowChannelInputViewIterator.next() |
BinaryRowData |
BinaryRowChannelInputViewIterator.next(BinaryRowData reuse) |
BinaryRowData |
LongHashPartitionChannelReaderInputViewIterator.next(BinaryRowData reuse) |
Modifier and Type | Method and Description |
---|---|
BinaryRowData |
BinaryRowChannelInputViewIterator.next(BinaryRowData reuse) |
BinaryRowData |
LongHashPartitionChannelReaderInputViewIterator.next(BinaryRowData reuse) |
Modifier and Type | Field and Description |
---|---|
protected BinaryRowData |
SortMergeJoinIterator.bufferedKey |
protected BinaryRowData |
SortMergeJoinIterator.bufferedRow |
protected BinaryRowData |
SortMergeJoinIterator.matchKey |
protected BinaryRowData |
SortMergeJoinIterator.probeKey |
Modifier and Type | Method and Description |
---|---|
BinaryRowData |
SortMergeFullOuterJoinIterator.getMatchKey() |
BinaryRowData |
SortMergeJoinIterator.getMatchKey() |
Modifier and Type | Method and Description |
---|---|
static boolean |
NullAwareJoinHelper.shouldFilter(boolean nullSafe,
boolean filterAllNulls,
int[] nullFilterKeys,
BinaryRowData key) |
Modifier and Type | Method and Description |
---|---|
abstract void |
HashJoinOperator.join(RowIterator<BinaryRowData> buildIter,
RowData probeRow) |
Modifier and Type | Method and Description |
---|---|
static BinaryRowData |
OverWindowFrame.getNextOrNull(ResettableExternalBuffer.BufferIterator iterator)
Get next row from iterator.
|
Modifier and Type | Field and Description |
---|---|
protected BinaryRowData |
BinaryIndexedSortable.row1 |
Modifier and Type | Method and Description |
---|---|
void |
BinaryExternalSorter.write(MutableObjectIterator<BinaryRowData> iterator) |
protected void |
BinaryExternalMerger.writeMergingOutput(MutableObjectIterator<BinaryRowData> mergeIterator,
AbstractPagedOutputView output) |
protected void |
BinaryKVExternalMerger.writeMergingOutput(MutableObjectIterator<Tuple2<BinaryRowData,BinaryRowData>> mergeIterator,
AbstractPagedOutputView output) |
protected void |
BinaryKVExternalMerger.writeMergingOutput(MutableObjectIterator<Tuple2<BinaryRowData,BinaryRowData>> mergeIterator,
AbstractPagedOutputView output) |
Modifier and Type | Method and Description |
---|---|
RowIterator<BinaryRowData> |
WindowsGrouping.buildTriggerWindowElementsIterator() |
protected abstract RowIterator<BinaryRowData> |
WindowsGrouping.newBufferIterator(int startIndex) |
protected RowIterator<BinaryRowData> |
HeapWindowsGrouping.newBufferIterator(int startIndex) |
Modifier and Type | Method and Description |
---|---|
void |
WindowsGrouping.addInputToBuffer(BinaryRowData input) |
protected abstract void |
WindowsGrouping.addIntoBuffer(BinaryRowData input) |
protected void |
HeapWindowsGrouping.addIntoBuffer(BinaryRowData input) |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<BinaryRowData> |
BinaryRowDataSerializer.duplicate() |
TypeSerializerSchemaCompatibility<BinaryRowData> |
BinaryRowDataSerializer.BinaryRowDataSerializerSnapshot.resolveSchemaCompatibility(TypeSerializerSnapshot<BinaryRowData> oldSerializerSnapshot) |
TypeSerializer<BinaryRowData> |
BinaryRowDataSerializer.BinaryRowDataSerializerSnapshot.restoreSerializer() |
TypeSerializerSnapshot<BinaryRowData> |
BinaryRowDataSerializer.snapshotConfiguration() |
Modifier and Type | Method and Description |
---|---|
BinaryRowData |
BinaryRowDataSerializer.copy(BinaryRowData from) |
BinaryRowData |
BinaryRowDataSerializer.copy(BinaryRowData from,
BinaryRowData reuse) |
BinaryRowData |
BinaryRowDataSerializer.deserialize(BinaryRowData reuse,
DataInputView source) |
BinaryRowData |
BinaryRowDataSerializer.deserializeFromPages(BinaryRowData reuse,
AbstractPagedInputView headerLessView) |
BinaryRowData |
BinaryRowDataSerializer.mapFromPages(BinaryRowData reuse,
AbstractPagedInputView headerLessView) |
void |
BinaryRowDataSerializer.pointTo(int length,
BinaryRowData reuse,
AbstractPagedInputView headerLessView)
Point row to memory segments with offset(in the AbstractPagedInputView) and length.
|
void |
BinaryRowDataSerializer.serialize(BinaryRowData record,
DataOutputView target) |
int |
BinaryRowDataSerializer.serializeToPages(BinaryRowData record,
AbstractPagedOutputView headerLessView) |
static void |
BinaryRowDataSerializer.serializeWithoutLengthSlow(BinaryRowData record,
MemorySegmentWritable out) |
BinaryRowData |
BinaryRowDataSerializer.toBinaryRow(BinaryRowData rowData) |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<BinaryRowData> |
BinaryRowDataSerializer.BinaryRowDataSerializerSnapshot.resolveSchemaCompatibility(TypeSerializerSnapshot<BinaryRowData> oldSerializerSnapshot) |
Modifier and Type | Method and Description |
---|---|
BinaryRowData |
ResettableExternalBuffer.BufferIterator.getRow() |
Modifier and Type | Method and Description |
---|---|
BinaryRowData |
AbstractBytesHashMap.append(BytesMap.LookupInfo<K,BinaryRowData> lookupInfo,
BinaryRowData value)
Append an value into the hash map's record area.
|
Modifier and Type | Method and Description |
---|---|
KeyValueIterator<K,BinaryRowData> |
AbstractBytesHashMap.getEntryIterator(boolean requiresCopy)
Returns an iterator for iterating over the entries of this map.
|
Modifier and Type | Method and Description |
---|---|
BinaryRowData |
AbstractBytesHashMap.append(BytesMap.LookupInfo<K,BinaryRowData> lookupInfo,
BinaryRowData value)
Append an value into the hash map's record area.
|
void |
AbstractBytesMultiMap.append(BytesMap.LookupInfo<K,Iterator<RowData>> lookupInfo,
BinaryRowData value)
Append an value into the hash map's record area.
|
Modifier and Type | Method and Description |
---|---|
BinaryRowData |
AbstractBytesHashMap.append(BytesMap.LookupInfo<K,BinaryRowData> lookupInfo,
BinaryRowData value)
Append an value into the hash map's record area.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.