public interface SerializeWrite
| Modifier and Type | Method and Description |
|---|---|
void |
beginList(List list) |
void |
beginMap(Map<?,?> map) |
void |
beginStruct(List fieldValues) |
void |
beginUnion(int tag) |
void |
finishList() |
void |
finishMap() |
void |
finishStruct() |
void |
finishUnion() |
void |
reset() |
void |
separateKey() |
void |
separateKeyValuePair() |
void |
separateList() |
void |
separateStruct() |
void |
set(ByteStream.Output output) |
void |
setAppend(ByteStream.Output output) |
void |
writeBinary(byte[] v) |
void |
writeBinary(byte[] v,
int start,
int length) |
void |
writeBoolean(boolean v) |
void |
writeByte(byte v) |
void |
writeDate(Date date) |
void |
writeDate(int dateAsDays) |
void |
writeDecimal64(long decimal64Long,
int scale) |
void |
writeDouble(double vd) |
void |
writeFloat(float vf) |
void |
writeHiveChar(HiveChar hiveChar) |
void |
writeHiveDecimal(org.apache.hadoop.hive.common.type.HiveDecimal dec,
int scale) |
void |
writeHiveDecimal(org.apache.hadoop.hive.serde2.io.HiveDecimalWritable decWritable,
int scale) |
void |
writeHiveIntervalDayTime(org.apache.hadoop.hive.common.type.HiveIntervalDayTime vidt) |
void |
writeHiveIntervalYearMonth(HiveIntervalYearMonth viyt) |
void |
writeHiveIntervalYearMonth(int totalMonths) |
void |
writeHiveVarchar(HiveVarchar hiveVarchar) |
void |
writeInt(int v) |
void |
writeLong(long v) |
void |
writeNull() |
void |
writeShort(short v) |
void |
writeString(byte[] v) |
void |
writeString(byte[] v,
int start,
int length) |
void |
writeTimestamp(Timestamp vt) |
void set(ByteStream.Output output)
void setAppend(ByteStream.Output output)
void reset()
void writeNull()
throws IOException
IOExceptionvoid writeBoolean(boolean v)
throws IOException
IOExceptionvoid writeByte(byte v)
throws IOException
IOExceptionvoid writeShort(short v)
throws IOException
IOExceptionvoid writeInt(int v)
throws IOException
IOExceptionvoid writeLong(long v)
throws IOException
IOExceptionvoid writeFloat(float vf)
throws IOException
IOExceptionvoid writeDouble(double vd)
throws IOException
IOExceptionvoid writeString(byte[] v)
throws IOException
IOExceptionvoid writeString(byte[] v,
int start,
int length)
throws IOException
IOExceptionvoid writeHiveChar(HiveChar hiveChar) throws IOException
IOExceptionvoid writeHiveVarchar(HiveVarchar hiveVarchar) throws IOException
IOExceptionvoid writeBinary(byte[] v)
throws IOException
IOExceptionvoid writeBinary(byte[] v,
int start,
int length)
throws IOException
IOExceptionvoid writeDate(Date date) throws IOException
IOExceptionvoid writeDate(int dateAsDays)
throws IOException
IOExceptionvoid writeTimestamp(Timestamp vt) throws IOException
IOExceptionvoid writeHiveIntervalYearMonth(HiveIntervalYearMonth viyt) throws IOException
IOExceptionvoid writeHiveIntervalYearMonth(int totalMonths)
throws IOException
IOExceptionvoid writeHiveIntervalDayTime(org.apache.hadoop.hive.common.type.HiveIntervalDayTime vidt)
throws IOException
IOExceptionvoid writeDecimal64(long decimal64Long,
int scale)
throws IOException
IOExceptionvoid writeHiveDecimal(org.apache.hadoop.hive.common.type.HiveDecimal dec,
int scale)
throws IOException
IOExceptionvoid writeHiveDecimal(org.apache.hadoop.hive.serde2.io.HiveDecimalWritable decWritable,
int scale)
throws IOException
IOExceptionvoid beginList(List list)
void separateList()
void finishList()
void beginMap(Map<?,?> map)
void separateKey()
void separateKeyValuePair()
void finishMap()
void beginStruct(List fieldValues)
void separateStruct()
void finishStruct()
void beginUnion(int tag)
throws IOException
IOExceptionvoid finishUnion()
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.