public class AccumuloStorageHandler extends DefaultStorageHandler implements HiveMetaHook, HiveStoragePredicateHandler
HiveStoragePredicateHandler.DecomposedPredicate| Modifier and Type | Field and Description |
|---|---|
protected org.apache.hadoop.conf.Configuration |
conf |
protected AccumuloConnectionParameters |
connectionParams |
protected HiveAccumuloHelper |
helper |
protected AccumuloPredicateHandler |
predicateHandler |
| Constructor and Description |
|---|
AccumuloStorageHandler() |
| Modifier and Type | Method and Description |
|---|---|
void |
commitCreateTable(Table table)
Called after successfully adding a new table definition to the metastore
during CREATE TABLE.
|
void |
commitDropTable(Table table,
boolean deleteData)
Called after successfully removing a table definition from the metastore
during DROP TABLE.
|
void |
configureInputJobProperties(TableDesc tableDesc,
Map<String,String> jobProperties)
This method is called to allow the StorageHandlers the chance
to populate the JobContext.getConfiguration() with properties that
maybe be needed by the handler's bundled artifacts (ie InputFormat, SerDe, etc).
|
void |
configureJobConf(TableDesc tableDesc,
org.apache.hadoop.mapred.JobConf jobConf)
Called just before submitting MapReduce job.
|
void |
configureOutputJobProperties(TableDesc tableDesc,
Map<String,String> jobProperties)
This method is called to allow the StorageHandlers the chance
to populate the JobContext.getConfiguration() with properties that
maybe be needed by the handler's bundled artifacts (ie InputFormat, SerDe, etc).
|
void |
configureTableJobProperties(TableDesc desc,
Map<String,String> jobProps)
Push down table properties into the JobConf.
|
HiveStoragePredicateHandler.DecomposedPredicate |
decomposePredicate(org.apache.hadoop.mapred.JobConf conf,
Deserializer deserializer,
ExprNodeDesc desc)
Gives the storage handler a chance to decompose a predicate.
|
HiveAuthorizationProvider |
getAuthorizationProvider()
Returns the implementation specific authorization provider
|
org.apache.hadoop.conf.Configuration |
getConf() |
Class<? extends org.apache.hadoop.mapred.InputFormat> |
getInputFormatClass() |
HiveMetaHook |
getMetaHook() |
Class<? extends org.apache.hadoop.mapred.OutputFormat> |
getOutputFormatClass() |
Class<? extends SerDe> |
getSerDeClass() |
protected String |
getTableName(Table table) |
protected String |
getTableName(TableDesc tableDesc) |
protected boolean |
isExternalTable(Table table) |
void |
preCreateTable(Table table)
Called before a new table definition is added to the metastore
during CREATE TABLE.
|
void |
preDropTable(Table table)
Called before a table definition is removed from the metastore
during DROP TABLE.
|
void |
rollbackCreateTable(Table table)
Called after failure adding a new table definition to the metastore
during CREATE TABLE.
|
void |
rollbackDropTable(Table table)
Called after failure removing a table definition from the metastore
during DROP TABLE.
|
void |
setConf(org.apache.hadoop.conf.Configuration conf) |
toStringprotected AccumuloPredicateHandler predicateHandler
protected AccumuloConnectionParameters connectionParams
protected org.apache.hadoop.conf.Configuration conf
protected HiveAccumuloHelper helper
public void configureTableJobProperties(TableDesc desc, Map<String,String> jobProps)
configureTableJobProperties in interface HiveStorageHandlerconfigureTableJobProperties in class DefaultStorageHandlerdesc - Hive table descriptionjobProps - Properties that will be added to the JobConf by Hiveprotected String getTableName(Table table) throws MetaException
MetaExceptionpublic org.apache.hadoop.conf.Configuration getConf()
getConf in interface org.apache.hadoop.conf.ConfigurablegetConf in class DefaultStorageHandlerpublic void setConf(org.apache.hadoop.conf.Configuration conf)
setConf in interface org.apache.hadoop.conf.ConfigurablesetConf in class DefaultStorageHandlerpublic Class<? extends SerDe> getSerDeClass()
getSerDeClass in interface HiveStorageHandlergetSerDeClass in class DefaultStorageHandlerSerDepublic HiveMetaHook getMetaHook()
getMetaHook in interface HiveStorageHandlergetMetaHook in class DefaultStorageHandlerpublic HiveAuthorizationProvider getAuthorizationProvider() throws HiveException
HiveStorageHandlergetAuthorizationProvider in interface HiveStorageHandlergetAuthorizationProvider in class DefaultStorageHandlerHiveExceptionpublic void configureInputJobProperties(TableDesc tableDesc, Map<String,String> jobProperties)
HiveStorageHandlerconfigureInputJobProperties in interface HiveStorageHandlerconfigureInputJobProperties in class DefaultStorageHandlertableDesc - descriptor for the table being accessedjobProperties - receives properties copied or transformed
from the table propertiespublic void configureOutputJobProperties(TableDesc tableDesc, Map<String,String> jobProperties)
HiveStorageHandlerconfigureOutputJobProperties in interface HiveStorageHandlerconfigureOutputJobProperties in class DefaultStorageHandlertableDesc - descriptor for the table being accessedjobProperties - receives properties copied or transformed
from the table propertiespublic Class<? extends org.apache.hadoop.mapred.InputFormat> getInputFormatClass()
getInputFormatClass in interface HiveStorageHandlergetInputFormatClass in class DefaultStorageHandlerInputFormatpublic Class<? extends org.apache.hadoop.mapred.OutputFormat> getOutputFormatClass()
getOutputFormatClass in interface HiveStorageHandlergetOutputFormatClass in class DefaultStorageHandlerOutputFormatpublic void preCreateTable(Table table) throws MetaException
HiveMetaHookpreCreateTable in interface HiveMetaHooktable - new table definitionMetaExceptionprotected boolean isExternalTable(Table table)
public void rollbackCreateTable(Table table) throws MetaException
HiveMetaHookrollbackCreateTable in interface HiveMetaHooktable - new table definitionMetaExceptionpublic void commitCreateTable(Table table) throws MetaException
HiveMetaHookcommitCreateTable in interface HiveMetaHooktable - new table definitionMetaExceptionpublic void commitDropTable(Table table, boolean deleteData) throws MetaException
HiveMetaHookcommitDropTable in interface HiveMetaHooktable - table definitiondeleteData - whether to delete data as well; this should typically
be ignored in the case of an external tableMetaExceptionpublic void preDropTable(Table table) throws MetaException
HiveMetaHookpreDropTable in interface HiveMetaHooktable - table definitionMetaExceptionpublic void rollbackDropTable(Table table) throws MetaException
HiveMetaHookrollbackDropTable in interface HiveMetaHooktable - table definitionMetaExceptionpublic HiveStoragePredicateHandler.DecomposedPredicate decomposePredicate(org.apache.hadoop.mapred.JobConf conf, Deserializer deserializer, ExprNodeDesc desc)
HiveStoragePredicateHandlerx = 2 AND upper(y)='YUM', the storage handler
might be able to handle x = 2 but leave the "residual"
upper(y)='YUM' for Hive to deal with. The breakdown
need not be non-overlapping; for example, given the
predicate x LIKE 'a%b', the storage handler might
be able to evaluate the prefix search x LIKE 'a%', leaving
x LIKE '%b' as the residual.decomposePredicate in interface HiveStoragePredicateHandlerconf - contains a job configuration matching the one that
will later be passed to getRecordReader and getSplitsdeserializer - deserializer which will be used when
fetching rowsdesc - predicate to be decomposedpublic void configureJobConf(TableDesc tableDesc, org.apache.hadoop.mapred.JobConf jobConf)
HiveStorageHandlerconfigureJobConf in interface HiveStorageHandlerconfigureJobConf in class DefaultStorageHandlertableDesc - descriptor for the table being accessedCopyright © 2017 The Apache Software Foundation. All rights reserved.