Uses of Class
org.apache.accumulo.core.client.AccumuloException

Packages that use AccumuloException
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.mock   
org.apache.accumulo.core.client.mock.impl   
org.apache.accumulo.core.conf   
org.apache.accumulo.core.metadata   
org.apache.accumulo.core.util   
org.apache.accumulo.core.util.shell   
org.apache.accumulo.core.util.shell.commands   
 

Uses of AccumuloException in org.apache.accumulo.core.cli
 

Methods in org.apache.accumulo.core.cli that throw AccumuloException
 Connector ClientOpts.getConnector()
           
 

Uses of AccumuloException in org.apache.accumulo.core.client
 

Subclasses of AccumuloException in org.apache.accumulo.core.client
 class MutationsRejectedException
          Communicate the failed mutations of a BatchWriter back to the client.
 

Methods in org.apache.accumulo.core.client that throw AccumuloException
 BatchWriter MultiTableBatchWriter.getBatchWriter(String table)
          Returns a BatchWriter for a particular table.
 Connector ZooKeeperInstance.getConnector(String principal, AuthenticationToken token)
           
 Connector Instance.getConnector(String principal, AuthenticationToken token)
          Returns a connection to this instance of accumulo.
 Connector ZooKeeperInstance.getConnector(String principal, byte[] pass)
          Deprecated. 
 Connector Instance.getConnector(String user, byte[] pass)
          Deprecated. since 1.5, use Instance.getConnector(String, AuthenticationToken) with PasswordToken
 Connector ZooKeeperInstance.getConnector(String user, ByteBuffer pass)
          Deprecated. 
 Connector Instance.getConnector(String user, ByteBuffer pass)
          Deprecated. since 1.5, use Instance.getConnector(String, AuthenticationToken) with PasswordToken
 Connector ZooKeeperInstance.getConnector(String user, CharSequence pass)
          Deprecated. 
 Connector Instance.getConnector(String user, CharSequence pass)
          Deprecated. since 1.5, use Instance.getConnector(String, AuthenticationToken) with PasswordToken
 ConditionalWriter.Status ConditionalWriter.Result.getStatus()
          If this method throws an exception, then its possible the mutation is still being actively processed.
 

Uses of AccumuloException in org.apache.accumulo.core.client.admin
 

