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

Packages that use AccumuloSecurityException
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.util 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.security   
org.apache.accumulo.core.util   
org.apache.accumulo.core.util.shell   
org.apache.accumulo.core.util.shell.commands   
org.apache.accumulo.examples.simple.client   
org.apache.accumulo.examples.simple.dirlist   
org.apache.accumulo.examples.simple.filedata   
org.apache.accumulo.examples.simple.helloworld   
org.apache.accumulo.examples.simple.mapreduce   
org.apache.accumulo.examples.simple.mapreduce.bulk   
org.apache.accumulo.server.client   
org.apache.accumulo.server.master   
org.apache.accumulo.server.security   
org.apache.accumulo.server.security.handler   
org.apache.accumulo.server.tabletserver   
org.apache.accumulo.server.util   
org.apache.accumulo.test   
org.apache.accumulo.test.continuous   
org.apache.accumulo.test.functional   
org.apache.accumulo.test.randomwalk   
org.apache.accumulo.test.randomwalk.security   
org.apache.accumulo.test.scalability   
 

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

Methods in org.apache.accumulo.core.cli that throw AccumuloSecurityException
 Connector ClientOpts.getConnector()
           
 void ClientOnRequiredTable.setAccumuloConfigs(org.apache.hadoop.mapreduce.Job job)
           
 void ClientOpts.setAccumuloConfigs(org.apache.hadoop.mapreduce.Job job)
           
 void ClientOnDefaultTable.setAccumuloConfigs(org.apache.hadoop.mapreduce.Job job)
           
 

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

Methods in org.apache.accumulo.core.client that throw AccumuloSecurityException
 BatchWriter MultiTableBatchWriter.getBatchWriter(String table)
          Returns a BatchWriter for a particular table.
 Connector Instance.getConnector(AuthInfo auth)
          Deprecated. since 1.5, use Instance.getConnector(String, AuthenticationToken) with PasswordToken
 Connector ZooKeeperInstance.getConnector(AuthInfo auth)
          Deprecated. 
 Connector Instance.getConnector(String principal, AuthenticationToken token)
          Returns a connection to this instance of accumulo.
 Connector ZooKeeperInstance.getConnector(String principal, AuthenticationToken token)
           
 Connector Instance.getConnector(String user, byte[] pass)
          Deprecated. since 1.5, use Instance.getConnector(String, AuthenticationToken) with PasswordToken
 Connector ZooKeeperInstance.getConnector(String principal, byte[] 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, ByteBuffer pass)
          Deprecated. 
 Connector Instance.getConnector(String user, CharSequence pass)
          Deprecated. since 1.5, use Instance.getConnector(String, AuthenticationToken) with PasswordToken
 Connector ZooKeeperInstance.getConnector(String user, CharSequence pass)
          Deprecated. 
 

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

Methods in org.apache.accumulo.core.client.admin that throw AccumuloSecurityException
 int TableOperationsHelper.addConstraint(String tableName, String constraintClassName)
           
 int TableOperationsImpl.addConstraint(String tableName, String constraintClassName)
           
 int TableOperations.addConstraint(String tableName, String constraintClassName)
          Add a new constraint to a table.
 void TableOperationsImpl.addSplits(String tableName, SortedSet<org.apache.hadoop.io.Text> partitionKeys)
           
 void TableOperations.addSplits(String tableName, SortedSet<org.apache.hadoop.io.Text> partitionKeys)
           
 void TableOperationsHelper.attachIterator(String tableName, IteratorSetting setting)
           
 void TableOperations.attachIterator(String tableName, IteratorSetting setting)
          Add an iterator to a table on all scopes.
 void TableOperationsHelper.attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
           
 void TableOperationsImpl.attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
           
 void TableOperations.attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
          Add an iterator to a table on the given scopes.
 boolean SecurityOperationsImpl.authenticateUser(String principal, AuthenticationToken token)
           
 boolean SecurityOperations.authenticateUser(String principal, AuthenticationToken token)
          Verify a username/password combination is valid
 boolean SecurityOperationsImpl.authenticateUser(String user, byte[] password)
          Deprecated. 
 boolean SecurityOperations.authenticateUser(String user, byte[] password)
          Deprecated. since 1.5.0; use SecurityOperations.authenticateUser(String, AuthenticationToken) instead.
 void TableOperationsImpl.cancelCompaction(String tableName)
           
 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 SecurityOperationsImpl.changeLocalUserPassword(String principal, PasswordToken token)
           
 void SecurityOperations.changeLocalUserPassword(String principal, PasswordToken token)
          Set the user's password
 void SecurityOperationsImpl.changeUserAuthorizations(String principal, Authorizations authorizations)
           
 void SecurityOperations.changeUserAuthorizations(String principal, Authorizations authorizations)
          Set the user's record-level authorizations
 void SecurityOperationsImpl.changeUserPassword(String user, byte[] password)
          Deprecated. 
 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 TableOperationsImpl.clone(String srcTableName, String newTableName, boolean flush, Map<String,String> propertiesToSet, Set<String> propertiesToExclude)
           
 void TableOperations.clone(String srcTableName, String newTableName, boolean flush, Map<String,String> propertiesToSet, Set<String> propertiesToExclude)
          Clone a table from an existing table.
 void TableOperationsImpl.compact(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end, boolean flush, boolean wait)
           
 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 TableOperationsImpl.compact(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end, List<IteratorSetting> iterators, boolean flush, boolean wait)
           
 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 TableOperationsImpl.create(String tableName)
          Create a table with no special configuration
 void TableOperations.create(String tableName)
          Create a table with no special configuration
 void TableOperationsImpl.create(String tableName, boolean limitVersion)
           
 void TableOperations.create(String tableName, boolean limitVersion)
           
 void TableOperationsImpl.create(String tableName, boolean limitVersion, TimeType timeType)
           
 void TableOperations.create(String tableName, boolean versioningIter, TimeType timeType)
           
 void SecurityOperationsImpl.createLocalUser(String principal, PasswordToken password)
           
 void SecurityOperations.createLocalUser(String principal, PasswordToken password)
          Create a user
 void SecurityOperationsImpl.createUser(String user, byte[] password, Authorizations authorizations)
          Deprecated. 
 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 TableOperationsImpl.delete(String tableName)
          Delete a table
 void TableOperations.delete(String tableName)
          Delete a table
 void TableOperationsImpl.deleteRows(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end)
           
 void TableOperations.deleteRows(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end)
          Delete rows between (start, end]
 void SecurityOperationsImpl.dropLocalUser(String principal)
           
 void SecurityOperations.dropLocalUser(String principal)
          Delete a user
 void SecurityOperationsImpl.dropUser(String user)
          Deprecated. 
 void SecurityOperations.dropUser(String user)
          Deprecated. since 1.5.0; use SecurityOperations.dropUser(String) or the user management functions of your configured authenticator instead.
 void TableOperationsImpl.exportTable(String tableName, String exportDir)
           
 void TableOperations.exportTable(String tableName, String exportDir)
          Exports a table.
 void TableOperationsImpl.flush(String tableName)
          Deprecated. since 1.4 TableOperationsImpl.flush(String, Text, Text, boolean)
 void TableOperations.flush(String tableName)
          Deprecated. As of release 1.4, replaced by TableOperations.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
 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<ActiveCompaction> InstanceOperationsImpl.getActiveCompactions(String tserver)
           
 List<ActiveScan> InstanceOperations.getActiveScans(String tserver)
          List the active scans on tablet server.
 List<ActiveScan> InstanceOperationsImpl.getActiveScans(String tserver)
           
 IteratorSetting TableOperationsHelper.getIteratorSetting(String tableName, String name, IteratorUtil.IteratorScope scope)
           
 IteratorSetting TableOperations.getIteratorSetting(String tableName, String name, IteratorUtil.IteratorScope scope)
          Get the settings for an iterator.
 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)
           
 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.
 Map<String,String> InstanceOperations.getSiteConfiguration()
           
 Map<String,String> InstanceOperationsImpl.getSiteConfiguration()
           
 Map<String,String> InstanceOperations.getSystemConfiguration()
           
 Map<String,String> InstanceOperationsImpl.getSystemConfiguration()
           
 Authorizations SecurityOperationsImpl.getUserAuthorizations(String principal)
           
 Authorizations SecurityOperations.getUserAuthorizations(String principal)
          Retrieves the user's authorizations for scanning
 void SecurityOperationsImpl.grantSystemPermission(String principal, SystemPermission permission)
           
 void SecurityOperations.grantSystemPermission(String principal, SystemPermission permission)
          Grant a user a system permission
 void SecurityOperationsImpl.grantTablePermission(String principal, String table, TablePermission permission)
           
 void SecurityOperations.grantTablePermission(String principal, String table, TablePermission permission)
          Grant a user a specific permission for a specific table
 boolean SecurityOperationsImpl.hasSystemPermission(String principal, SystemPermission perm)
           
 boolean SecurityOperations.hasSystemPermission(String principal, SystemPermission perm)
          Verify the user has a particular system permission
 boolean SecurityOperationsImpl.hasTablePermission(String principal, String table, TablePermission perm)
           
 boolean SecurityOperations.hasTablePermission(String principal, String table, TablePermission perm)
          Verify the user has a particular table permission
 void TableOperationsImpl.importDirectory(String tableName, String dir, String failureDir, boolean setTime)
           
 void TableOperations.importDirectory(String tableName, String dir, String failureDir, boolean setTime)
          Bulk import all the files in a directory into a table.
 void TableOperationsImpl.importTable(String tableName, String importDir)
           
 void TableOperations.importTable(String tableName, String importDir)
          Imports a table exported via exportTable and copied via hadoop distcp.
 Map<String,EnumSet<IteratorUtil.IteratorScope>> TableOperationsHelper.listIterators(String tableName)
           
 Map<String,EnumSet<IteratorUtil.IteratorScope>> TableOperations.listIterators(String tableName)
          Get a list of iterators for this table.
 Set<String> SecurityOperationsImpl.listLocalUsers()
           
 Set<String> SecurityOperations.listLocalUsers()
          Return a list of users in accumulo
 Collection<org.apache.hadoop.io.Text> TableOperationsImpl.listSplits(String tableName)
           
 Collection<org.apache.hadoop.io.Text> TableOperations.listSplits(String tableName)
           
 Collection<org.apache.hadoop.io.Text> TableOperationsImpl.listSplits(String tableName, int maxSplits)
           
 Collection<org.apache.hadoop.io.Text> TableOperations.listSplits(String tableName, int maxSplits)
           
 Set<String> SecurityOperationsImpl.listUsers()
          Deprecated. 
 Set<String> SecurityOperations.listUsers()
          Deprecated. since 1.5.0; use SecurityOperations.listLocalUsers() or the user management functions of your configured authenticator instead.
 void TableOperationsImpl.merge(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end)
           
 void TableOperations.merge(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end)
          Merge tablets between (start, end]
 void TableOperationsImpl.offline(String tableName)
           
 void TableOperations.offline(String tableName)
           
 void TableOperationsImpl.online(String tableName)
           
 void TableOperations.online(String tableName)
           
 void TableOperationsHelper.removeConstraint(String tableName, int number)
           
 void TableOperations.removeConstraint(String tableName, int number)
          Remove a constraint from a table.
 void TableOperationsHelper.removeIterator(String tableName, String name, EnumSet<IteratorUtil.IteratorScope> scopes)
           
 void TableOperations.removeIterator(String tableName, String name, EnumSet<IteratorUtil.IteratorScope> scopes)
          Remove an iterator from a table by name.
 void InstanceOperations.removeProperty(String property)
          Removes a instance property from zookeeper
 void InstanceOperationsImpl.removeProperty(String property)
           
 void TableOperationsImpl.removeProperty(String tableName, String property)
          Removes a property from a table
 void TableOperations.removeProperty(String tableName, String property)
          Removes a property from a table.
 void TableOperationsImpl.rename(String oldTableName, String newTableName)
          Rename a table
 void TableOperations.rename(String oldTableName, String newTableName)
          Rename a table
 void SecurityOperationsImpl.revokeSystemPermission(String principal, SystemPermission permission)
           
 void SecurityOperations.revokeSystemPermission(String principal, SystemPermission permission)
          Revoke a system permission from a user
 void SecurityOperationsImpl.revokeTablePermission(String principal, String table, TablePermission permission)
           
 void SecurityOperations.revokeTablePermission(String principal, String table, TablePermission permission)
          Revoke a table permission for a specific user on a specific table
 void TableOperationsImpl.setLocalityGroups(String tableName, Map<String,Set<org.apache.hadoop.io.Text>> groups)
          Sets a tables locality groups.
 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 instance property in zookeeper.
 void InstanceOperationsImpl.setProperty(String property, String value)
           
 void TableOperationsImpl.setProperty(String tableName, String property, String value)
          Sets a property on a table
 void TableOperations.setProperty(String tableName, String property, String value)
          Sets a property on a table.
 Set<Range> TableOperationsImpl.splitRangeByTablets(String tableName, Range range, int maxSplits)
           
 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 InstanceOperationsImpl.testClassLoad(String className, String asTypeName)
           
 boolean TableOperationsImpl.testClassLoad(String tableName, String className, String asTypeName)
           
 boolean TableOperations.testClassLoad(String tableName, String className, String asTypeName)
          Test to see if the instance can load the given class as the given type.
 

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

