public class HiveAccumuloTableOutputFormat
extends org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
| Modifier and Type | Field and Description |
|---|---|
protected HiveAccumuloHelper |
helper |
| Constructor and Description |
|---|
HiveAccumuloTableOutputFormat() |
| Modifier and Type | Method and Description |
|---|---|
void |
checkOutputSpecs(org.apache.hadoop.fs.FileSystem ignored,
org.apache.hadoop.mapred.JobConf job) |
protected void |
configureAccumuloOutputFormat(org.apache.hadoop.mapred.JobConf job) |
org.apache.hadoop.mapred.RecordWriter<org.apache.hadoop.io.Text,org.apache.accumulo.core.data.Mutation> |
getRecordWriter(org.apache.hadoop.fs.FileSystem ignored,
org.apache.hadoop.mapred.JobConf job,
String name,
org.apache.hadoop.util.Progressable progress) |
protected void |
setAccumuloConnectorInfo(org.apache.hadoop.mapred.JobConf conf,
String username,
org.apache.accumulo.core.client.security.tokens.AuthenticationToken token) |
protected void |
setAccumuloMockInstance(org.apache.hadoop.mapred.JobConf conf,
String instanceName) |
protected void |
setAccumuloZooKeeperInstance(org.apache.hadoop.mapred.JobConf conf,
String instanceName,
String zookeepers,
boolean isSasl) |
protected void |
setDefaultAccumuloTableName(org.apache.hadoop.mapred.JobConf conf,
String tableName) |
canCreateTables, getAuthenticationToken, getBatchWriterOptions, getDefaultTableName, getInstance, getLogLevel, getPrincipal, getSimulationMode, getToken, getTokenClass, isConnectorInfoSet, setBatchWriterOptions, setConnectorInfo, setConnectorInfo, setCreateTables, setDefaultTableName, setLogLevel, setMockInstance, setSimulationMode, setZooKeeperInstance, setZooKeeperInstanceprotected final HiveAccumuloHelper helper
public void checkOutputSpecs(org.apache.hadoop.fs.FileSystem ignored,
org.apache.hadoop.mapred.JobConf job)
throws IOException
checkOutputSpecs in interface org.apache.hadoop.mapred.OutputFormat<org.apache.hadoop.io.Text,org.apache.accumulo.core.data.Mutation>checkOutputSpecs in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormatIOExceptionpublic org.apache.hadoop.mapred.RecordWriter<org.apache.hadoop.io.Text,org.apache.accumulo.core.data.Mutation> getRecordWriter(org.apache.hadoop.fs.FileSystem ignored,
org.apache.hadoop.mapred.JobConf job,
String name,
org.apache.hadoop.util.Progressable progress)
throws IOException
getRecordWriter in interface org.apache.hadoop.mapred.OutputFormat<org.apache.hadoop.io.Text,org.apache.accumulo.core.data.Mutation>getRecordWriter in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormatIOExceptionprotected void configureAccumuloOutputFormat(org.apache.hadoop.mapred.JobConf job)
throws IOException
IOExceptionprotected void setAccumuloConnectorInfo(org.apache.hadoop.mapred.JobConf conf,
String username,
org.apache.accumulo.core.client.security.tokens.AuthenticationToken token)
throws org.apache.accumulo.core.client.AccumuloSecurityException
org.apache.accumulo.core.client.AccumuloSecurityExceptionprotected void setAccumuloZooKeeperInstance(org.apache.hadoop.mapred.JobConf conf,
String instanceName,
String zookeepers,
boolean isSasl)
throws IOException
IOExceptionprotected void setAccumuloMockInstance(org.apache.hadoop.mapred.JobConf conf,
String instanceName)
protected void setDefaultAccumuloTableName(org.apache.hadoop.mapred.JobConf conf,
String tableName)
Copyright © 2017 The Apache Software Foundation. All rights reserved.