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 |
---|
TableOfflineException(Instance instance,
String tableId) |
Constructor and Description |
---|
InstanceOperationsImpl(Instance instance,
TCredentials credentials) |
SecurityOperationsImpl(Instance instance,
TCredentials credentials) |
TableOperationsImpl(Instance instance,
TCredentials credentials) |
Modifier and Type | Method and Description |
---|---|
Instance |
ConnectorImpl.getInstance() |
Modifier and Type | Method and Description |
---|---|
static void |
Tables.clearCache(Instance instance) |
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 |
ServerClient.executeRaw(Instance instance,
ClientExec<ClientService.Client> exec) |
static <T> T |
ServerClient.executeRaw(Instance instance,
ClientExecReturn<T,ClientService.Client> exec) |
static boolean |
Tables.exists(Instance instance,
String tableId) |
static MasterClientService.Client |
MasterClient.getConnection(Instance instance) |
static Pair<String,ClientService.Client> |
ServerClient.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 TabletLocator |
TabletLocator.getInstance(Instance instance,
org.apache.hadoop.io.Text tableId) |
static SortedMap<String,String> |
Tables.getNameToIdMap(Instance instance) |
static String |
Tables.getTableId(Instance instance,
String tableName) |
static String |
Tables.getTableName(Instance instance,
String tableId) |
static TableState |
Tables.getTableState(Instance instance,
String tableId) |
static List<KeyValue> |
ThriftScanner.scan(Instance instance,
TCredentials credentials,
ThriftScanner.ScanState scanState,
int timeOut,
AccumuloConfiguration conf) |
Constructor and Description |
---|
BatchWriterImpl(Instance instance,
TCredentials credentials,
String table,
BatchWriterConfig config) |
ConnectorImpl(Instance instance,
TCredentials cred)
Deprecated.
|
MultiTableBatchWriterImpl(Instance instance,
TCredentials credentials,
BatchWriterConfig config) |
MultiTableBatchWriterImpl(Instance instance,
TCredentials credentials,
BatchWriterConfig config,
long cacheTime,
TimeUnit cacheTimeUnit) |
OfflineScanner(Instance instance,
TCredentials credentials,
String tableId,
Authorizations authorizations) |
ScannerImpl(Instance instance,
TCredentials credentials,
String table,
Authorizations authorizations) |
TabletServerBatchDeleter(Instance instance,
TCredentials credentials,
String tableId,
Authorizations authorizations,
int numQueryThreads,
BatchWriterConfig bwConfig) |
TabletServerBatchReader(Instance instance,
TCredentials credentials,
String table,
Authorizations authorizations,
int numQueryThreads) |
TabletServerBatchReaderIterator(Instance instance,
TCredentials credentials,
String table,
Authorizations authorizations,
ArrayList<Range> ranges,
int numThreads,
ExecutorService queryThreadPool,
ScannerOptions scannerOptions,
long timeout) |
TabletServerBatchWriter(Instance instance,
TCredentials credentials,
BatchWriterConfig config) |
Writer(Instance instance,
TCredentials credentials,
String table) |
Writer(Instance instance,
TCredentials 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 |
InputFormatBase.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.conf.Configuration conf)
Deprecated.
since 1.5.0; Use
AccumuloOutputFormat.getInstance(JobContext) instead. |
protected static Instance |
InputFormatBase.getInstance(org.apache.hadoop.conf.Configuration conf)
Deprecated.
since 1.5.0; Use
InputFormatBase.getInstance(JobContext) instead. |
protected static Instance |
AccumuloFileOutputFormat.getInstance(org.apache.hadoop.conf.Configuration conf)
Deprecated.
since 1.5.0; This
OutputFormat does not communicate with Accumulo. If this is needed, subclasses must implement their own
configuration. |
protected static Instance |
AccumuloOutputFormat.getInstance(org.apache.hadoop.mapreduce.JobContext context)
Initializes an Accumulo
Instance based on the configuration. |
protected static Instance |
InputFormatBase.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 | 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() |
Constructor and Description |
---|
Credentials(Instance instance,
String principal,
AuthenticationToken token) |
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 void |
MetadataTable.getEntries(Instance instance,
TCredentials credentials,
String table,
boolean isTid,
Map<KeyExtent,String> locations,
SortedSet<KeyExtent> tablets) |
Modifier and Type | Field and Description |
---|---|
protected Instance |
Shell.instance |
Modifier and Type | Method and Description |
---|---|
static String |
ZooUtil.getRoot(Instance instance) |
Modifier and Type | Field and Description |
---|---|
protected Instance |
ProxyServer.instance |
Modifier and Type | Method and Description |
---|---|
Instance |
ClientOnRequiredTable.getInstance() |
Instance |
ClientOpts.getInstance() |
Instance |
ClientOnDefaultTable.getInstance() |
Modifier and Type | Class and Description |
---|---|
class |
HdfsZooInstance
An implementation of Instance that looks in HDFS and ZooKeeper to find the master and root tablet location.
|
Modifier and Type | Method and Description |
---|---|
static Instance |
HdfsZooInstance.getInstance() |
Modifier and Type | Method and Description |
---|---|
static List<String> |
BulkImporter.bulkLoad(AccumuloConfiguration conf,
Instance instance,
TCredentials creds,
long tid,
String tableId,
List<String> files,
String errorDir,
boolean setTime) |
Constructor and Description |
---|
BulkImporter(AccumuloConfiguration conf,
Instance instance,
TCredentials credentials,
long tid,
String tableId,
boolean setTime) |
ClientServiceHandler(Instance instance,
TransactionWatcher transactionWatcher) |
Modifier and Type | Method and Description |
---|---|
Instance |
ServerConfiguration.getInstance() |
Modifier and Type | Method and Description |
---|---|
static ZooConfiguration |
ZooConfiguration.getInstance(Instance inst,
AccumuloConfiguration parent) |
static AccumuloConfiguration |
ServerConfiguration.getSystemConfiguration(Instance instance) |
static TableConfiguration |
ServerConfiguration.getTableConfiguration(Instance instance,
String tableId) |
Constructor and Description |
---|
ServerConfiguration(Instance instance) |
TableConfiguration(String instanceId,
Instance instance,
String table,
AccumuloConfiguration parent) |
Modifier and Type | Method and Description |
---|---|
void |
SimpleGarbageCollector.init(org.apache.hadoop.fs.FileSystem fs,
Instance instance,
TCredentials credentials,
boolean noTrash) |
Modifier and Type | Method and Description |
---|---|
Instance |
Master.getInstance() |
Constructor and Description |
---|
LiveTServerSet(Instance instance,
AccumuloConfiguration conf,
LiveTServerSet.Listener cback) |
Modifier and Type | Field and Description |
---|---|
protected Instance |
MetaDataStateStore.instance |
Constructor and Description |
---|
MetaDataStateStore(Instance instance,
TCredentials auths,
CurrentState state) |
MetaDataTableScanner(Instance instance,
TCredentials auths,
Range range) |
MetaDataTableScanner(Instance instance,
TCredentials auths,
Range range,
CurrentState state) |
RootTabletStateStore(Instance instance,
TCredentials auths,
CurrentState state) |
Modifier and Type | Method and Description |
---|---|
static Instance |
Monitor.getInstance() |
Constructor and Description |
---|
TabletServerResourceManager(Instance instance,
org.apache.hadoop.fs.FileSystem fs) |
Constructor and Description |
---|
LogSorter(Instance instance,
org.apache.hadoop.fs.FileSystem fs,
AccumuloConfiguration conf) |
Modifier and Type | Method and Description |
---|---|
static void |
MetadataTable.cloneTable(Instance instance,
String srcTableId,
String tableId) |
static void |
MetadataTable.moveMetaDeleteMarkers(Instance instance,
TCredentials creds)
During an upgrade from Accumulo 1.4 -> 1.5, we need to move deletion requests for files under the !METADATA table to the root tablet.
|
Modifier and Type | Method and Description |
---|---|
protected Instance |
FunctionalTest.getInstance() |
Constructor and Description |
---|
NullTserver.ThriftClientHandler(Instance instance,
TransactionWatcher watcher) |
Modifier and Type | Method and Description |
---|---|
Instance |
State.getInstance() |
Copyright © 2011-2015 The Apache Software Foundation. All Rights Reserved.