Package | Description |
---|---|
org.apache.hadoop.hive.accumulo |
Serde and InputFormat support for connecting Hive to Accumulo tables.
|
org.apache.hadoop.hive.accumulo.serde |
Modifier and Type | Method and Description |
---|---|
void |
LazyAccumuloRow.init(AccumuloHiveRow hiveRow,
List<ColumnMapping> columnMappings,
AccumuloRowIdFactory rowIdFactory) |
Modifier and Type | Class and Description |
---|---|
class |
CompositeAccumuloRowIdFactory<T extends AccumuloCompositeRowId>
AccumuloRowIdFactory designed for injection of the AccumuloCompositeRowId to be
used to generate the Accumulo rowId. |
class |
DefaultAccumuloRowIdFactory
Default implementation of the AccumuloRowIdFactory which uses the normal
AccumuloRowSerializer methods to serialize the field for storage into Accumulo. |
Modifier and Type | Method and Description |
---|---|
protected AccumuloRowIdFactory |
AccumuloSerDeParameters.createRowIdFactory(org.apache.hadoop.conf.Configuration job,
Properties tbl) |
AccumuloRowIdFactory |
AccumuloSerDeParameters.getRowIdFactory() |
protected AccumuloRowIdFactory |
AccumuloSerDeParameters.initRowIdFactory(org.apache.hadoop.conf.Configuration conf,
Properties tbl) |
Modifier and Type | Method and Description |
---|---|
protected ArrayList<ObjectInspector> |
AccumuloSerDe.getColumnObjectInspectors(List<TypeInfo> columnTypes,
LazySerDeParameters serDeParams,
List<ColumnMapping> mappings,
AccumuloRowIdFactory factory) |
Constructor and Description |
---|
AccumuloRowSerializer(int primaryKeyOffset,
LazySerDeParameters serDeParams,
List<ColumnMapping> mappings,
org.apache.accumulo.core.security.ColumnVisibility visibility,
AccumuloRowIdFactory rowIdFactory) |
Copyright © 2017 The Apache Software Foundation. All rights reserved.