Modifier and Type | Method and Description |
---|---|
MapData |
EnrichedRowData.getMap(int pos) |
Modifier and Type | Method and Description |
---|---|
MapData |
OrcMapColumnVector.getMap(int i) |
Modifier and Type | Class and Description |
---|---|
class |
GenericMapData
An internal data structure representing data of
MapType or MultisetType . |
Modifier and Type | Method and Description |
---|---|
MapData |
UpdatableRowData.getMap(int pos) |
MapData |
BoxedWrapperRowData.getMap(int pos) |
MapData |
RowData.getMap(int pos)
Returns the map value at the given position.
|
MapData |
GenericRowData.getMap(int pos) |
MapData |
GenericArrayData.getMap(int pos) |
MapData |
ArrayData.getMap(int pos)
Returns the map value at the given position.
|
Modifier and Type | Class and Description |
---|---|
class |
BinaryMapData
[4 byte(keyArray size in bytes)] + [Key BinaryArray] + [Value BinaryArray].
|
Modifier and Type | Method and Description |
---|---|
MapData |
NestedRowData.getMap(int pos) |
MapData |
BinaryArrayData.getMap(int pos) |
MapData |
BinaryRowData.getMap(int pos) |
static MapData |
BinarySegmentUtils.readMapData(MemorySegment[] segments,
int baseOffset,
long offsetAndSize)
Gets an instance of
MapData from underlying MemorySegment . |
Modifier and Type | Class and Description |
---|---|
class |
ColumnarMapData
Columnar map to support access to vector column data.
|
Modifier and Type | Method and Description |
---|---|
MapData |
ColumnarRowData.getMap(int pos) |
MapData |
ColumnarArrayData.getMap(int pos) |
Modifier and Type | Method and Description |
---|---|
MapData |
MapColumnVector.getMap(int i) |
MapData |
VectorizedColumnBatch.getMap(int rowId,
int colId) |
Modifier and Type | Method and Description |
---|---|
MapData |
HeapMapVector.getMap(int i) |
Modifier and Type | Method and Description |
---|---|
MapData |
MapMapConverter.toInternal(Map<K,V> external) |
Modifier and Type | Method and Description |
---|---|
Map<K,V> |
MapMapConverter.toExternal(MapData internal) |
Modifier and Type | Method and Description |
---|---|
static Map<Object,Object> |
MapDataUtil.convertToJavaMap(MapData map,
LogicalType keyType,
LogicalType valueType)
|
Modifier and Type | Method and Description |
---|---|
MapData |
JoinedRowData.getMap(int pos) |
MapData |
ProjectedRowData.getMap(int pos) |
Modifier and Type | Method and Description |
---|---|
void |
BinaryWriter.writeMap(int pos,
MapData value,
MapDataSerializer serializer) |
Modifier and Type | Method and Description |
---|---|
MapData |
ArrowMapColumnVector.getMap(int i) |
Modifier and Type | Method and Description |
---|---|
MapData |
CollectAggFunction.getValue(CollectAggFunction.CollectAccumulator<T> accumulator) |
Modifier and Type | Method and Description |
---|---|
MapData |
MapFromArraysFunction.eval(ArrayData keysArray,
ArrayData valuesArray) |
MapData |
MapUnionFunction.eval(MapData... maps) |
Modifier and Type | Method and Description |
---|---|
MapData |
MapUnionFunction.eval(MapData... maps) |
ArrayData |
MapEntriesFunction.eval(MapData input) |
ArrayData |
MapKeysFunction.eval(MapData input) |
ArrayData |
MapValuesFunction.eval(MapData input) |
Modifier and Type | Method and Description |
---|---|
void |
UnnestRowsFunction.CollectionUnnestTableFunction.eval(MapData mapData) |
void |
UnnestRowsFunction.MapUnnestTableFunction.eval(MapData mapData) |
Modifier and Type | Method and Description |
---|---|
MapData |
MapDataSerializer.copy(MapData from)
NOTE: Map should be a HashMap, when we insert the key/value pairs of the TreeMap into a
HashMap, problems maybe occur.
|
MapData |
MapDataSerializer.copy(MapData from,
MapData reuse) |
MapData |
MapDataSerializer.createInstance() |
MapData |
MapDataSerializer.deserialize(DataInputView source) |
MapData |
MapDataSerializer.deserialize(MapData reuse,
DataInputView source) |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<MapData> |
MapDataSerializer.duplicate() |
TypeSerializerSchemaCompatibility<MapData> |
MapDataSerializer.MapDataSerializerSnapshot.resolveSchemaCompatibility(TypeSerializerSnapshot<MapData> oldSerializerSnapshot) |
TypeSerializer<MapData> |
MapDataSerializer.MapDataSerializerSnapshot.restoreSerializer() |
TypeSerializerSnapshot<MapData> |
MapDataSerializer.snapshotConfiguration() |
Modifier and Type | Method and Description |
---|---|
MapData |
MapDataSerializer.copy(MapData from)
NOTE: Map should be a HashMap, when we insert the key/value pairs of the TreeMap into a
HashMap, problems maybe occur.
|
MapData |
MapDataSerializer.copy(MapData from,
MapData reuse) |
MapData |
MapDataSerializer.deserialize(MapData reuse,
DataInputView source) |
void |
MapDataSerializer.serialize(MapData record,
DataOutputView target) |
BinaryMapData |
MapDataSerializer.toBinaryMap(MapData from) |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<MapData> |
MapDataSerializer.MapDataSerializerSnapshot.resolveSchemaCompatibility(TypeSerializerSnapshot<MapData> oldSerializerSnapshot) |
Modifier and Type | Method and Description |
---|---|
MapData |
MapDataSerializer.deserialize(DataInputView source) |
MapData |
MapDataSerializer.deserialize(MapData reuse,
DataInputView source) |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<MapData> |
MapDataSerializer.duplicate() |
TypeSerializerSchemaCompatibility<MapData> |
MapDataSerializer.BaseMapSerializerSnapshot.resolveSchemaCompatibility(TypeSerializerSnapshot<MapData> oldSerializerSnapshot) |
TypeSerializer<MapData> |
MapDataSerializer.BaseMapSerializerSnapshot.restoreSerializer() |
TypeSerializerSnapshot<MapData> |
MapDataSerializer.snapshotConfiguration() |
Modifier and Type | Method and Description |
---|---|
MapData |
MapDataSerializer.deserialize(MapData reuse,
DataInputView source) |
void |
MapDataSerializer.serialize(MapData map,
DataOutputView target) |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<MapData> |
MapDataSerializer.BaseMapSerializerSnapshot.resolveSchemaCompatibility(TypeSerializerSnapshot<MapData> oldSerializerSnapshot) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.