public class AccumuloSerDeParameters extends AccumuloConnectionParameters
Modifier and Type | Field and Description |
---|---|
static String |
AUTHORIZATIONS_KEY |
static String |
COLUMN_MAPPINGS |
protected ColumnMapper |
columnMapper |
static String |
COMPOSITE_ROWID_CLASS |
static String |
COMPOSITE_ROWID_FACTORY |
static String |
DEFAULT_STORAGE_TYPE |
static org.apache.accumulo.core.security.ColumnVisibility |
DEFAULT_VISIBILITY_LABEL |
static boolean |
ITERATOR_PUSHDOWN_DEFAULT |
static String |
ITERATOR_PUSHDOWN_KEY |
static String |
VISIBILITY_LABEL_KEY |
conf, INSTANCE_NAME, SASL_ENABLED, TABLE_NAME, USE_MOCK_INSTANCE, useMockInstance, USER_KEYTAB, USER_NAME, USER_PASS, ZOOKEEPERS
Constructor and Description |
---|
AccumuloSerDeParameters(org.apache.hadoop.conf.Configuration conf,
Properties tableProperties,
String serdeName) |
Modifier and Type | Method and Description |
---|---|
protected AccumuloRowIdFactory |
createRowIdFactory(org.apache.hadoop.conf.Configuration job,
Properties tbl) |
org.apache.accumulo.core.security.Authorizations |
getAuthorizations()
Extracts the table property to allow dynamic Accumulo Authorizations to be used when reading
data from an Accumulo table.
|
static org.apache.accumulo.core.security.Authorizations |
getAuthorizationsFromConf(org.apache.hadoop.conf.Configuration conf)
Extract any configuration on Authorizations to be used from the provided Configuration.
|
protected static org.apache.accumulo.core.security.Authorizations |
getAuthorizationsFromValue(String authorizationStr)
Create an Authorizations object when the provided value is not null.
|
ColumnMapper |
getColumnMapper() |
ColumnMapping |
getColumnMappingForHiveColumn(String hiveColumn) |
List<ColumnMapping> |
getColumnMappings() |
String |
getColumnMappingValue() |
String |
getColumnTypeValue() |
List<String> |
getHiveColumnNames() |
List<TypeInfo> |
getHiveColumnTypes() |
boolean |
getIteratorPushdown() |
HiveAccumuloRowIdColumnMapping |
getRowIdColumnMapping() |
AccumuloRowIdFactory |
getRowIdFactory() |
String |
getRowIdHiveColumnName() |
int |
getRowIdOffset() |
String |
getSerDeName() |
LazySerDeParameters |
getSerDeParameters() |
Properties |
getTableProperties() |
org.apache.accumulo.core.security.ColumnVisibility |
getTableVisibilityLabel()
Extracts the table property to allow a custom ColumnVisibility label to be set on updates to be
written to an Accumulo table.
|
TypeInfo |
getTypeForHiveColumn(String hiveColumn) |
protected AccumuloRowIdFactory |
initRowIdFactory(org.apache.hadoop.conf.Configuration conf,
Properties tbl) |
getAccumuloInstanceName, getAccumuloKeytab, getAccumuloPassword, getAccumuloTableName, getAccumuloUserName, getConf, getConnector, getConnector, getInstance, getKerberosToken, getZooKeepers, useMockInstance, useSasl
public static final String COLUMN_MAPPINGS
public static final String ITERATOR_PUSHDOWN_KEY
public static final boolean ITERATOR_PUSHDOWN_DEFAULT
public static final String DEFAULT_STORAGE_TYPE
public static final String VISIBILITY_LABEL_KEY
public static final org.apache.accumulo.core.security.ColumnVisibility DEFAULT_VISIBILITY_LABEL
public static final String AUTHORIZATIONS_KEY
public static final String COMPOSITE_ROWID_FACTORY
public static final String COMPOSITE_ROWID_CLASS
protected final ColumnMapper columnMapper
public AccumuloSerDeParameters(org.apache.hadoop.conf.Configuration conf, Properties tableProperties, String serdeName) throws SerDeException
SerDeException
protected AccumuloRowIdFactory initRowIdFactory(org.apache.hadoop.conf.Configuration conf, Properties tbl) throws SerDeException
SerDeException
protected AccumuloRowIdFactory createRowIdFactory(org.apache.hadoop.conf.Configuration job, Properties tbl) throws Exception
Exception
public LazySerDeParameters getSerDeParameters()
public Properties getTableProperties()
public String getColumnTypeValue()
public String getSerDeName()
public String getColumnMappingValue()
public HiveAccumuloRowIdColumnMapping getRowIdColumnMapping()
public boolean getIteratorPushdown()
public ColumnMapper getColumnMapper()
public int getRowIdOffset()
public List<ColumnMapping> getColumnMappings()
public AccumuloRowIdFactory getRowIdFactory()
public String getRowIdHiveColumnName()
public ColumnMapping getColumnMappingForHiveColumn(String hiveColumn)
public org.apache.accumulo.core.security.ColumnVisibility getTableVisibilityLabel()
ColumnVisibility
. If not value is present in the table properties, an empty
ColumnVisibility is returned.public org.apache.accumulo.core.security.Authorizations getAuthorizations()
protected static org.apache.accumulo.core.security.Authorizations getAuthorizationsFromValue(String authorizationStr)
authorizationStr
- Configuration value to parsepublic static org.apache.accumulo.core.security.Authorizations getAuthorizationsFromConf(org.apache.hadoop.conf.Configuration conf)
Copyright © 2017 The Apache Software Foundation. All rights reserved.