public final class VectorDeserializeRow<T extends DeserializeRead> extends Object
| Modifier and Type | Field and Description |
|---|---|
protected org.apache.hadoop.hive.common.type.DataTypePhysicalVariation[] |
dataTypePhysicalVariations |
| Constructor and Description |
|---|
VectorDeserializeRow(T deserializeRead) |
| Modifier and Type | Method and Description |
|---|---|
void |
deserialize(org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch batch,
int batchIndex)
Deserialize a row from the range of bytes specified by setBytes.
|
void |
deserializeByRef(org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch batch,
int batchIndex)
Deserialize a row from the range of bytes specified by setBytes.
|
String |
getDetailedReadPositionString() |
void |
init() |
void |
init(boolean[] columnsToIncludeTruncated) |
void |
init(int startColumn) |
void |
init(int[] outputColumns) |
void |
init(List<Integer> outputColumns) |
void |
initConversion(TypeInfo[] targetTypeInfos,
boolean[] columnsToIncludeTruncated)
Initialize for converting the source data type that are going to be read with the
DeserializedRead interface passed to the constructor to the target data types desired in
the VectorizedRowBatch.
|
void |
setBytes(byte[] bytes,
int offset,
int length)
Specify the range of bytes to deserialize in the next call to the deserialize method.
|
protected org.apache.hadoop.hive.common.type.DataTypePhysicalVariation[] dataTypePhysicalVariations
public VectorDeserializeRow(T deserializeRead)
deserializeRead - Set useExternalBuffer to true to avoid buffer copying and to get
more efficient reading.public void init(int[] outputColumns)
throws HiveException
HiveExceptionpublic void init(List<Integer> outputColumns) throws HiveException
HiveExceptionpublic void init(int startColumn)
throws HiveException
HiveExceptionpublic void init(boolean[] columnsToIncludeTruncated)
throws HiveException
HiveExceptionpublic void initConversion(TypeInfo[] targetTypeInfos, boolean[] columnsToIncludeTruncated) throws HiveException
targetTypeInfos - columnsToIncludeTruncated - HiveExceptionpublic void init()
throws HiveException
HiveExceptionpublic void setBytes(byte[] bytes,
int offset,
int length)
bytes - offset - length - public void deserialize(org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch batch,
int batchIndex)
throws IOException
batch - batchIndex - IOExceptionpublic void deserializeByRef(org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch batch,
int batchIndex)
throws IOException
batch - batchIndex - IOExceptionpublic String getDetailedReadPositionString()
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.