Methods in org.apache.accumulo.core.client.impl that throw AccumuloSecurityException
protected  TabletLocator.TabletLocation TabletLocatorImpl._locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry, boolean lock, TCredentials credentials)
           
 void RootTabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
 void TabletLocatorImpl.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
abstract  void TabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
 void TimeoutTabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
 List<Range> RootTabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges, TCredentials credentials)
           
 List<Range> TabletLocatorImpl.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges, TCredentials credentials)
           
abstract  List<Range> TabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges, TCredentials credentials)
           
 List<Range> TimeoutTabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges, TCredentials credentials)
           
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)
           
 BatchWriter MultiTableBatchWriterImpl.getBatchWriter(String tableName)
           
 TabletLocator.TabletLocation RootTabletLocator.locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry, TCredentials credentials)
           
 TabletLocator.TabletLocation TabletLocatorImpl.locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry, TCredentials credentials)
           
abstract  TabletLocator.TabletLocation TabletLocator.locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry, TCredentials credentials)
           
 TabletLocator.TabletLocation TimeoutTabletLocator.locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry, TCredentials credentials)
           
 TabletLocator.TabletLocations TabletLocatorImpl.TabletLocationObtainer.lookupTablet(TabletLocator.TabletLocation src, org.apache.hadoop.io.Text row, org.apache.hadoop.io.Text stopRow, TabletLocator parent, TCredentials credentials)
           
 TabletLocator.TabletLocations MetadataLocationObtainer.lookupTablet(TabletLocator.TabletLocation src, org.apache.hadoop.io.Text row, org.apache.hadoop.io.Text stopRow, TabletLocator parent, TCredentials credentials)
           
 List<TabletLocator.TabletLocation> TabletLocatorImpl.TabletLocationObtainer.lookupTablets(String tserver, Map<KeyExtent,List<Range>> map, TabletLocator parent, TCredentials credentials)
           
 List<TabletLocator.TabletLocation> MetadataLocationObtainer.lookupTablets(String tserver, Map<KeyExtent,List<Range>> tabletsRanges, TabletLocator parent, TCredentials credentials)
           
