Uses of Class
org.apache.flink.table.data.binary.BinaryRowData
-
-
Uses of BinaryRowData in org.apache.flink.table.data.binary
Fields in org.apache.flink.table.data.binary declared as BinaryRowData Modifier and Type Field Description static BinaryRowData
BinaryRowDataUtil. EMPTY_ROW
Methods in org.apache.flink.table.data.binary that return BinaryRowData Modifier and Type Method Description BinaryRowData
BinaryRowData. copy()
BinaryRowData
BinaryRowData. copy(BinaryRowData reuse)
Methods in org.apache.flink.table.data.binary with parameters of type BinaryRowData Modifier and Type Method Description BinaryRowData
BinaryRowData. copy(BinaryRowData reuse)
-
Uses of BinaryRowData in org.apache.flink.table.data.writer
Constructors in org.apache.flink.table.data.writer with parameters of type BinaryRowData Constructor Description BinaryRowWriter(BinaryRowData row)
BinaryRowWriter(BinaryRowData row, int initialSize)
-
Uses of BinaryRowData in org.apache.flink.table.runtime.hashtable
Methods in org.apache.flink.table.runtime.hashtable that return BinaryRowData Modifier and Type Method Description BinaryRowData
BuildSideIterator.BucketIterator. getRow()
BinaryRowData
BuildSideIterator. getRow()
BinaryRowData
LongHashPartition.MatchIterator. getRow()
BinaryRowData
LookupBucketIterator. getRow()
BinaryRowData
ProbeIterator. next()
abstract BinaryRowData
LongHybridHashTable. probeToBinary(RowData row)
For code gen probe side to BinaryRowData.Methods in org.apache.flink.table.runtime.hashtable that return types with arguments of type BinaryRowData Modifier and Type Method 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()
Methods in org.apache.flink.table.runtime.hashtable with parameters of type BinaryRowData Modifier and Type Method 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)
Method parameters in org.apache.flink.table.runtime.hashtable with type arguments of type BinaryRowData Modifier and Type Method Description void
ProbeIterator. set(ChannelReaderInputViewIterator<BinaryRowData> source)
Constructors in org.apache.flink.table.runtime.hashtable with parameters of type BinaryRowData Constructor Description ProbeIterator(BinaryRowData instance)
Constructor parameters in org.apache.flink.table.runtime.hashtable with type arguments of type BinaryRowData Constructor 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)
-
Uses of BinaryRowData in org.apache.flink.table.runtime.io
Methods in org.apache.flink.table.runtime.io that return BinaryRowData Modifier and Type Method Description BinaryRowData
BinaryRowChannelInputViewIterator. next()
BinaryRowData
BinaryRowChannelInputViewIterator. next(BinaryRowData reuse)
BinaryRowData
LongHashPartitionChannelReaderInputViewIterator. next(BinaryRowData reuse)
Methods in org.apache.flink.table.runtime.io with parameters of type BinaryRowData Modifier and Type Method Description BinaryRowData
BinaryRowChannelInputViewIterator. next(BinaryRowData reuse)
BinaryRowData
LongHashPartitionChannelReaderInputViewIterator. next(BinaryRowData reuse)
-
Uses of BinaryRowData in org.apache.flink.table.runtime.operators.join
Fields in org.apache.flink.table.runtime.operators.join declared as BinaryRowData Modifier and Type Field Description protected BinaryRowData
SortMergeJoinIterator. bufferedKey
protected BinaryRowData
SortMergeJoinIterator. bufferedRow
protected BinaryRowData
SortMergeJoinIterator. matchKey
protected BinaryRowData
SortMergeJoinIterator. probeKey
Methods in org.apache.flink.table.runtime.operators.join that return BinaryRowData Modifier and Type Method Description BinaryRowData
SortMergeFullOuterJoinIterator. getMatchKey()
BinaryRowData
SortMergeJoinIterator. getMatchKey()
Methods in org.apache.flink.table.runtime.operators.join with parameters of type BinaryRowData Modifier and Type Method Description static boolean
NullAwareJoinHelper. shouldFilter(boolean nullSafe, boolean filterAllNulls, int[] nullFilterKeys, BinaryRowData key)
Method parameters in org.apache.flink.table.runtime.operators.join with type arguments of type BinaryRowData Modifier and Type Method Description abstract void
HashJoinOperator. join(RowIterator<BinaryRowData> buildIter, RowData probeRow)
-
Uses of BinaryRowData in org.apache.flink.table.runtime.operators.over.frame
Methods in org.apache.flink.table.runtime.operators.over.frame that return BinaryRowData Modifier and Type Method Description static BinaryRowData
OverWindowFrame. getNextOrNull(ResettableExternalBuffer.BufferIterator iterator)
Get next row from iterator. -
Uses of BinaryRowData in org.apache.flink.table.runtime.operators.sort
Fields in org.apache.flink.table.runtime.operators.sort declared as BinaryRowData Modifier and Type Field Description protected BinaryRowData
BinaryIndexedSortable. row1
Method parameters in org.apache.flink.table.runtime.operators.sort with type arguments of type BinaryRowData Modifier and Type Method 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)
-
Uses of BinaryRowData in org.apache.flink.table.runtime.operators.window.grouping
Methods in org.apache.flink.table.runtime.operators.window.grouping that return types with arguments of type BinaryRowData Modifier and Type Method Description RowIterator<BinaryRowData>
WindowsGrouping. buildTriggerWindowElementsIterator()
protected RowIterator<BinaryRowData>
HeapWindowsGrouping. newBufferIterator(int startIndex)
protected abstract RowIterator<BinaryRowData>
WindowsGrouping. newBufferIterator(int startIndex)
Methods in org.apache.flink.table.runtime.operators.window.grouping with parameters of type BinaryRowData Modifier and Type Method Description void
WindowsGrouping. addInputToBuffer(BinaryRowData input)
protected void
HeapWindowsGrouping. addIntoBuffer(BinaryRowData input)
protected abstract void
WindowsGrouping. addIntoBuffer(BinaryRowData input)
-
Uses of BinaryRowData in org.apache.flink.table.runtime.typeutils
Methods in org.apache.flink.table.runtime.typeutils that return types with arguments of type BinaryRowData Modifier and Type Method Description TypeSerializer<BinaryRowData>
BinaryRowDataSerializer. duplicate()
TypeSerializerSchemaCompatibility<BinaryRowData>
BinaryRowDataSerializer.BinaryRowDataSerializerSnapshot. resolveSchemaCompatibility(TypeSerializerSnapshot<BinaryRowData> oldSerializerSnapshot)
TypeSerializer<BinaryRowData>
BinaryRowDataSerializer.BinaryRowDataSerializerSnapshot. restoreSerializer()
TypeSerializerSnapshot<BinaryRowData>
BinaryRowDataSerializer. snapshotConfiguration()
Methods in org.apache.flink.table.runtime.typeutils with parameters of type BinaryRowData Modifier and Type Method 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)
Method parameters in org.apache.flink.table.runtime.typeutils with type arguments of type BinaryRowData Modifier and Type Method Description TypeSerializerSchemaCompatibility<BinaryRowData>
BinaryRowDataSerializer.BinaryRowDataSerializerSnapshot. resolveSchemaCompatibility(TypeSerializerSnapshot<BinaryRowData> oldSerializerSnapshot)
-
Uses of BinaryRowData in org.apache.flink.table.runtime.util
Methods in org.apache.flink.table.runtime.util that return BinaryRowData Modifier and Type Method Description BinaryRowData
ResettableExternalBuffer.BufferIterator. getRow()
-
Uses of BinaryRowData in org.apache.flink.table.runtime.util.collections.binary
Methods in org.apache.flink.table.runtime.util.collections.binary that return BinaryRowData Modifier and Type Method Description BinaryRowData
AbstractBytesHashMap. append(BytesMap.LookupInfo<K,BinaryRowData> lookupInfo, BinaryRowData value)
Append an value into the hash map's record area.Methods in org.apache.flink.table.runtime.util.collections.binary that return types with arguments of type BinaryRowData Modifier and Type Method Description KeyValueIterator<K,BinaryRowData>
AbstractBytesHashMap. getEntryIterator(boolean requiresCopy)
Returns an iterator for iterating over the entries of this map.Methods in org.apache.flink.table.runtime.util.collections.binary with parameters of type BinaryRowData Modifier and Type Method 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.Method parameters in org.apache.flink.table.runtime.util.collections.binary with type arguments of type BinaryRowData Modifier and Type Method Description BinaryRowData
AbstractBytesHashMap. append(BytesMap.LookupInfo<K,BinaryRowData> lookupInfo, BinaryRowData value)
Append an value into the hash map's record area.
-