public class DefaultAccumuloRowIdFactory extends Object implements AccumuloRowIdFactory
AccumuloRowSerializer methods to serialize the field for storage into Accumulo.| Modifier and Type | Field and Description |
|---|---|
protected AccumuloSerDeParameters |
accumuloSerDeParams |
protected Properties |
properties |
protected HiveAccumuloRowIdColumnMapping |
rowIdMapping |
protected LazySerDeParameters |
serdeParams |
protected AccumuloRowSerializer |
serializer |
| Constructor and Description |
|---|
DefaultAccumuloRowIdFactory() |
| Modifier and Type | Method and Description |
|---|---|
void |
addDependencyJars(org.apache.hadoop.conf.Configuration conf)
Add this implementation to the classpath for the Job
|
LazyObjectBase |
createRowId(ObjectInspector inspector)
create custom object for accumulo
|
ObjectInspector |
createRowIdObjectInspector(TypeInfo type)
create custom object inspector for accumulo rowId
|
void |
init(AccumuloSerDeParameters accumuloSerDeParams,
Properties properties)
initialize factory with properties
|
byte[] |
serializeRowId(Object object,
StructField field,
ByteStream.Output output)
serialize hive object in internal format of custom key
|
protected AccumuloSerDeParameters accumuloSerDeParams
protected LazySerDeParameters serdeParams
protected Properties properties
protected HiveAccumuloRowIdColumnMapping rowIdMapping
protected AccumuloRowSerializer serializer
public void init(AccumuloSerDeParameters accumuloSerDeParams, Properties properties) throws SerDeException
AccumuloRowIdFactoryinit in interface AccumuloRowIdFactorySerDeExceptionpublic void addDependencyJars(org.apache.hadoop.conf.Configuration conf)
throws IOException
AccumuloRowIdFactoryaddDependencyJars in interface AccumuloRowIdFactoryIOExceptionpublic ObjectInspector createRowIdObjectInspector(TypeInfo type) throws SerDeException
AccumuloRowIdFactorycreateRowIdObjectInspector in interface AccumuloRowIdFactorytype - type informationSerDeExceptionpublic LazyObjectBase createRowId(ObjectInspector inspector) throws SerDeException
AccumuloRowIdFactorycreateRowId in interface AccumuloRowIdFactoryinspector - OI create by AccumuloRowIdFactory.createRowIdObjectInspector(org.apache.hadoop.hive.serde2.typeinfo.TypeInfo)SerDeExceptionpublic byte[] serializeRowId(Object object, StructField field, ByteStream.Output output) throws IOException
AccumuloRowIdFactoryserializeRowId in interface AccumuloRowIdFactoryIOExceptionCopyright © 2017 The Apache Software Foundation. All rights reserved.