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
Deserializer
initialize
in interface Deserializer
initialize
in interface Serializer
conf
- System propertiesproperties
- table propertiesSerDeException
protected ArrayList<ObjectInspector> getColumnObjectInspectors(List<TypeInfo> columnTypes, LazySerDeParameters serDeParams, List<ColumnMapping> mappings, AccumuloRowIdFactory factory) throws SerDeException
SerDeException
public LazyAccumuloRow getCachedRow()
public Class<? extends org.apache.hadoop.io.Writable> getSerializedClass()
Serializer
getSerializedClass
in interface Serializer
public org.apache.hadoop.io.Writable serialize(Object o, ObjectInspector objectInspector) throws SerDeException
Serializer
serialize
in interface Serializer
SerDeException
public Object deserialize(org.apache.hadoop.io.Writable writable) throws SerDeException
Deserializer
deserialize
in interface Deserializer
writable
- The Writable object containing a serialized objectSerDeException
public ObjectInspector getObjectInspector() throws SerDeException
Deserializer
getObjectInspector
in interface Deserializer
SerDeException
public SerDeStats getSerDeStats()
Deserializer
getSerDeStats
in interface Deserializer
getSerDeStats
in interface Serializer
public AccumuloSerDeParameters getParams()
public boolean getIteratorPushdown()
protected AccumuloRowSerializer getSerializer()
Copyright © 2017 The Apache Software Foundation. All rights reserved.