static List<KeyValue> ThriftScanner.scan(Instance instance, TCredentials credentials, ThriftScanner.ScanState scanState, int timeOut, AccumuloConfiguration conf)
           
 void Writer.update(Mutation m)
           
 

Constructors in org.apache.accumulo.core.client.impl that throw AccumuloSecurityException
ConnectorImpl(Instance instance, TCredentials cred)
          Deprecated. 
 

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

Methods in org.apache.accumulo.core.client.mapred that throw AccumuloSecurityException
 void AccumuloOutputFormat.AccumuloRecordWriter.addTable(org.apache.hadoop.io.Text tableName)
           
static void AccumuloOutputFormat.setConnectorInfo(org.apache.hadoop.mapred.JobConf job, String principal, AuthenticationToken token)
          Sets the connector information needed to communicate with Accumulo in this job.
static void InputFormatBase.setConnectorInfo(org.apache.hadoop.mapred.JobConf job, String principal, AuthenticationToken token)
          Sets the connector information needed to communicate with Accumulo in this job.
 

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

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

Methods in org.apache.accumulo.core.client.mapreduce that throw AccumuloSecurityException
 void AccumuloOutputFormat.AccumuloRecordWriter.addTable(org.apache.hadoop.io.Text tableName)
           
static void AccumuloOutputFormat.setConnectorInfo(org.apache.hadoop.mapreduce.Job job, String principal, AuthenticationToken token)
          Sets the connector information needed to communicate with Accumulo in this job.
static void InputFormatBase.setConnectorInfo(org.apache.hadoop.mapreduce.Job job, String principal, AuthenticationToken token)
          Sets the connector information needed to communicate with Accumulo in this job.
 

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

Uses of AccumuloSecurityException in org.apache.accumulo.core.client.mapreduce.lib.util
 

Methods in org.apache.accumulo.core.client.mapreduce.lib.util that throw AccumuloSecurityException
static void ConfiguratorBase.setConnectorInfo(Class<?> implementingClass, org.apache.hadoop.conf.Configuration conf, String principal, AuthenticationToken token)
          Sets the connector information needed to communicate with Accumulo in this job.
 

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

Methods in org.apache.accumulo.core.client.mock that throw AccumuloSecurityException
 void MockTableOperations.addSplits(String tableName, SortedSet<org.apache.hadoop.io.Text> partitionKeys)
           
 boolean MockSecurityOperations.authenticateUser(String principal, AuthenticationToken token)
           
 boolean MockSecurityOperations.authenticateUser(String user, byte[] password)
          Deprecated. 
 void MockTabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures, TCredentials credentials)
           
 List<Range> MockTabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges, TCredentials credentials)
           
 void MockTableOperations.cancelCompaction(String tableName)
           
 void MockSecurityOperations.changeLocalUserPassword(String principal, PasswordToken token)
           
 void MockSecurityOperations.changeUserAuthorizations(String principal, Authorizations authorizations)
           
 void MockSecurityOperations.changeUserPassword(String user, byte[] password)
          Deprecated. 
 void MockTableOperations.clone(String srcTableName, String newTableName, boolean flush, Map<String,String> propertiesToSet, Set<String> propertiesToExclude)
           
 void MockTableOperations.compact(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end, boolean flush, boolean wait)
           
 void MockTableOperations.compact(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end, List<IteratorSetting> iterators, boolean flush, boolean wait)
           
 void MockTableOperations.create(String tableName)
           
 void MockTableOperations.create(String tableName, boolean versioningIter)
           
 void MockTableOperations.create(String tableName, boolean versioningIter, TimeType timeType)
           
 void MockSecurityOperations.createLocalUser(String principal, PasswordToken password)
           
 void MockSecurityOperations.createUser(String user, byte[] password, Authorizations authorizations)
          Deprecated. 
 void MockTableOperations.delete(String tableName)
           
 void MockTableOperations.deleteRows(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end)
           
 void MockSecurityOperations.dropLocalUser(String principal)
           
 void MockSecurityOperations.dropUser(String user)
          Deprecated. 
 void MockTableOperations.exportTable(String tableName, String exportDir)
           
 void MockTableOperations.flush(String tableName)
          Deprecated. 
 void MockTableOperations.flush(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end, boolean wait)
           
 List<ActiveCompaction> MockInstanceOperations.getActiveCompactions(String tserver)
           
 List<ActiveScan> MockInstanceOperations.getActiveScans(String tserver)
           
 BatchWriter MockMultiTableBatchWriter.getBatchWriter(String table)
           
 Connector MockInstance.getConnector(AuthInfo auth)
          Deprecated. 
 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. 
 org.apache.hadoop.io.Text MockTableOperations.getMaxRow(String tableName, Authorizations auths, org.apache.hadoop.io.Text startRow, boolean startInclusive, org.apache.hadoop.io.Text endRow, boolean endInclusive)
           
 Map<String,String> MockInstanceOperations.getSiteConfiguration()
           
 Map<String,String> MockInstanceOperations.getSystemConfiguration()
           
 Authorizations MockSecurityOperations.getUserAuthorizations(String principal)
           
 void MockSecurityOperations.grantSystemPermission(String principal, SystemPermission permission)
           
 void MockSecurityOperations.grantTablePermission(String principal, String tableName, TablePermission permission)
           
 boolean MockSecurityOperations.hasSystemPermission(String principal, SystemPermission perm)
           
 boolean MockSecurityOperations.hasTablePermission(String principal, String tableName, TablePermission perm)
           
 void MockTableOperations.importDirectory(String tableName, String dir, String failureDir, boolean setTime)
           
 void MockTableOperations.importTable(String tableName, String exportDir)
           
 Set<String> MockSecurityOperations.listLocalUsers()
           
 Set<String> MockSecurityOperations.listUsers()
          Deprecated. 
 TabletLocator.TabletLocation MockTabletLocator.locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry, TCredentials credentials)
           
 void MockTableOperations.merge(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end)
           
 void MockTableOperations.offline(String tableName)
           
 void MockTableOperations.online(String tableName)
           
 void MockInstanceOperations.removeProperty(String property)
           
 void MockTableOperations.removeProperty(String tableName, String property)
           
 void MockTableOperations.rename(String oldTableName, String newTableName)
           
 void MockSecurityOperations.revokeSystemPermission(String principal, SystemPermission permission)
           
 void MockSecurityOperations.revokeTablePermission(String principal, String tableName, TablePermission permission)
           
 void MockTableOperations.setLocalityGroups(String tableName, Map<String,Set<org.apache.hadoop.io.Text>> groups)
           
 void MockInstanceOperations.setProperty(String property, String value)
           
 void MockTableOperations.setProperty(String tableName, String property, String value)
           
 Set<Range> MockTableOperations.splitRangeByTablets(String tableName, Range range, int maxSplits)
           
 boolean MockInstanceOperations.testClassLoad(String className, String asTypeName)
           
 boolean MockTableOperations.testClassLoad(String tableName, String className, String asTypeName)
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.core.security
 

Methods in org.apache.accumulo.core.security that throw AccumuloSecurityException
static String CredentialHelper.asBase64String(TCredentials cred)
           
static byte[] CredentialHelper.asByteArray(TCredentials cred)
           
static TCredentials CredentialHelper.create(String principal, AuthenticationToken token, String instanceID)
           
static AuthenticationToken CredentialHelper.extractToken(String tokenClass, byte[] token)
           
static AuthenticationToken CredentialHelper.extractToken(TCredentials toAuth)
           
static TCredentials CredentialHelper.fromBase64String(String string)
           
static TCredentials CredentialHelper.fromByteArray(byte[] serializedCredential)
           
static String CredentialHelper.tokenAsBase64(AuthenticationToken token)
           
 

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

Methods in org.apache.accumulo.core.util that throw AccumuloSecurityException
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)
           
