|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Uses of Instance in org.apache.accumulo.core.cli |
---|
Fields in org.apache.accumulo.core.cli declared as Instance | |
---|---|
protected Instance |
ClientOpts.cachedInstance
|
Methods in org.apache.accumulo.core.cli that return Instance | |
---|---|
Instance |
ClientOpts.getInstance()
|
Uses of Instance in org.apache.accumulo.core.client |
---|
Classes in org.apache.accumulo.core.client that implement Instance | |
---|---|
class |
ZooKeeperInstance
An implementation of instance that looks in zookeeper to find information needed to connect to an instance of accumulo. |
Methods in org.apache.accumulo.core.client that return Instance | |
---|---|
abstract Instance |
Connector.getInstance()
Accessor method for internal instance object. |
Constructors in org.apache.accumulo.core.client with parameters of type Instance | |
---|---|
TableOfflineException(Instance instance,
String tableId)
|
Uses of Instance in org.apache.accumulo.core.client.admin |
---|
Constructors in org.apache.accumulo.core.client.admin with parameters of type Instance | |
---|---|
InstanceOperationsImpl(Instance instance,
TCredentials credentials)
|
|
SecurityOperationsImpl(Instance instance,
TCredentials credentials)
|
|
TableOperationsImpl(Instance instance,
TCredentials credentials)
|
Uses of Instance in org.apache.accumulo.core.client.impl |
---|
Methods in org.apache.accumulo.core.client.impl that return Instance | |
---|---|
Instance |
ConnectorImpl.getInstance()
|
Methods in org.apache.accumulo.core.client.impl with parameters of type Instance | ||
---|---|---|
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
|
ServerClient.execute(Instance instance,
ClientExecReturn<T,ClientService.Client> exec)
|
|
static
|
MasterClient.execute(Instance instance,
ClientExecReturn<T,MasterClientService.Client> exec)
|
|
static void |
ServerClient.executeRaw(Instance instance,
ClientExec<ClientService.Client> exec)
|
|
static
|
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)
|
Uses of Instance in org.apache.accumulo.core.client.mapred |
---|
Methods in org.apache.accumulo.core.client.mapred that return Instance | |
---|---|
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. |
Uses of Instance in org.apache.accumulo.core.client.mapreduce |
---|
Methods in org.apache.accumulo.core.client.mapreduce that return Instance | |
---|---|
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.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 |
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. |
Uses of Instance in org.apache.accumulo.core.client.mapreduce.lib.util |
---|
Methods in org.apache.accumulo.core.client.mapreduce.lib.util that return Instance | |
---|---|
static Instance |
ConfiguratorBase.getInstance(Class<?> implementingClass,
org.apache.hadoop.conf.Configuration conf)
Initializes an Accumulo Instance based on the configuration. |
Uses of Instance in org.apache.accumulo.core.client.mock |
---|
Classes in org.apache.accumulo.core.client.mock that implement Instance | |
---|---|
class |
MockInstance
Mock Accumulo provides an in memory implementation of the Accumulo client API. |
Methods in org.apache.accumulo.core.client.mock that return Instance | |
---|---|
Instance |
MockConnector.getInstance()
|
Uses of Instance in org.apache.accumulo.core.security |
---|
Constructors in org.apache.accumulo.core.security with parameters of type Instance | |
---|---|
Credentials(Instance instance,
String principal,
AuthenticationToken token)
|
Uses of Instance in org.apache.accumulo.core.trace |
---|
Fields in org.apache.accumulo.core.trace declared as Instance | |
---|---|
Instance |
InstanceUserPassword.instance
|
Methods in org.apache.accumulo.core.trace with parameters of type Instance | |
---|---|
static void |
DistributedTrace.enable(Instance instance,
ZooReader zoo,
String application,
String address)
|
Constructors in org.apache.accumulo.core.trace with parameters of type Instance | |
---|---|
InstanceUserPassword(Instance instance,
String username,
String password)
|
Uses of Instance in org.apache.accumulo.core.util |
---|
Methods in org.apache.accumulo.core.util with parameters of type Instance | |
---|---|
static void |
MetadataTable.getEntries(Instance instance,
TCredentials credentials,
String table,
boolean isTid,
Map<KeyExtent,String> locations,
SortedSet<KeyExtent> tablets)
|
Uses of Instance in org.apache.accumulo.core.util.shell |
---|
Fields in org.apache.accumulo.core.util.shell declared as Instance | |
---|---|
protected Instance |
Shell.instance
|
Uses of Instance in org.apache.accumulo.core.zookeeper |
---|
Methods in org.apache.accumulo.core.zookeeper with parameters of type Instance | |
---|---|
static String |
ZooUtil.getRoot(Instance instance)
|
Uses of Instance in org.apache.accumulo.proxy |
---|
Fields in org.apache.accumulo.proxy declared as Instance | |
---|---|
protected Instance |
ProxyServer.instance
|
Uses of Instance in org.apache.accumulo.server.cli |
---|
Methods in org.apache.accumulo.server.cli that return Instance | |
---|---|
Instance |
ClientOnRequiredTable.getInstance()
|
Instance |
ClientOpts.getInstance()
|
Instance |
ClientOnDefaultTable.getInstance()
|
Uses of Instance in org.apache.accumulo.server.client |
---|
Classes in org.apache.accumulo.server.client that implement Instance | |
---|---|
class |
HdfsZooInstance
An implementation of Instance that looks in HDFS and ZooKeeper to find the master and root tablet location. |
Methods in org.apache.accumulo.server.client that return Instance | |
---|---|
static Instance |
HdfsZooInstance.getInstance()
|
Methods in org.apache.accumulo.server.client with parameters of type Instance | |
---|---|
static List<String> |
BulkImporter.bulkLoad(AccumuloConfiguration conf,
Instance instance,
TCredentials creds,
long tid,
String tableId,
List<String> files,
String errorDir,
boolean setTime)
|
Constructors in org.apache.accumulo.server.client with parameters of type Instance | |
---|---|
BulkImporter(AccumuloConfiguration conf,
Instance instance,
TCredentials credentials,
long tid,
String tableId,
boolean setTime)
|
|
ClientServiceHandler(Instance instance,
TransactionWatcher transactionWatcher)
|
Uses of Instance in org.apache.accumulo.server.conf |
---|
Methods in org.apache.accumulo.server.conf that return Instance | |
---|---|
Instance |
ServerConfiguration.getInstance()
|
Methods in org.apache.accumulo.server.conf with parameters of type Instance | |
---|---|
static ZooConfiguration |
ZooConfiguration.getInstance(Instance inst,
AccumuloConfiguration parent)
|
static AccumuloConfiguration |
ServerConfiguration.getSystemConfiguration(Instance instance)
|
static TableConfiguration |
ServerConfiguration.getTableConfiguration(Instance instance,
String tableId)
|
Constructors in org.apache.accumulo.server.conf with parameters of type Instance | |
---|---|
ServerConfiguration(Instance instance)
|
Uses of Instance in org.apache.accumulo.server.gc |
---|
Methods in org.apache.accumulo.server.gc with parameters of type Instance | |
---|---|
void |
SimpleGarbageCollector.init(org.apache.hadoop.fs.FileSystem fs,
Instance instance,
TCredentials credentials,
boolean noTrash)
|
Uses of Instance in org.apache.accumulo.server.master |
---|
Methods in org.apache.accumulo.server.master that return Instance | |
---|---|
Instance |
Master.getInstance()
|
Constructors in org.apache.accumulo.server.master with parameters of type Instance | |
---|---|
LiveTServerSet(Instance instance,
AccumuloConfiguration conf,
LiveTServerSet.Listener cback)
|
Uses of Instance in org.apache.accumulo.server.master.state |
---|
Fields in org.apache.accumulo.server.master.state declared as Instance | |
---|---|
protected Instance |
MetaDataStateStore.instance
|
Constructors in org.apache.accumulo.server.master.state with parameters of type Instance | |
---|---|
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)
|
Uses of Instance in org.apache.accumulo.server.monitor |
---|
Methods in org.apache.accumulo.server.monitor that return Instance | |
---|---|
static Instance |
Monitor.getInstance()
|
Uses of Instance in org.apache.accumulo.server.tabletserver |
---|
Constructors in org.apache.accumulo.server.tabletserver with parameters of type Instance | |
---|---|
TabletServerResourceManager(Instance instance,
org.apache.hadoop.fs.FileSystem fs)
|
Uses of Instance in org.apache.accumulo.server.tabletserver.log |
---|
Constructors in org.apache.accumulo.server.tabletserver.log with parameters of type Instance | |
---|---|
LogSorter(Instance instance,
org.apache.hadoop.fs.FileSystem fs,
AccumuloConfiguration conf)
|
Uses of Instance in org.apache.accumulo.server.util |
---|
Methods in org.apache.accumulo.server.util with parameters of type Instance | |
---|---|
static void |
MetadataTable.cloneTable(Instance instance,
String srcTableId,
String tableId)
|
static void |
MetadataTable.moveMetaDeleteMarkers(Instance instance,
TCredentials creds)
|
Uses of Instance in org.apache.accumulo.test.functional |
---|
Methods in org.apache.accumulo.test.functional that return Instance | |
---|---|
protected Instance |
FunctionalTest.getInstance()
|
Uses of Instance in org.apache.accumulo.test.performance.thrift |
---|
Constructors in org.apache.accumulo.test.performance.thrift with parameters of type Instance | |
---|---|
NullTserver.ThriftClientHandler(Instance instance,
TransactionWatcher watcher)
|
Uses of Instance in org.apache.accumulo.test.randomwalk |
---|
Methods in org.apache.accumulo.test.randomwalk that return Instance | |
---|---|
Instance |
State.getInstance()
|
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |