public class AccumuloSerDe extends Object implements SerDe
| Constructor and Description |
|---|
AccumuloSerDe() |
| Modifier and Type | Method and Description |
|---|---|
Object |
deserialize(org.apache.hadoop.io.Writable writable)
Deserialize an object out of a Writable blob.
|
LazyAccumuloRow |
getCachedRow()
For testing purposes.
|
protected ArrayList<ObjectInspector> |
getColumnObjectInspectors(List<TypeInfo> columnTypes,
LazySerDeParameters serDeParams,
List<ColumnMapping> mappings,
AccumuloRowIdFactory factory) |
boolean |
getIteratorPushdown() |
ObjectInspector |
getObjectInspector()
Get the object inspector that can be used to navigate through the internal
structure of the Object returned from deserialize(...).
|
AccumuloSerDeParameters |
getParams() |
SerDeStats |
getSerDeStats()
Returns statistics collected when serializing
|
Class<? extends org.apache.hadoop.io.Writable> |
getSerializedClass()
Returns the Writable class that would be returned by the serialize method.
|
protected AccumuloRowSerializer |
getSerializer() |
void |
initialize(org.apache.hadoop.conf.Configuration conf,
Properties properties)
Initialize the HiveDeserializer.
|
org.apache.hadoop.io.Writable |
serialize(Object o,
ObjectInspector objectInspector)
Serialize an object by navigating inside the Object with the
ObjectInspector.
|
public void initialize(org.apache.hadoop.conf.Configuration conf,
Properties properties)
throws SerDeException
Deserializerinitialize in interface Deserializerinitialize in interface Serializerconf - System propertiesproperties - table propertiesSerDeExceptionprotected ArrayList<ObjectInspector> getColumnObjectInspectors(List<TypeInfo> columnTypes, LazySerDeParameters serDeParams, List<ColumnMapping> mappings, AccumuloRowIdFactory factory) throws SerDeException
SerDeExceptionpublic LazyAccumuloRow getCachedRow()
public Class<? extends org.apache.hadoop.io.Writable> getSerializedClass()
SerializergetSerializedClass in interface Serializerpublic org.apache.hadoop.io.Writable serialize(Object o, ObjectInspector objectInspector) throws SerDeException
Serializerserialize in interface SerializerSerDeExceptionpublic Object deserialize(org.apache.hadoop.io.Writable writable) throws SerDeException
Deserializerdeserialize in interface Deserializerwritable - The Writable object containing a serialized objectSerDeExceptionpublic ObjectInspector getObjectInspector() throws SerDeException
DeserializergetObjectInspector in interface DeserializerSerDeExceptionpublic SerDeStats getSerDeStats()
DeserializergetSerDeStats in interface DeserializergetSerDeStats in interface Serializerpublic AccumuloSerDeParameters getParams()
public boolean getIteratorPushdown()
protected AccumuloRowSerializer getSerializer()
Copyright © 2017 The Apache Software Foundation. All rights reserved.