public interface AccumuloRowIdFactory
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 serDeParams,
Properties properties)
initialize factory with properties
|
byte[] |
serializeRowId(Object object,
StructField field,
ByteStream.Output output)
serialize hive object in internal format of custom key
|
void init(AccumuloSerDeParameters serDeParams, Properties properties) throws SerDeException
SerDeException
ObjectInspector createRowIdObjectInspector(TypeInfo type) throws SerDeException
type
- type informationSerDeException
LazyObjectBase createRowId(ObjectInspector inspector) throws SerDeException
inspector
- OI create by createRowIdObjectInspector(org.apache.hadoop.hive.serde2.typeinfo.TypeInfo)
SerDeException
byte[] serializeRowId(Object object, StructField field, ByteStream.Output output) throws IOException
IOException
void addDependencyJars(org.apache.hadoop.conf.Configuration conf) throws IOException
IOException
Copyright © 2017 The Apache Software Foundation. All rights reserved.