Modifier and Type | Method and Description |
---|---|
protected byte[] |
AccumuloRowSerializer.getSerializedValue(ObjectInspector fieldObjectInspector,
Object value,
ByteStream.Output output,
ColumnMapping mapping)
Compute the serialized value from the given element and object inspectors.
|
byte[] |
DefaultAccumuloRowIdFactory.serializeRowId(Object object,
StructField field,
ByteStream.Output output) |
byte[] |
AccumuloRowIdFactory.serializeRowId(Object object,
StructField field,
ByteStream.Output output)
serialize hive object in internal format of custom key
|
protected void |
AccumuloRowSerializer.writeBinary(ByteStream.Output output,
Object value,
PrimitiveObjectInspector inspector) |
protected void |
AccumuloRowSerializer.writeSerializedPrimitive(PrimitiveObjectInspector objectInspector,
ByteStream.Output output,
Object value,
ColumnEncoding encoding)
Serialize the given primitive to the given output buffer, using the provided encoding
mechanism.
|
protected void |
AccumuloRowSerializer.writeString(ByteStream.Output output,
Object value,
PrimitiveObjectInspector inspector) |
protected void |
AccumuloRowSerializer.writeWithLevel(ObjectInspector oi,
Object value,
ByteStream.Output output,
ColumnMapping mapping,
int level)
Recursively serialize an Object using its
ObjectInspector , respecting the
separators defined by the LazySerDeParameters . |
Modifier and Type | Method and Description |
---|---|
static ByteStream.Output |
MapJoinKey.serializeRow(ByteStream.Output byteStream,
Object[] fieldData,
List<ObjectInspector> fieldOis,
boolean[] sortableSortOrders)
Serializes row to output.
|
static ByteStream.Output |
MapJoinKey.serializeVector(ByteStream.Output byteStream,
VectorHashKeyWrapper kw,
VectorExpressionWriter[] keyOutputWriters,
VectorHashKeyWrapperBatch keyWrapperBatch,
boolean[] nulls,
boolean[] sortableSortOrders)
Serializes row to output for vectorized path.
|
Modifier and Type | Method and Description |
---|---|
static MapJoinKey |
MapJoinKey.read(ByteStream.Output output,
MapJoinObjectSerDeContext context,
org.apache.hadoop.io.Writable writable) |
static MapJoinKey |
MapJoinKey.readFromRow(ByteStream.Output output,
MapJoinKey key,
Object[] keyObject,
List<ObjectInspector> keyFieldsOI,
boolean mayReuseKey) |
static MapJoinKey |
MapJoinKey.readFromVector(ByteStream.Output output,
MapJoinKey key,
Object[] keyObject,
List<ObjectInspector> keyOIs,
boolean mayReuseKey) |
static ByteStream.Output |
MapJoinKey.serializeRow(ByteStream.Output byteStream,
Object[] fieldData,
List<ObjectInspector> fieldOis,
boolean[] sortableSortOrders)
Serializes row to output.
|
static ByteStream.Output |
MapJoinKey.serializeVector(ByteStream.Output byteStream,
VectorHashKeyWrapper kw,
VectorExpressionWriter[] keyOutputWriters,
VectorHashKeyWrapperBatch keyWrapperBatch,
boolean[] nulls,
boolean[] sortableSortOrders)
Serializes row to output for vectorized path.
|
Modifier and Type | Method and Description |
---|---|
void |
VectorSerializeRowNoNulls.setOutput(ByteStream.Output output) |
void |
VectorSerializeRow.setOutput(ByteStream.Output output) |
void |
VectorSerializeRowNoNulls.setOutputAppend(ByteStream.Output output) |
void |
VectorSerializeRow.setOutputAppend(ByteStream.Output output) |
Modifier and Type | Method and Description |
---|---|
ByteStream.Output |
VectorMapJoinRowBytesContainer.getOuputForRowBytes() |
Modifier and Type | Field and Description |
---|---|
protected ByteStream.Output |
ByteStreamTypedSerDe.bos |
Modifier and Type | Method and Description |
---|---|
boolean |
ByteStream.Output.arraysEquals(ByteStream.Output output) |
protected void |
DelimitedJSONSerDe.serializeField(ByteStream.Output out,
Object obj,
ObjectInspector objInspector,
LazySerDeParameters serdeParams) |
Modifier and Type | Method and Description |
---|---|
static void |
BinarySortableSerDe.serializeBytes(ByteStream.Output buffer,
byte[] data,
int length,
boolean invert) |
static void |
BinarySortableSerDe.serializeBytes(ByteStream.Output buffer,
byte[] data,
int offset,
int length,
boolean invert) |
static void |
BinarySortableSerDe.serializeDouble(ByteStream.Output buffer,
double vd,
boolean invert) |
static void |
BinarySortableSerDe.serializeFloat(ByteStream.Output buffer,
float vf,
boolean invert) |
static void |
BinarySortableSerDe.serializeHiveDecimal(ByteStream.Output buffer,
HiveDecimal dec,
boolean invert) |
static void |
BinarySortableSerDe.serializeHiveIntervalDayTime(ByteStream.Output buffer,
HiveIntervalDayTime intervalDayTime,
boolean invert) |
static void |
BinarySortableSerDe.serializeHiveIntervalYearMonth(ByteStream.Output buffer,
HiveIntervalYearMonth intervalYearMonth,
boolean invert) |
static void |
BinarySortableSerDe.serializeInt(ByteStream.Output buffer,
int v,
boolean invert) |
static void |
BinarySortableSerDe.serializeLong(ByteStream.Output buffer,
long v,
boolean invert) |
static void |
BinarySortableSerDe.serializeShort(ByteStream.Output buffer,
short v,
boolean invert) |
static void |
BinarySortableSerDe.serializeStruct(ByteStream.Output byteStream,
Object[] fieldData,
List<ObjectInspector> fieldOis,
boolean[] sortableSortOrders) |
static void |
BinarySortableSerDe.serializeTimestampWritable(ByteStream.Output buffer,
TimestampWritable t,
boolean invert) |
Modifier and Type | Method and Description |
---|---|
void |
BinarySortableSerializeWrite.set(ByteStream.Output output) |
void |
BinarySortableSerializeWrite.setAppend(ByteStream.Output output) |
Modifier and Type | Field and Description |
---|---|
protected ByteStream.Output |
DynamicSerDe.bos_ |
Modifier and Type | Method and Description |
---|---|
void |
SerializeWrite.set(ByteStream.Output output) |
void |
SerializeWrite.setAppend(ByteStream.Output output) |
Modifier and Type | Method and Description |
---|---|
static void |
HiveDecimalWritable.writeToByteStream(Decimal128 dec,
ByteStream.Output byteStream) |
Modifier and Type | Method and Description |
---|---|
static void |
LazySimpleSerDe.serialize(ByteStream.Output out,
Object obj,
ObjectInspector objInspector,
byte[] separators,
int level,
org.apache.hadoop.io.Text nullSequence,
boolean escaped,
byte escapeChar,
boolean[] needsEscape)
Serialize the row into the StringBuilder.
|
protected void |
LazySimpleSerDe.serializeField(ByteStream.Output out,
Object obj,
ObjectInspector objInspector,
LazySerDeParameters serdeParams) |
Modifier and Type | Method and Description |
---|---|
void |
LazySimpleSerializeWrite.set(ByteStream.Output output) |
void |
LazySimpleSerializeWrite.setAppend(ByteStream.Output output) |
Modifier and Type | Method and Description |
---|---|
void |
LazyBinarySerializeWrite.set(ByteStream.Output output) |
void |
LazyBinarySerializeWrite.setAppend(ByteStream.Output output) |
Copyright © 2017 The Apache Software Foundation. All rights reserved.