Methods in org.apache.accumulo.core.client.admin that throw AccumuloException
 int TableOperations.addConstraint(String tableName, String constraintClassName)
          Add a new constraint to a table.
 int NamespaceOperations.addConstraint(String namespace, String constraintClassName)
          Add a new constraint to a namespace.
 void TableOperations.addSplits(String tableName, SortedSet<org.apache.hadoop.io.Text> partitionKeys)
          Ensures that tablets are split along a set of keys.
 void TableOperations.attachIterator(String tableName, IteratorSetting setting)
          Add an iterator to a table on all scopes.
 void NamespaceOperations.attachIterator(String namespace, IteratorSetting setting)
          Add an iterator to a namespace on all scopes.
 void TableOperations.attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
          Add an iterator to a table on the given scopes.
 void NamespaceOperations.attachIterator(String namespace, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
          Add an iterator to a namespace on the given scopes.
 boolean SecurityOperations.authenticateUser(String principal, AuthenticationToken token)
          Verify a username/password combination is valid
 boolean SecurityOperations.authenticateUser(String user, byte[] password)
          Deprecated. since 1.5.0; use SecurityOperations.authenticateUser(String, AuthenticationToken) instead.
 void TableOperations.cancelCompaction(String tableName)
          Cancels a user initiated major compaction of a table initiated with TableOperations.compact(String, Text, Text, boolean, boolean) or TableOperations.compact(String, Text, Text, List, boolean, boolean).
 void SecurityOperations.changeLocalUserPassword(String principal, PasswordToken token)
          Set the user's password
 void SecurityOperations.changeUserAuthorizations(String principal, Authorizations authorizations)
          Set the user's record-level authorizations
 void SecurityOperations.changeUserPassword(String user, byte[] password)
          Deprecated. since 1.5.0; use SecurityOperations.changeLocalUserPassword(String, PasswordToken) or the user management functions of your configured authenticator instead.
 void TableOperations.checkIteratorConflicts(String tableName, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
          Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for the specified scopes.
 void NamespaceOperations.checkIteratorConflicts(String namespace, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
          Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for the specified scopes.
 void TableOperations.clone(String srcTableName, String newTableName, boolean flush, Map<String,String> propertiesToSet, Set<String> propertiesToExclude)
          Clone a table from an existing table.
 void TableOperations.compact(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end, boolean flush, boolean wait)
          Starts a full major compaction of the tablets in the range (start, end].
 void TableOperations.compact(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end, List<IteratorSetting> iterators, boolean flush, boolean wait)
          Starts a full major compaction of the tablets in the range (start, end].
 void TableOperations.create(String tableName)
          Create a table with no special configuration
 void NamespaceOperations.create(String namespace)
          Create an empty namespace with no initial configuration.
 void TableOperations.create(String tableName, boolean limitVersion)
           
 void TableOperations.create(String tableName, boolean versioningIter, TimeType timeType)
           
 void SecurityOperations.createLocalUser(String principal, PasswordToken password)
          Create a user
 void SecurityOperations.createUser(String user, byte[] password, Authorizations authorizations)
          Deprecated. since 1.5.0; use SecurityOperations.createLocalUser(String, PasswordToken) or the user management functions of your configured authenticator instead.
 void TableOperations.delete(String tableName)
          Delete a table
 void NamespaceOperations.delete(String namespace)
          Delete an empty namespace
 void TableOperations.deleteRows(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end)
          Delete rows between (start, end]
 void SecurityOperations.dropLocalUser(String principal)
          Delete a user
 void SecurityOperations.dropUser(String user)
          Deprecated. since 1.5.0; use SecurityOperations.dropUser(String) or the user management functions of your configured authenticator instead.
 boolean NamespaceOperations.exists(String namespace)
          A method to check if a namespace exists in Accumulo.
 void TableOperations.exportTable(String tableName, String exportDir)
          Exports a table.
 void TableOperations.flush(String tableName)
          Deprecated. As of release 1.4, replaced by TableOperations.flush(String, Text, Text, boolean)
 void TableOperations.flush(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end, boolean wait)
          Flush a table's data that is currently in memory.
 List<ActiveCompaction> InstanceOperations.getActiveCompactions(String tserver)
          List the active compaction running on a tablet server
 List<ActiveScan> InstanceOperations.getActiveScans(String tserver)
          List the active scans on tablet server.
 List<DiskUsage> TableOperations.getDiskUsage(Set<String> tables)
          Gets the number of bytes being used in the files for a set of tables
 IteratorSetting TableOperations.getIteratorSetting(String tableName, String name, IteratorUtil.IteratorScope scope)
          Get the settings for an iterator.
 IteratorSetting NamespaceOperations.getIteratorSetting(String namespace, String name, IteratorUtil.IteratorScope scope)
          Get the settings for an iterator.
 Map<String,Set<org.apache.hadoop.io.Text>> TableOperations.getLocalityGroups(String tableName)
          Gets the locality groups currently set for a table.
 org.apache.hadoop.io.Text TableOperations.getMaxRow(String tableName, Authorizations auths, org.apache.hadoop.io.Text startRow, boolean startInclusive, org.apache.hadoop.io.Text endRow, boolean endInclusive)
          Finds the max row within a given range.
 Iterable<Map.Entry<String,String>> TableOperations.getProperties(String tableName)
          Gets properties of a table.
 Iterable<Map.Entry<String,String>> NamespaceOperations.getProperties(String namespace)
          Gets properties of a namespace, which are inherited by tables in this namespace.
 Map<String,String> InstanceOperations.getSiteConfiguration()
           
 Map<String,String> InstanceOperations.getSystemConfiguration()
           
 Authorizations SecurityOperations.getUserAuthorizations(String principal)
          Retrieves the user's authorizations for scanning
 void SecurityOperations.grantNamespacePermission(String principal, String namespace, NamespacePermission permission)
          Grant a user a specific permission for a specific namespace
 void SecurityOperations.grantSystemPermission(String principal, SystemPermission permission)
          Grant a user a system permission
 void SecurityOperations.grantTablePermission(String principal, String table, TablePermission permission)
          Grant a user a specific permission for a specific table
 boolean SecurityOperations.hasNamespacePermission(String principal, String namespace, NamespacePermission perm)
          Verify the user has a particular namespace permission
 boolean SecurityOperations.hasSystemPermission(String principal, SystemPermission perm)
          Verify the user has a particular system permission
 boolean SecurityOperations.hasTablePermission(String principal, String table, TablePermission perm)
          Verify the user has a particular table permission
 void TableOperations.importDirectory(String tableName, String dir, String failureDir, boolean setTime)
          Bulk import all the files in a directory into a table.
 void TableOperations.importTable(String tableName, String importDir)
          Imports a table exported via exportTable and copied via hadoop distcp.
 SortedSet<String> NamespaceOperations.list()
          Retrieve a list of namespaces in Accumulo.
 Map<String,Integer> TableOperations.listConstraints(String tableName)
          List constraints on a table with their assigned numbers.
 Map<String,Integer> NamespaceOperations.listConstraints(String namespace)
          List constraints on a namespace with their assigned numbers.
 Map<String,EnumSet<IteratorUtil.IteratorScope>> TableOperations.listIterators(String tableName)
          Get a list of iterators for this table.
 Map<String,EnumSet<IteratorUtil.IteratorScope>> NamespaceOperations.listIterators(String namespace)
          Get a list of iterators for this namespace.
 Set<String> SecurityOperations.listLocalUsers()
          Return a list of users in accumulo
 Collection<org.apache.hadoop.io.Text> TableOperations.listSplits(String tableName)
           
 Collection<org.apache.hadoop.io.Text> TableOperations.listSplits(String tableName, int maxSplits)
           
 Set<String> SecurityOperations.listUsers()
          Deprecated. since 1.5.0; use SecurityOperations.listLocalUsers() or the user management functions of your configured authenticator instead.
 void TableOperations.merge(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end)
          Merge tablets between (start, end]
 Map<String,String> NamespaceOperations.namespaceIdMap()
          Get a mapping of namespace name to internal namespace id.
 void TableOperations.offline(String tableName)
          Initiates taking a table offline, but does not wait for action to complete
 void TableOperations.offline(String tableName, boolean wait)
           
 void TableOperations.online(String tableName)
          Initiates bringing a table online, but does not wait for action to complete
 void TableOperations.online(String tableName, boolean wait)
           
 void InstanceOperations.ping(String tserver)
          Throws an exception if a tablet server can not be contacted.
 void TableOperations.removeConstraint(String tableName, int number)
          Remove a constraint from a table.
 void NamespaceOperations.removeConstraint(String namespace, int id)
          Remove a constraint from a namespace.
 void TableOperations.removeIterator(String tableName, String name, EnumSet<IteratorUtil.IteratorScope> scopes)
          Remove an iterator from a table by name.
 void NamespaceOperations.removeIterator(String namespace, String name, EnumSet<IteratorUtil.IteratorScope> scopes)
          Remove an iterator from a namespace by name.
 void InstanceOperations.removeProperty(String property)
          Removes a system property from zookeeper.
 void TableOperations.removeProperty(String tableName, String property)
          Removes a property from a table.
 void NamespaceOperations.removeProperty(String namespace, String property)
          Removes a property from a namespace.
 void TableOperations.rename(String oldTableName, String newTableName)
          Rename a table
 void NamespaceOperations.rename(String oldNamespaceName, String newNamespaceName)
          Rename a namespace
 void SecurityOperations.revokeNamespacePermission(String principal, String namespace, NamespacePermission permission)
          Revoke a namespace permission for a specific user on a specific namespace
 void SecurityOperations.revokeSystemPermission(String principal, SystemPermission permission)
          Revoke a system permission from a user
 void SecurityOperations.revokeTablePermission(String principal, String table, TablePermission permission)
          Revoke a table permission for a specific user on a specific table
 void TableOperations.setLocalityGroups(String tableName, Map<String,Set<org.apache.hadoop.io.Text>> groups)
          Sets a table's locality groups.
 void InstanceOperations.setProperty(String property, String value)
          Sets an system property in zookeeper.
 void TableOperations.setProperty(String tableName, String property, String value)
          Sets a property on a table.
 void NamespaceOperations.setProperty(String namespace, String property, String value)
          Sets a property on a namespace which applies to all tables in the namespace.
 Set<Range> TableOperations.splitRangeByTablets(String tableName, Range range, int maxSplits)
           
 boolean InstanceOperations.testClassLoad(String className, String asTypeName)
          Test to see if the instance can load the given class as the given type.
 boolean TableOperations.testClassLoad(String tableName, String className, String asTypeName)
          Test to see if the instance can load the given class as the given type.
 boolean NamespaceOperations.testClassLoad(String namespace, String className, String asTypeName)
          Test to see if the instance can load the given class as the given type.
 

Uses of AccumuloException in org.apache.accumulo.core.client.impl
 

Subclasses of AccumuloException in org.apache.accumulo.core.client.impl
 class AccumuloServerException
          This class is intended to encapsulate errors that occurred on the server side.
 

Methods in org.apache.accumulo.core.client.impl that throw AccumuloException
protected  TabletLocator.TabletLocation TabletLocatorImpl._locateTablet(Credentials credentials, org.apache.hadoop.io.Text row, boolean skipRow, boolean retry, boolean lock, org.apache.accumulo.core.client.impl.TabletLocatorImpl.LockCheckerSession lcSession)
           
 int TableOperationsImpl.addConstraint(String tableName, String constraintClassName)
           
 int TableOperationsHelper.addConstraint(String tableName, String constraintClassName)
           
 int NamespaceOperationsImpl.addConstraint(String namespace, String constraintClassName)
           
 int NamespaceOperationsHelper.addConstraint(String namespace, String constraintClassName)
           
 void TableOperationsImpl.addSplits(String tableName, SortedSet<org.apache.hadoop.io.Text> partitionKeys)
           
 void TableOperationsHelper.attachIterator(String tableName, IteratorSetting setting)
           
 void NamespaceOperationsHelper.attachIterator(String namespace, IteratorSetting setting)
           
 void TableOperationsImpl.attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
           
 void TableOperationsHelper.attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
           
 void NamespaceOperationsImpl.attachIterator(String namespace, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
           
 void NamespaceOperationsHelper.attachIterator(String namespace, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
           
 boolean SecurityOperationsImpl.authenticateUser(String principal, AuthenticationToken token)
           
 boolean SecurityOperationsImpl.authenticateUser(String user, byte[] password)
          Deprecated. 
<T extends Mutation>
void
TimeoutTabletLocator.binMutations(Credentials credentials, List<T> mutations, Map<String,TabletLocator.TabletServerMutations<T>> binnedMutations, List<T> failures)
           
<T extends Mutation>
void
TabletLocatorImpl.binMutations(Credentials credentials, List<T> mutations, Map<String,TabletLocator.TabletServerMutations<T>> binnedMutations, List<T> failures)
           
abstract
<T extends Mutation>
void
TabletLocator.binMutations(Credentials credentials, List<T> mutations, Map<String,TabletLocator.TabletServerMutations<T>> binnedMutations, List<T> failures)
           
<T extends Mutation>
void
RootTabletLocator.binMutations(Credentials credentials, List<T> mutations, Map<String,TabletLocator.TabletServerMutations<T>> binnedMutations, List<T> failures)
           
 List<Range> TimeoutTabletLocator.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 List<Range> TabletLocatorImpl.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
abstract  List<Range> TabletLocator.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 List<Range> RootTabletLocator.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 void TableOperationsImpl.cancelCompaction(String tableName)
           
 void SecurityOperationsImpl.changeLocalUserPassword(String principal, PasswordToken token)
           
 void SecurityOperationsImpl.changeUserAuthorizations(String principal, Authorizations authorizations)
           
 void SecurityOperationsImpl.changeUserPassword(String user, byte[] password)
          Deprecated. 
 void TableOperationsHelper.checkIteratorConflicts(String tableName, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
           
 void NamespaceOperationsHelper.checkIteratorConflicts(String namespace, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
           
 void TableOperationsImpl.clone(String srcTableName, String newTableName, boolean flush, Map<String,String> propertiesToSet, Set<String> propertiesToExclude)
           
 void TableOperationsImpl.compact(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end, boolean flush, boolean wait)
           
 void TableOperationsImpl.compact(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end, List<IteratorSetting> iterators, boolean flush, boolean wait)
           
 void TableOperationsImpl.create(String tableName)
          Create a table with no special configuration
 void NamespaceOperationsImpl.create(String namespace)
           
 void TableOperationsImpl.create(String tableName, boolean limitVersion)
           
 void TableOperationsImpl.create(String tableName, boolean limitVersion, TimeType timeType)
           
 void SecurityOperationsImpl.createLocalUser(String principal, PasswordToken password)
           
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.
 void SecurityOperationsImpl.createUser(String user, byte[] password, Authorizations authorizations)
          Deprecated. 
 void TableOperationsImpl.delete(String tableName)
          Delete a table
 void NamespaceOperationsImpl.delete(String namespace)
           
 void TableOperationsImpl.deleteRows(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end)
           
 void SecurityOperationsImpl.dropLocalUser(String principal)
           
 void SecurityOperationsImpl.dropUser(String user)
          Deprecated. 
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 MasterClient.executeTable(Instance instance, ClientExec<MasterClientService.Client> exec)
           
 void TableOperationsImpl.exportTable(String tableName, String exportDir)
           
 void TableOperationsImpl.flush(String tableName)
          Deprecated. since 1.4 TableOperationsImpl.flush(String, Text, Text, boolean)
 void TableOperationsImpl.flush(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end, boolean wait)
          Flush a table
 List<ActiveCompaction> InstanceOperationsImpl.getActiveCompactions(String tserver)
           
 List<ActiveScan> InstanceOperationsImpl.getActiveScans(String tserver)
           
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)
           
 BatchWriter MultiTableBatchWriterImpl.getBatchWriter(String tableName)
           
 List<DiskUsage> TableOperationsImpl.getDiskUsage(Set<String> tableNames)
           
 IteratorSetting TableOperationsHelper.getIteratorSetting(String tableName, String name, IteratorUtil.IteratorScope scope)
           
 IteratorSetting NamespaceOperationsHelper.getIteratorSetting(String namespace, String name, IteratorUtil.IteratorScope scope)
           
 Map<String,Set<org.apache.hadoop.io.Text>> TableOperationsImpl.getLocalityGroups(String tableName)
          Gets the locality groups currently set for a table.
 org.apache.hadoop.io.Text TableOperationsImpl.getMaxRow(String tableName, Authorizations auths, org.apache.hadoop.io.Text startRow, boolean startInclusive, org.apache.hadoop.io.Text endRow, boolean endInclusive)
           
 Iterable<Map.Entry<String,String>> TableOperationsImpl.getProperties(String tableName)
          Gets properties of a table
 Iterable<Map.Entry<String,String>> NamespaceOperationsImpl.getProperties(String namespace)
           
 Map<String,String> InstanceOperationsImpl.getSiteConfiguration()
           
 Map<String,String> InstanceOperationsImpl.getSystemConfiguration()
           
 Authorizations SecurityOperationsImpl.getUserAuthorizations(String principal)
           
 void SecurityOperationsImpl.grantNamespacePermission(String principal, String namespace, NamespacePermission permission)
           
 void SecurityOperationsImpl.grantSystemPermission(String principal, SystemPermission permission)
           
 void SecurityOperationsImpl.grantTablePermission(String principal, String table, TablePermission permission)
           
 boolean SecurityOperationsImpl.hasNamespacePermission(String principal, String namespace, NamespacePermission permission)
           
 boolean SecurityOperationsImpl.hasSystemPermission(String principal, SystemPermission perm)
           
 boolean SecurityOperationsImpl.hasTablePermission(String principal, String table, TablePermission perm)
           
 void TableOperationsImpl.importDirectory(String tableName, String dir, String failureDir, boolean setTime)
           
 void TableOperationsImpl.importTable(String tableName, String importDir)
           
 Map<String,Integer> TableOperationsHelper.listConstraints(String tableName)
           
 Map<String,Integer> NamespaceOperationsHelper.listConstraints(String namespace)
           
 Map<String,EnumSet<IteratorUtil.IteratorScope>> TableOperationsHelper.listIterators(String tableName)
           
 Map<String,EnumSet<IteratorUtil.IteratorScope>> NamespaceOperationsHelper.listIterators(String namespace)
           
 Set<String> SecurityOperationsImpl.listLocalUsers()
           
 Set<String> SecurityOperationsImpl.listUsers()
          Deprecated. 
 TabletLocator.TabletLocation TimeoutTabletLocator.locateTablet(Credentials credentials, org.apache.hadoop.io.Text row, boolean skipRow, boolean retry)
           
 TabletLocator.TabletLocation TabletLocatorImpl.locateTablet(Credentials credentials, org.apache.hadoop.io.Text row, boolean skipRow, boolean retry)
           
abstract  TabletLocator.TabletLocation TabletLocator.locateTablet(Credentials credentials, org.apache.hadoop.io.Text row, boolean skipRow, boolean retry)
           
 TabletLocator.TabletLocation RootTabletLocator.locateTablet(Credentials credentials, org.apache.hadoop.io.Text row, boolean skipRow, boolean retry)
           
 TabletLocator.TabletLocations TabletLocatorImpl.TabletLocationObtainer.lookupTablet(Credentials credentials, TabletLocator.TabletLocation src, org.apache.hadoop.io.Text row, org.apache.hadoop.io.Text stopRow, TabletLocator parent)
           
 List<TabletLocator.TabletLocation> TabletLocatorImpl.TabletLocationObtainer.lookupTablets(Credentials credentials, String tserver, Map<KeyExtent,List<Range>> map, TabletLocator parent)
           
 void TableOperationsImpl.merge(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end)
           
 void TableOperationsImpl.offline(String tableName)
           
 void TableOperationsImpl.offline(String tableName, boolean wait)
           
 void TableOperationsImpl.online(String tableName)
           
 void TableOperationsImpl.online(String tableName, boolean wait)
           
 void InstanceOperationsImpl.ping(String tserver)
           
 void TableOperationsHelper.removeConstraint(String tableName, int number)
           
 void NamespaceOperationsHelper.removeConstraint(String namespace, int number)
           
 void TableOperationsHelper.removeIterator(String tableName, String name, EnumSet<IteratorUtil.IteratorScope> scopes)
           
 void NamespaceOperationsHelper.removeIterator(String namespace, String name, EnumSet<IteratorUtil.IteratorScope> scopes)
           
 void InstanceOperationsImpl.removeProperty(String property)
           
 void TableOperationsImpl.removeProperty(String tableName, String property)
          Removes a property from a table
 void NamespaceOperationsImpl.removeProperty(String namespace, String property)
           
 void TableOperationsImpl.rename(String oldTableName, String newTableName)
          Rename a table
 void NamespaceOperationsImpl.rename(String oldNamespaceName, String newNamespaceName)
           
 void SecurityOperationsImpl.revokeNamespacePermission(String principal, String namespace, NamespacePermission permission)
           
 void SecurityOperationsImpl.revokeSystemPermission(String principal, SystemPermission permission)
           
 void SecurityOperationsImpl.revokeTablePermission(String principal, String table, TablePermission permission)
           
static List<KeyValue> ThriftScanner.scan(Instance instance, Credentials credentials, ThriftScanner.ScanState scanState, int timeOut, AccumuloConfiguration conf)
           
 void TableOperationsImpl.setLocalityGroups(String tableName, Map<String,Set<org.apache.hadoop.io.Text>> groups)
          Sets a tables locality groups.
 void InstanceOperationsImpl.setProperty(String property, String value)
           
 void TableOperationsImpl.setProperty(String tableName, String property, String value)
          Sets a property on a table
 void NamespaceOperationsImpl.setProperty(String namespace, String property, String value)
           
 Set<Range> TableOperationsImpl.splitRangeByTablets(String tableName, Range range, int maxSplits)
           
 boolean InstanceOperationsImpl.testClassLoad(String className, String asTypeName)
           
 boolean TableOperationsImpl.testClassLoad(String tableName, String className, String asTypeName)
           
 boolean NamespaceOperationsImpl.testClassLoad(String namespace, String className, String asTypeName)
           
 void Writer.update(Mutation m)
           
 

Constructors in org.apache.accumulo.core.client.impl that throw AccumuloException
ConnectorImpl(Instance instance, Credentials cred)
           
 

Uses of AccumuloException in org.apache.accumulo.core.client.mapred
 

Methods in org.apache.accumulo.core.client.mapred that throw AccumuloException
 void AccumuloOutputFormat.AccumuloRecordWriter.addTable(org.apache.hadoop.io.Text tableName)
           
 

Constructors in org.apache.accumulo.core.client.mapred that throw AccumuloException
AccumuloOutputFormat.AccumuloRecordWriter(org.apache.hadoop.mapred.JobConf job)
           
 

Uses of AccumuloException in org.apache.accumulo.core.client.mapreduce
 

Methods in org.apache.accumulo.core.client.mapreduce that throw AccumuloException
 void AccumuloOutputFormat.AccumuloRecordWriter.addTable(org.apache.hadoop.io.Text tableName)
           
 

Constructors in org.apache.accumulo.core.client.mapreduce that throw AccumuloException
AccumuloOutputFormat.AccumuloRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context)
           
 

Uses of AccumuloException in org.apache.accumulo.core.client.mapreduce.lib.impl
 

Methods in org.apache.accumulo.core.client.mapreduce.lib.impl that throw AccumuloException
static Map<String,Map<KeyExtent,List<Range>>> InputConfigurator.binOffline(String tableId, List<Range> ranges, Instance instance, Connector conn)
           
 

Uses of AccumuloException in org.apache.accumulo.core.client.mock
 

Methods in org.apache.accumulo.core.client.mock that throw AccumuloException
<T extends Mutation>
void
MockTabletLocator.binMutations(List<T> mutations, Map<String,TabletLocator.TabletServerMutations<T>> binnedMutations, List<T> failures, TCredentials credentials)
          Deprecated.  
 List<Range> MockTabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges, TCredentials credentials)
          Deprecated.  
 BatchWriter MockMultiTableBatchWriter.getBatchWriter(String table)
           
 Connector MockInstance.getConnector(String principal, AuthenticationToken token)
           
 Connector MockInstance.getConnector(String user, byte[] pass)
          Deprecated. 
 Connector MockInstance.getConnector(String user, ByteBuffer pass)
          Deprecated. 
 Connector MockInstance.getConnector(String user, CharSequence pass)
          Deprecated. 
 TabletLocator.TabletLocation MockTabletLocator.locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry, TCredentials credentials)
          Deprecated.  
 

Uses of AccumuloException in org.apache.accumulo.core.client.mock.impl
 

Methods in org.apache.accumulo.core.client.mock.impl that throw AccumuloException
<T extends Mutation>
void
MockTabletLocator.binMutations(Credentials credentials, List<T> mutations, Map<String,TabletLocator.TabletServerMutations<T>> binnedMutations, List<T> failures)
           
 List<Range> MockTabletLocator.binRanges(Credentials credentials, List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 TabletLocator.TabletLocation MockTabletLocator.locateTablet(Credentials credentials, org.apache.hadoop.io.Text row, boolean skipRow, boolean retry)
           
 

Uses of AccumuloException in org.apache.accumulo.core.conf
 

Methods in org.apache.accumulo.core.conf that throw AccumuloException
static AccumuloConfiguration AccumuloConfiguration.getTableConfiguration(Connector conn, String tableId)
           
 

Uses of AccumuloException in org.apache.accumulo.core.metadata
 

Methods in org.apache.accumulo.core.metadata that throw AccumuloException
static MetadataServicer MetadataServicer.forTableName(Instance instance, Credentials credentials, String tableName)
           
abstract  void MetadataServicer.getTabletLocations(SortedMap<KeyExtent,String> tablets)
          Populate the provided data structure with the known tablets for the table being serviced
 TabletLocator.TabletLocations MetadataLocationObtainer.lookupTablet(Credentials credentials, TabletLocator.TabletLocation src, org.apache.hadoop.io.Text row, org.apache.hadoop.io.Text stopRow, TabletLocator parent)
           
 List<TabletLocator.TabletLocation> MetadataLocationObtainer.lookupTablets(Credentials credentials, String tserver, Map<KeyExtent,List<Range>> tabletsRanges, TabletLocator parent)
           
 

Uses of AccumuloException in org.apache.accumulo.core.util
 

Subclasses of AccumuloException in org.apache.accumulo.core.util
static class LocalityGroupUtil.LocalityGroupConfigurationError
           
 

Methods in org.apache.accumulo.core.util that throw AccumuloException
static void ThriftUtil.execute(String address, AccumuloConfiguration conf, ClientExec<TabletClientService.Client> exec)
           
static
<T> T
ThriftUtil.execute(String address, AccumuloConfiguration conf, ClientExecReturn<T,TabletClientService.Client> exec)
           
 

Uses of AccumuloException in org.apache.accumulo.core.util.shell
 

Methods in org.apache.accumulo.core.util.shell that throw AccumuloException
 ClassLoader Shell.getClassLoader(org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 void Shell.updateUser(String principal, AuthenticationToken token)
           
 

Uses of AccumuloException in org.apache.accumulo.core.util.shell.commands
 

Methods in org.apache.accumulo.core.util.shell.commands that throw AccumuloException
protected  void OnlineCommand.doTableOp(Shell shellState, String tableName)
           
protected  void OfflineCommand.doTableOp(Shell shellState, String tableName)
           
protected  void FlushCommand.doTableOp(Shell shellState, String tableName)
           
protected  void CompactCommand.doTableOp(Shell shellState, String tableName)
           
 int UsersCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int UserPermissionsCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int UserCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int TablesCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int TableCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int SetShellIterCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int SetScanIterCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int SetIterCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int SetAuthsCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int RenameTableCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int RenameNamespaceCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int PasswdCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int NamespacesCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int InsertCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int ImportTableCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int ImportDirectoryCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int GetSplitsCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int GetAuthsCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int ExportTableCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int DropUserCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int DeleteCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int CreateUserCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int CreateTableCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int CreateNamespaceCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int ConfigCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int CloneTableCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int AuthenticateCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int AddAuthsCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
protected  Authorizations ScanCommand.getAuths(org.apache.commons.cli.CommandLine cl, Shell shellState)
           
static String OptUtil.getNamespaceOpt(org.apache.commons.cli.CommandLine cl, Shell shellState)
           
protected  void ShellPluginConfigurationCommand.removePlugin(org.apache.commons.cli.CommandLine cl, Shell shellState, String tableName)
           
protected  void FormatterCommand.removePlugin(org.apache.commons.cli.CommandLine cl, Shell shellState, String tableName)
           
protected  void SetIterCommand.setNamespaceProperties(org.apache.commons.cli.CommandLine cl, Shell shellState, int priority, Map<String,String> options, String classname, String name)
           
protected  void ShellPluginConfigurationCommand.setPlugin(org.apache.commons.cli.CommandLine cl, Shell shellState, String tableName, String className)
           
protected  void FormatterCommand.setPlugin(org.apache.commons.cli.CommandLine cl, Shell shellState, String tableName, String className)
           
protected  void SetShellIterCommand.setTableProperties(org.apache.commons.cli.CommandLine cl, Shell shellState, int priority, Map<String,String> options, String classname, String name)
           
protected  void SetScanIterCommand.setTableProperties(org.apache.commons.cli.CommandLine cl, Shell shellState, int priority, Map<String,String> options, String classname, String name)
           
protected  void SetIterCommand.setTableProperties(org.apache.commons.cli.CommandLine cl, Shell shellState, int priority, Map<String,String> options, String classname, String name)
           
 



Copyright © 2015 Apache Accumulo Project. All rights reserved.