public final class LazySimpleSerializeWrite extends Object implements SerializeWrite
| Modifier and Type | Field and Description |
|---|---|
static org.slf4j.Logger |
LOG |
| Constructor and Description |
|---|
LazySimpleSerializeWrite(int fieldCount,
LazySerDeParameters lazyParams) |
| 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 v) |
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 v) |
public LazySimpleSerializeWrite(int fieldCount,
LazySerDeParameters lazyParams)
public void set(ByteStream.Output output)
set in interface SerializeWritepublic void setAppend(ByteStream.Output output)
setAppend in interface SerializeWritepublic void reset()
reset in interface SerializeWritepublic void writeNull()
throws IOException
writeNull in interface SerializeWriteIOExceptionpublic void writeBoolean(boolean v)
throws IOException
writeBoolean in interface SerializeWriteIOExceptionpublic void writeByte(byte v)
throws IOException
writeByte in interface SerializeWriteIOExceptionpublic void writeShort(short v)
throws IOException
writeShort in interface SerializeWriteIOExceptionpublic void writeInt(int v)
throws IOException
writeInt in interface SerializeWriteIOExceptionpublic void writeLong(long v)
throws IOException
writeLong in interface SerializeWriteIOExceptionpublic void writeFloat(float vf)
throws IOException
writeFloat in interface SerializeWriteIOExceptionpublic void writeDouble(double v)
throws IOException
writeDouble in interface SerializeWriteIOExceptionpublic void writeString(byte[] v)
throws IOException
writeString in interface SerializeWriteIOExceptionpublic void writeString(byte[] v,
int start,
int length)
throws IOException
writeString in interface SerializeWriteIOExceptionpublic void writeHiveChar(HiveChar hiveChar) throws IOException
writeHiveChar in interface SerializeWriteIOExceptionpublic void writeHiveVarchar(HiveVarchar hiveVarchar) throws IOException
writeHiveVarchar in interface SerializeWriteIOExceptionpublic void writeBinary(byte[] v)
throws IOException
writeBinary in interface SerializeWriteIOExceptionpublic void writeBinary(byte[] v,
int start,
int length)
throws IOException
writeBinary in interface SerializeWriteIOExceptionpublic void writeDate(Date date) throws IOException
writeDate in interface SerializeWriteIOExceptionpublic void writeDate(int dateAsDays)
throws IOException
writeDate in interface SerializeWriteIOExceptionpublic void writeTimestamp(Timestamp v) throws IOException
writeTimestamp in interface SerializeWriteIOExceptionpublic void writeHiveIntervalYearMonth(HiveIntervalYearMonth viyt) throws IOException
writeHiveIntervalYearMonth in interface SerializeWriteIOExceptionpublic void writeHiveIntervalYearMonth(int totalMonths)
throws IOException
writeHiveIntervalYearMonth in interface SerializeWriteIOExceptionpublic void writeHiveIntervalDayTime(org.apache.hadoop.hive.common.type.HiveIntervalDayTime vidt)
throws IOException
writeHiveIntervalDayTime in interface SerializeWriteIOExceptionpublic void writeDecimal64(long decimal64Long,
int scale)
throws IOException
writeDecimal64 in interface SerializeWriteIOExceptionpublic void writeHiveDecimal(org.apache.hadoop.hive.common.type.HiveDecimal dec,
int scale)
throws IOException
writeHiveDecimal in interface SerializeWriteIOExceptionpublic void writeHiveDecimal(org.apache.hadoop.hive.serde2.io.HiveDecimalWritable decWritable,
int scale)
throws IOException
writeHiveDecimal in interface SerializeWriteIOExceptionpublic void beginList(List list)
beginList in interface SerializeWritepublic void separateList()
separateList in interface SerializeWritepublic void finishList()
finishList in interface SerializeWritepublic void beginMap(Map<?,?> map)
beginMap in interface SerializeWritepublic void separateKey()
separateKey in interface SerializeWritepublic void separateKeyValuePair()
separateKeyValuePair in interface SerializeWritepublic void finishMap()
finishMap in interface SerializeWritepublic void beginStruct(List fieldValues)
beginStruct in interface SerializeWritepublic void separateStruct()
separateStruct in interface SerializeWritepublic void finishStruct()
finishStruct in interface SerializeWritepublic void beginUnion(int tag)
throws IOException
beginUnion in interface SerializeWriteIOExceptionpublic void finishUnion()
finishUnion in interface SerializeWriteCopyright © 2019 The Apache Software Foundation. All Rights Reserved.