static void MetadataTable.getEntries(Instance instance, TCredentials credentials, String table, boolean isTid, Map<KeyExtent,String> locations, SortedSet<KeyExtent> tablets)
           
 

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

Methods in org.apache.accumulo.core.util.shell that throw AccumuloSecurityException
 void Shell.updateUser(String principal, AuthenticationToken token)
           
 

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

Methods in org.apache.accumulo.core.util.shell.commands that throw AccumuloSecurityException
protected  void FlushCommand.doTableOp(Shell shellState, String tableName)
           
protected  void OfflineCommand.doTableOp(Shell shellState, String tableName)
           
protected  void CompactCommand.doTableOp(Shell shellState, String tableName)
           
protected  void OnlineCommand.doTableOp(Shell shellState, String tableName)
           
 int SetIterCommand.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 UsersCommand.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 PasswdCommand.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 DropUserCommand.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 SetScanIterCommand.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 DeleteCommand.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 ImportDirectoryCommand.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 SetShellIterCommand.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 CreateUserCommand.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 RenameTableCommand.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 AddAuthsCommand.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 SetAuthsCommand.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 ExportTableCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
protected  Authorizations ScanCommand.getAuths(org.apache.commons.cli.CommandLine cl, Shell shellState)
           
protected  void FormatterCommand.removePlugin(org.apache.commons.cli.CommandLine cl, Shell shellState, String tableName)
           
protected  void ShellPluginConfigurationCommand.removePlugin(org.apache.commons.cli.CommandLine cl, Shell shellState, String tableName)
           
protected  void FormatterCommand.setPlugin(org.apache.commons.cli.CommandLine cl, Shell shellState, String tableName, String className)
           
protected  void ShellPluginConfigurationCommand.setPlugin(org.apache.commons.cli.CommandLine cl, Shell shellState, String tableName, String className)
           
protected  void SetIterCommand.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 SetShellIterCommand.setTableProperties(org.apache.commons.cli.CommandLine cl, Shell shellState, int priority, Map<String,String> options, String classname, String name)
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.examples.simple.client
 

Methods in org.apache.accumulo.examples.simple.client that throw AccumuloSecurityException
static void SequentialBatchWriter.main(String[] args)
          Writes a specified number of entries to Accumulo using a BatchWriter.
static void RandomBatchWriter.main(String[] args)
          Writes a specified number of entries to Accumulo using a BatchWriter.
static void RowOperations.main(String[] args)
           
static void RandomBatchScanner.main(String[] args)
          Scans over a specified number of entries to Accumulo using a BatchScanner.
 

Uses of AccumuloSecurityException in org.apache.accumulo.examples.simple.dirlist
 

Constructors in org.apache.accumulo.examples.simple.dirlist that throw AccumuloSecurityException
QueryUtil(QueryUtil.Opts opts)
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.examples.simple.filedata
 

Constructors in org.apache.accumulo.examples.simple.filedata that throw AccumuloSecurityException
FileDataQuery(String instanceName, String zooKeepers, String user, AuthenticationToken token, String tableName, Authorizations auths)
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.examples.simple.helloworld
 

Methods in org.apache.accumulo.examples.simple.helloworld that throw AccumuloSecurityException
static void ReadData.main(String[] args)
           
static void InsertWithBatchWriter.main(String[] args)
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.examples.simple.mapreduce
 

Methods in org.apache.accumulo.examples.simple.mapreduce that throw AccumuloSecurityException
 int TableToFile.run(String[] args)
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.examples.simple.mapreduce.bulk
 

Methods in org.apache.accumulo.examples.simple.mapreduce.bulk that throw AccumuloSecurityException
static void VerifyIngest.main(String[] args)
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.server.client
 

Methods in org.apache.accumulo.server.client that throw AccumuloSecurityException
static List<String> BulkImporter.bulkLoad(AccumuloConfiguration conf, Instance instance, TCredentials creds, long tid, String tableId, List<String> files, String errorDir, boolean setTime)
           
 Connector HdfsZooInstance.getConnector(AuthInfo auth)
          Deprecated. 
 Connector HdfsZooInstance.getConnector(String principal, AuthenticationToken token)
           
 Connector HdfsZooInstance.getConnector(String user, byte[] pass)
           
 Connector HdfsZooInstance.getConnector(String user, ByteBuffer pass)
           
 Connector HdfsZooInstance.getConnector(String user, CharSequence pass)
           
 BulkImporter.AssignmentStats BulkImporter.importFiles(List<String> files, org.apache.hadoop.fs.Path failureDir)
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.server.master
 

Methods in org.apache.accumulo.server.master that throw AccumuloSecurityException
 Connector Master.getConnector()
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.server.security
 

