Package | Description |
---|---|
org.apache.accumulo.core.cli | |
org.apache.accumulo.core.client | |
org.apache.accumulo.core.client.admin | |
org.apache.accumulo.core.client.impl | |
org.apache.accumulo.core.client.mapred | |
org.apache.accumulo.core.client.mapreduce | |
org.apache.accumulo.core.client.mapreduce.lib.impl |
This package exists to store common helpers for configuring MapReduce jobs in a single location.
|
org.apache.accumulo.core.client.mapreduce.lib.util | |
org.apache.accumulo.core.client.mock | |
org.apache.accumulo.core.metadata | |
org.apache.accumulo.core.security | |
org.apache.accumulo.core.trace | |
org.apache.accumulo.core.util | |
org.apache.accumulo.core.util.shell | |
org.apache.accumulo.core.util.shell.commands | |
org.apache.accumulo.core.zookeeper |
Modifier and Type | Field and Description |
---|---|
protected Instance |
ClientOpts.cachedInstance |
Modifier and Type | Method and Description |
---|---|
Instance |
ClientOpts.getInstance() |
Modifier and Type | Class and Description |
---|---|
class |
ZooKeeperInstance
An implementation of instance that looks in zookeeper to find information needed to connect to an instance of accumulo.
|
Modifier and Type | Method and Description |
---|---|
abstract Instance |
Connector.getInstance()
Accessor method for internal instance object.
|
Constructor and Description |
---|
MutationsRejectedException(Instance instance,
List<ConstraintViolationSummary> cvsList,
HashMap<KeyExtent,Set<SecurityErrorCode>> hashMap,
Collection<String> serverSideErrors,
int unknownErrors,
Throwable cause) |
TableOfflineException(Instance instance,
String tableId) |
Constructor and Description |
---|
InstanceOperationsImpl(Instance instance,
TCredentials credentials)
Deprecated.
|
SecurityOperationsImpl(Instance instance,
Credentials credentials)
Deprecated.
|
SecurityOperationsImpl(Instance instance,
TCredentials credentials)
Deprecated.
|
TableOperationsImpl(Instance instance,
Credentials credentials)
Deprecated.
|
TableOperationsImpl(Instance instance,
TCredentials credentials)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
Instance |
ConnectorImpl.getInstance() |
Modifier and Type | Method and Description |
---|---|
static String |
Tables._getTableId(Instance instance,
String tableName) |
static void |
Tables.clearCache(Instance instance) |
protected IsolatedScanner |
TableOperationsImpl.createMetadataScanner(Instance inst,
Credentials creds,
String metaTable,
Range range)
Create an IsolatedScanner over the given table, fetching the columns necessary to determine when a table has transitioned to online or offline.
|
static void |
TabletServerBatchReaderIterator.doLookup(Instance instance,
Credentials credentials,
String server,
Map<KeyExtent,List<Range>> requested,
Map<KeyExtent,List<Range>> failures,
Map<KeyExtent,List<Range>> unscanned,
TabletServerBatchReaderIterator.ResultReceiver receiver,
List<Column> columns,
ScannerOptions options,
Authorizations authorizations,
AccumuloConfiguration conf) |
static void |
ServerClient.execute(Instance instance,
ClientExec<ClientService.Client> exec) |
static void |
MasterClient.execute(Instance instance,
ClientExec<MasterClientService.Client> exec) |
static <T> T |
ServerClient.execute(Instance instance,
ClientExecReturn<T,ClientService.Client> exec) |
static <T> T |
MasterClient.execute(Instance instance,
ClientExecReturn<T,MasterClientService.Client> exec) |
static void |
MasterClient.executeGeneric(Instance instance,
ClientExec<MasterClientService.Client> exec) |
static void |
MasterClient.executeNamespace(Instance instance,
ClientExec<MasterClientService.Client> exec) |
static void |
ServerClient.executeRaw(Instance instance,
ClientExec<ClientService.Client> exec) |
static <T> T |
ServerClient.executeRaw(Instance instance,
ClientExecReturn<T,ClientService.Client> exec) |
static void |
MasterClient.executeTable(Instance instance,
ClientExec<MasterClientService.Client> exec) |
static boolean |
Tables.exists(Instance instance,
String tableId) |
static boolean |
Namespaces.exists(Instance instance,
String namespaceId) |
static boolean |
ThriftScanner.getBatchFromServer(Instance instance,
Credentials credentials,
Range range,
KeyExtent extent,
String server,
SortedMap<Key,Value> results,
SortedSet<Column> fetchedColumns,
List<IterInfo> serverSideIteratorList,
Map<String,Map<String,String>> serverSideIteratorOptions,
int size,
Authorizations authorizations,
boolean retry,
AccumuloConfiguration conf) |
static AccumuloConfiguration |
ServerConfigurationUtil.getConfiguration(Instance instance) |
static Pair<String,ClientService.Client> |
ServerClient.getConnection(Instance instance) |
static MasterClientService.Client |
MasterClient.getConnection(Instance instance) |
static Pair<String,ClientService.Client> |
ServerClient.getConnection(Instance instance,
boolean preferCachedConnections) |
static Pair<String,ClientService.Client> |
ServerClient.getConnection(Instance instance,
boolean preferCachedConnections,
long rpcTimeout) |
static MasterClientService.Client |
MasterClient.getConnectionWithRetry(Instance instance) |
static SortedMap<String,String> |
Tables.getIdToNameMap(Instance instance) |
static SortedMap<String,String> |
Namespaces.getIdToNameMap(Instance instance) |
static TabletLocator |
TabletLocator.getLocator(Instance instance,
org.apache.hadoop.io.Text tableId) |
static String |
Tables.getNamespaceId(Instance instance,
String tableId)
Returns the namespace id for a given table ID.
|
static String |
Namespaces.getNamespaceId(Instance instance,
String namespace) |
static String |
Namespaces.getNamespaceName(Instance instance,
String namespaceId) |
static SortedMap<String,String> |
Tables.getNameToIdMap(Instance instance) |
static SortedMap<String,String> |
Namespaces.getNameToIdMap(Instance instance) |
static String |
Tables.getPrintableTableInfoFromId(Instance instance,
String tableId) |
static String |
Tables.getPrintableTableInfoFromName(Instance instance,
String tableName) |
static String |
Tables.getTableId(Instance instance,
String tableName) |
static List<String> |
Namespaces.getTableIds(Instance instance,
String namespaceId) |
static String |
Tables.getTableName(Instance instance,
String tableId) |
static List<String> |
Namespaces.getTableNames(Instance instance,
String namespaceId) |
static TableState |
Tables.getTableState(Instance instance,
String tableId) |
static List<KeyValue> |
ThriftScanner.scan(Instance instance,
Credentials credentials,
ThriftScanner.ScanState scanState,
int timeOut,
AccumuloConfiguration conf) |
Constructor and Description |
---|
BatchWriterImpl(Instance instance,
Credentials credentials,
String table,
BatchWriterConfig config) |
ConnectorImpl(Instance instance,
Credentials cred) |
InstanceOperationsImpl(Instance instance,
Credentials credentials) |
MultiTableBatchWriterImpl(Instance instance,
Credentials credentials,
BatchWriterConfig config) |
MultiTableBatchWriterImpl(Instance instance,
Credentials credentials,
BatchWriterConfig config,
long cacheTime,
TimeUnit cacheTimeUnit) |
NamespaceOperationsImpl(Instance instance,
Credentials credentials,
TableOperationsImpl tableOps) |
OfflineScanner(Instance instance,
Credentials credentials,
String tableId,
Authorizations authorizations) |
ScannerImpl(Instance instance,
Credentials credentials,
String table,
Authorizations authorizations) |
SecurityOperationsImpl(Instance instance,
Credentials credentials) |
TableOperationsImpl(Instance instance,
Credentials credentials) |
TabletServerBatchDeleter(Instance instance,
Credentials credentials,
String tableId,
Authorizations authorizations,
int numQueryThreads,
BatchWriterConfig bwConfig) |
TabletServerBatchReader(Instance instance,
Credentials credentials,
String table,
Authorizations authorizations,
int numQueryThreads) |
TabletServerBatchReaderIterator(Instance instance,
Credentials credentials,
String table,
Authorizations authorizations,
ArrayList<Range> ranges,
int numThreads,
ExecutorService queryThreadPool,
ScannerOptions scannerOptions,
long timeout) |
TabletServerBatchWriter(Instance instance,
Credentials credentials,
BatchWriterConfig config) |
ThriftScanner.ScanState(Instance instance,
Credentials credentials,
org.apache.hadoop.io.Text tableId,
Authorizations authorizations,
Range range,
SortedSet<Column> fetchedColumns,
int size,
List<IterInfo> serverSideIteratorList,
Map<String,Map<String,String>> serverSideIteratorOptions,
boolean isolated) |
ThriftScanner.ScanState(Instance instance,
Credentials credentials,
org.apache.hadoop.io.Text tableId,
Authorizations authorizations,
Range range,
SortedSet<Column> fetchedColumns,
int size,
List<IterInfo> serverSideIteratorList,
Map<String,Map<String,String>> serverSideIteratorOptions,
boolean isolated,
long readaheadThreshold) |
Writer(Instance instance,
Credentials credentials,
String table) |
Writer(Instance instance,
Credentials credentials,
org.apache.hadoop.io.Text table) |
Modifier and Type | Method and Description |
---|---|
protected static Instance |
AccumuloOutputFormat.getInstance(org.apache.hadoop.mapred.JobConf job)
Initializes an Accumulo
Instance based on the configuration. |
protected static Instance |
AbstractInputFormat.getInstance(org.apache.hadoop.mapred.JobConf job)
Initializes an Accumulo
Instance based on the configuration. |
Modifier and Type | Method and Description |
---|---|
Instance |
RangeInputSplit.getInstance() |
protected static Instance |
AccumuloOutputFormat.getInstance(org.apache.hadoop.mapreduce.JobContext context)
Initializes an Accumulo
Instance based on the configuration. |
protected static Instance |
AbstractInputFormat.getInstance(org.apache.hadoop.mapreduce.JobContext context)
Initializes an Accumulo
Instance based on the configuration. |
Modifier and Type | Method and Description |
---|---|
static Instance |
ConfiguratorBase.getInstance(Class<?> implementingClass,
org.apache.hadoop.conf.Configuration conf)
Initializes an Accumulo
Instance based on the configuration. |
Modifier and Type | Method and Description |
---|---|
static Map<String,Map<KeyExtent,List<Range>>> |
InputConfigurator.binOffline(String tableId,
List<Range> ranges,
Instance instance,
Connector conn) |
Modifier and Type | Method and Description |
---|---|
static Instance |
ConfiguratorBase.getInstance(Class<?> implementingClass,
org.apache.hadoop.conf.Configuration conf)
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
|
Modifier and Type | Class and Description |
---|---|
class |
MockInstance
Mock Accumulo provides an in memory implementation of the Accumulo client API.
|
Modifier and Type | Method and Description |
---|---|
Instance |
MockConnector.getInstance() |
Modifier and Type | Method and Description |
---|---|
static MetadataServicer |
MetadataServicer.forTableId(Instance instance,
Credentials credentials,
String tableId) |
static MetadataServicer |
MetadataServicer.forTableName(Instance instance,
Credentials credentials,
String tableName) |
Constructor and Description |
---|
MetadataLocationObtainer(Instance instance) |
Modifier and Type | Method and Description |
---|---|
TCredentials |
Credentials.toThrift(Instance instance)
Converts the current object to the relevant thrift type.
|
Modifier and Type | Field and Description |
---|---|
Instance |
InstanceUserPassword.instance |
Modifier and Type | Method and Description |
---|---|
static void |
DistributedTrace.enable(Instance instance,
ZooReader zoo,
String application,
String address) |
Constructor and Description |
---|
InstanceUserPassword(Instance instance,
String username,
String password) |
Modifier and Type | Method and Description |
---|---|
static String |
MonitorUtil.getLocation(Instance instance) |
Modifier and Type | Field and Description |
---|---|
protected Instance |
Shell.instance |
Modifier and Type | Method and Description |
---|---|
Instance |
Shell.getInstance() |
Modifier and Type | Method and Description |
---|---|
protected IZooReaderWriter |
FateCommand.getZooReaderWriter(Instance instance,
String secret) |
Modifier and Type | Method and Description |
---|---|
static String |
ZooUtil.getRoot(Instance instance) |
Copyright © 2011–2016 The Apache Software Foundation. All rights reserved.