T
- public class CompositeAccumuloRowIdFactory<T extends AccumuloCompositeRowId> extends DefaultAccumuloRowIdFactory
AccumuloRowIdFactory
designed for injection of the AccumuloCompositeRowId
to be
used to generate the Accumulo rowId. Allows for custom AccumuloCompositeRowId
s to be
specified without overriding the entire ObjectInspector for the Hive row.Modifier and Type | Field and Description |
---|---|
static org.apache.log4j.Logger |
log |
accumuloSerDeParams, properties, rowIdMapping, serdeParams, serializer
Constructor and Description |
---|
CompositeAccumuloRowIdFactory(Class<T> keyClass) |
Modifier and Type | Method and Description |
---|---|
void |
addDependencyJars(org.apache.hadoop.conf.Configuration jobConf)
Add this implementation to the classpath for the Job
|
T |
createRowId(ObjectInspector inspector)
create custom object for accumulo
|
createRowIdObjectInspector, init, serializeRowId
public CompositeAccumuloRowIdFactory(Class<T> keyClass) throws SecurityException, NoSuchMethodException
public void addDependencyJars(org.apache.hadoop.conf.Configuration jobConf) throws IOException
AccumuloRowIdFactory
addDependencyJars
in interface AccumuloRowIdFactory
addDependencyJars
in class DefaultAccumuloRowIdFactory
IOException
public T createRowId(ObjectInspector inspector) throws SerDeException
AccumuloRowIdFactory
createRowId
in interface AccumuloRowIdFactory
createRowId
in class DefaultAccumuloRowIdFactory
inspector
- OI create by AccumuloRowIdFactory.createRowIdObjectInspector(org.apache.hadoop.hive.serde2.typeinfo.TypeInfo)
SerDeException
Copyright © 2017 The Apache Software Foundation. All rights reserved.