Methods in org.apache.accumulo.server.security that throw AccumuloSecurityException
 void SecurityOperation.initializeSecurity(TCredentials credentials, String rootPrincipal, byte[] token)
           
 void AuditedSecurityOperation.initializeSecurity(TCredentials credentials, String principal, byte[] token)
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.server.security.handler
 

Methods in org.apache.accumulo.server.security.handler that throw AccumuloSecurityException
 boolean Authenticator.authenticateUser(String principal, AuthenticationToken token)
           
 boolean ZKAuthenticator.authenticateUser(String principal, AuthenticationToken token)
           
 void Authorizor.changeAuthorizations(String user, Authorizations authorizations)
          Used to change the authorizations for the user
 void ZKAuthorizor.changeAuthorizations(String user, Authorizations authorizations)
           
 void Authenticator.changePassword(String principal, AuthenticationToken token)
           
 void ZKAuthenticator.changePassword(String principal, AuthenticationToken token)
           
 void InsecureAuthenticator.changePassword(String user, AuthenticationToken token)
           
 void ZKPermHandler.cleanTablePermissions(String table)
           
 void InsecurePermHandler.cleanTablePermissions(String table)
           
 void PermissionHandler.cleanTablePermissions(String table)
          Cleans up the permissions for a table.
 void ZKPermHandler.cleanUser(String user)
           
 void InsecurePermHandler.cleanUser(String user)
           
 void PermissionHandler.cleanUser(String user)
          Deletes a user
 void Authenticator.createUser(String principal, AuthenticationToken token)
           
 void ZKAuthenticator.createUser(String principal, AuthenticationToken token)
          Creates a user with no permissions whatsoever
 void InsecureAuthenticator.createUser(String principal, AuthenticationToken token)
           
 void Authenticator.dropUser(String user)
           
 void Authorizor.dropUser(String user)
          Deletes a user
 void ZKAuthenticator.dropUser(String user)
           
 void ZKAuthorizor.dropUser(String user)
           
 void InsecureAuthenticator.dropUser(String user)
           
 Authorizations Authorizor.getCachedUserAuthorizations(String user)
          Used to get the authorizations for the user
 void ZKPermHandler.grantSystemPermission(String user, SystemPermission permission)
           
 void InsecurePermHandler.grantSystemPermission(String user, SystemPermission permission)
           
 void PermissionHandler.grantSystemPermission(String user, SystemPermission permission)
          Gives the user the given system permission
 void ZKPermHandler.grantTablePermission(String user, String table, TablePermission permission)
           
 void InsecurePermHandler.grantTablePermission(String user, String table, TablePermission permission)
           
 void PermissionHandler.grantTablePermission(String user, String table, TablePermission permission)
          Gives the user the given table permission
 boolean ZKPermHandler.hasCachedSystemPermission(String user, SystemPermission permission)
           
 boolean InsecurePermHandler.hasCachedSystemPermission(String user, SystemPermission permission)
           
 boolean PermissionHandler.hasCachedSystemPermission(String user, SystemPermission permission)
          Used to get the system permission for the user, with caching due to high frequency operation.
 boolean ZKPermHandler.hasCachedTablePermission(String user, String table, TablePermission permission)
           
 boolean InsecurePermHandler.hasCachedTablePermission(String user, String table, TablePermission permission)
           
 boolean PermissionHandler.hasCachedTablePermission(String user, String table, TablePermission permission)
          Used to get the table permission of a user for a table, with caching.
 boolean ZKPermHandler.hasSystemPermission(String user, SystemPermission permission)
           
 boolean InsecurePermHandler.hasSystemPermission(String user, SystemPermission permission)
           
 boolean PermissionHandler.hasSystemPermission(String user, SystemPermission permission)
          Used to get the system permission for the user
 boolean InsecurePermHandler.hasTablePermission(String user, String table, TablePermission permission)
           
 boolean PermissionHandler.hasTablePermission(String user, String table, TablePermission permission)
          Used to get the table permission of a user for a table
 void ZKPermHandler.initializeSecurity(TCredentials itw, String rootuser)
           
 void Authorizor.initializeSecurity(TCredentials credentials, String rootuser)
          Used to initialize security for the root user
 void InsecurePermHandler.initializeSecurity(TCredentials token, String rootuser)
           
 void PermissionHandler.initializeSecurity(TCredentials credentials, String rootuser)
          Used to initialize security for the root user
 void ZKAuthorizor.initializeSecurity(TCredentials itw, String rootuser)
           
 void Authenticator.initializeSecurity(TCredentials credentials, String principal, byte[] token)
           
 void ZKAuthenticator.initializeSecurity(TCredentials credentials, String principal, byte[] token)
           
 void InsecureAuthenticator.initializeSecurity(TCredentials credentials, String principal, byte[] token)
           
 void ZKPermHandler.initTable(String table)
           
 void InsecurePermHandler.initTable(String table)
           
 void PermissionHandler.initTable(String table)
          Initializes a new user
 void ZKPermHandler.initUser(String user)
           
 void Authorizor.initUser(String user)
          Initializes a new user
 void InsecurePermHandler.initUser(String user)
           
 void PermissionHandler.initUser(String user)
          Initializes a new user
 void ZKAuthorizor.initUser(String user)
           
 Set<String> Authenticator.listUsers()
           
 Set<String> InsecureAuthenticator.listUsers()
           
 void ZKPermHandler.revokeSystemPermission(String user, SystemPermission permission)
           
 void InsecurePermHandler.revokeSystemPermission(String user, SystemPermission permission)
           
 void PermissionHandler.revokeSystemPermission(String user, SystemPermission permission)
          Denies the user the given system permission
 void ZKPermHandler.revokeTablePermission(String user, String table, TablePermission permission)
           
 void InsecurePermHandler.revokeTablePermission(String user, String table, TablePermission permission)
           
 void PermissionHandler.revokeTablePermission(String user, String table, TablePermission permission)
          Denies the user the given table permission.
 boolean Authenticator.userExists(String user)
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.server.tabletserver
 

Methods in org.apache.accumulo.server.tabletserver that throw AccumuloSecurityException
static Pair<org.apache.hadoop.io.Text,KeyExtent> TabletServer.verifyTabletInformation(KeyExtent extent, TServerInstance instance, SortedMap<Key,Value> tabletsKeyValues, String clientAddress, ZooLock lock)
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.server.util
 

Methods in org.apache.accumulo.server.util that throw AccumuloSecurityException
static void CheckForMetadataProblems.checkTable(String tablename, TreeSet<KeyExtent> tablets, org.apache.accumulo.server.util.CheckForMetadataProblems.Opts opts)
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.test
 

Methods in org.apache.accumulo.test that throw AccumuloSecurityException
static void GCLotsOfCandidatesTest.main(String[] args)
           
static void QueryMetadataTable.main(String[] args)
           
static void BulkImportDirectory.main(String[] args)
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.test.continuous
 

Methods in org.apache.accumulo.test.continuous that throw AccumuloSecurityException
 int ContinuousMoru.run(String[] args)
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.test.functional
 

Methods in org.apache.accumulo.test.functional that throw AccumuloSecurityException
protected  Connector FunctionalTest.getConnector()
           
 void PermissionsTest.SystemPermissionsTest.run()
           
 void PermissionsTest.TablePermissionsTest.run()
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.test.randomwalk
 

Methods in org.apache.accumulo.test.randomwalk that throw AccumuloSecurityException
 Connector State.getConnector()
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.test.randomwalk.security
 

Methods in org.apache.accumulo.test.randomwalk.security that throw AccumuloSecurityException
 void WalkingSecurity.changeAuthorizations(String user, Authorizations authorizations)
           
 void WalkingSecurity.changePassword(String principal, AuthenticationToken token)
           
 void WalkingSecurity.cleanTablePermissions(String table)
           
 void WalkingSecurity.cleanUser(String user)
           
 void WalkingSecurity.createUser(String principal, AuthenticationToken token)
           
 void WalkingSecurity.dropUser(String user)
           
 Authorizations WalkingSecurity.getCachedUserAuthorizations(String user)
           
 void WalkingSecurity.grantSystemPermission(String user, SystemPermission permission)
           
 void WalkingSecurity.grantTablePermission(String user, String table, TablePermission permission)
           
 boolean WalkingSecurity.hasCachedSystemPermission(String user, SystemPermission permission)
           
 boolean WalkingSecurity.hasCachedTablePermission(String user, String table, TablePermission permission)
           
 boolean WalkingSecurity.hasSystemPermission(String user, SystemPermission permission)
           
 boolean WalkingSecurity.hasTablePermission(String user, String table, TablePermission permission)
           
 void WalkingSecurity.initTable(String table)
           
 void WalkingSecurity.initUser(String user)
           
 Set<String> WalkingSecurity.listUsers()
           
static void AlterTable.renameTable(Connector conn, State state, String oldName, String newName, boolean hasPermission, boolean tableExists)
           
 void WalkingSecurity.revokeSystemPermission(String user, SystemPermission permission)
           
 void WalkingSecurity.revokeTablePermission(String user, String table, TablePermission permission)
           
 

Uses of AccumuloSecurityException in org.apache.accumulo.test.scalability
 

Methods in org.apache.accumulo.test.scalability that throw AccumuloSecurityException
 void ScaleTest.init(Properties scaleProps, Properties testProps, int numTabletServers)
           
 



Copyright © 2013 Apache Accumulo Project. All Rights Reserved.