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

Packages that use AccumuloSecurityException
org.apache.accumulo.core.client   
org.apache.accumulo.core.client.admin   
org.apache.accumulo.core.client.impl   
org.apache.accumulo.core.client.mock   
org.apache.accumulo.core.util   
org.apache.accumulo.core.util.shell   
org.apache.accumulo.core.util.shell.commands   
 

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)
          Returns a connection to accumulo.
 Connector ZooKeeperInstance.getConnector(AuthInfo auth)
           
 Connector Instance.getConnector(String user, byte[] pass)
          Returns a connection to accumulo.
 Connector ZooKeeperInstance.getConnector(String user, byte[] pass)
           
 Connector Instance.getConnector(String user, ByteBuffer pass)
          Returns a connection to accumulo.
 Connector ZooKeeperInstance.getConnector(String user, ByteBuffer pass)
           
 Connector Instance.getConnector(String user, CharSequence pass)
          Returns a connection to this instance of accumulo.
 Connector ZooKeeperInstance.getConnector(String user, CharSequence pass)
           
 

Constructors in org.apache.accumulo.core.client that throw AccumuloSecurityException
Connector(Instance instance, String user, byte[] password)
          Deprecated. Not for client use
 

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

Methods in org.apache.accumulo.core.client.admin that throw AccumuloSecurityException
 void TableOperations.addAggregators(String tableName, List<? extends PerColumnIteratorConfig> aggregators)
          Deprecated. since 1.4 TableOperations.attachIterator(String, IteratorSetting)
 void TableOperationsImpl.addAggregators(String tableName, List<? extends PerColumnIteratorConfig> aggregators)
          Deprecated. since 1.4 TableOperationsHelper.attachIterator(String, IteratorSetting)
 void TableOperations.addSplits(String tableName, SortedSet<org.apache.hadoop.io.Text> partitionKeys)
           
 void TableOperationsImpl.addSplits(String tableName, SortedSet<org.apache.hadoop.io.Text> partitionKeys)
           
 void TableOperations.attachIterator(String tableName, IteratorSetting setting)
          Add an iterator to a table on all scopes.
 void TableOperationsHelper.attachIterator(String tableName, IteratorSetting setting)
           
 void TableOperations.attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
          Add an iterator to a table on the given scopes.
 void TableOperationsHelper.attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes)
           
 boolean SecurityOperationsImpl.authenticateUser(String user, byte[] password)
          Verify a username/password combination is valid
 boolean SecurityOperations.authenticateUser(String user, byte[] password)
          Verify a username/password combination is valid
 void SecurityOperationsImpl.changeUserAuthorizations(String user, Authorizations authorizations)
          Set the user's record-level authorizations
 void SecurityOperations.changeUserAuthorizations(String user, Authorizations authorizations)
          Set the user's record-level authorizations
 void SecurityOperationsImpl.changeUserPassword(String user, byte[] password)
          Set the user's password
 void SecurityOperations.changeUserPassword(String user, byte[] password)
          Set the user's password
 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.clone(String srcTableName, String newTableName, boolean flush, Map<String,String> propertiesToSet, Set<String> propertiesToExclude)
           
 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, boolean flush, boolean wait)
           
 void TableOperations.create(String tableName)
          Create a table with no special configuration
 void TableOperationsImpl.create(String tableName)
          Create a table with no special configuration
 void TableOperations.create(String tableName, boolean limitVersion)
           
 void TableOperationsImpl.create(String tableName, boolean limitVersion)
           
 void TableOperations.create(String tableName, boolean versioningIter, TimeType timeType)
           
 void TableOperationsImpl.create(String tableName, boolean limitVersion, TimeType timeType)
           
 void SecurityOperationsImpl.createUser(String user, byte[] password, Authorizations authorizations)
          Create a user
 void SecurityOperations.createUser(String user, byte[] password, Authorizations authorizations)
          Create a user
 void TableOperations.delete(String tableName)
          Delete a table
 void TableOperationsImpl.delete(String tableName)
          Delete a table
 void TableOperations.deleteRows(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end)
          Delete rows between (start, end]
 void TableOperationsImpl.deleteRows(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end)
           
 void SecurityOperationsImpl.dropUser(String user)
          Delete a user
 void SecurityOperations.dropUser(String user)
          Delete a user
 void TableOperations.flush(String tableName)
          Deprecated. As of release 1.4, replaced by TableOperations.flush(String, Text, Text, boolean)
 void TableOperationsImpl.flush(String tableName)
          Deprecated. since 1.4 TableOperationsImpl.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 tables data that is currently in memory.
 void TableOperationsImpl.flush(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end, boolean wait)
          Flush a table
 List<ActiveScan> InstanceOperationsImpl.getActiveScans(String tserver)
           
 List<ActiveScan> InstanceOperations.getActiveScans(String tserver)
          List the active scans on tablet server.
 IteratorSetting TableOperations.getIteratorSetting(String tableName, String name, IteratorUtil.IteratorScope scope)
          Get the settings for an iterator.
 IteratorSetting TableOperationsHelper.getIteratorSetting(String tableName, String name, IteratorUtil.IteratorScope scope)
           
 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.
 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)
           
 Map<String,String> InstanceOperationsImpl.getSiteConfiguration()
           
 Map<String,String> InstanceOperations.getSiteConfiguration()
           
 Map<String,String> InstanceOperationsImpl.getSystemConfiguration()
           
 Map<String,String> InstanceOperations.getSystemConfiguration()
           
 Authorizations SecurityOperationsImpl.getUserAuthorizations(String user)
          Retrieves the user's authorizations for scanning
 Authorizations SecurityOperations.getUserAuthorizations(String user)
          Retrieves the user's authorizations for scanning
 void SecurityOperationsImpl.grantSystemPermission(String user, SystemPermission permission)
          Grant a user a system permission
 void SecurityOperations.grantSystemPermission(String user, SystemPermission permission)
          Grant a user a system permission
 void SecurityOperationsImpl.grantTablePermission(String user, String table, TablePermission permission)
          Grant a user a specific permission for a specific table
 void SecurityOperations.grantTablePermission(String user, String table, TablePermission permission)
          Grant a user a specific permission for a specific table
 boolean SecurityOperationsImpl.hasSystemPermission(String user, SystemPermission perm)
          Verify the user has a particular system permission
 boolean SecurityOperations.hasSystemPermission(String user, SystemPermission perm)
          Verify the user has a particular system permission
 boolean SecurityOperationsImpl.hasTablePermission(String user, String table, TablePermission perm)
          Verify the user has a particular table permission
 boolean SecurityOperations.hasTablePermission(String user, 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 TableOperationsImpl.importDirectory(String tableName, String dir, String failureDir, boolean setTime)
           
 BulkImportHelper.AssignmentStats TableOperations.importDirectory(String tableName, String dir, String failureDir, int numThreads, int numAssignThreads, boolean disableGC)
          Deprecated. Since 1.4 use TableOperations.importDirectory(String, String, String, boolean)
 BulkImportHelper.AssignmentStats TableOperationsImpl.importDirectory(String tableName, String dir, String failureDir, int numThreads, int numAssignThreads, boolean disableGC)
          Deprecated. since 1.4 TableOperationsImpl.importDirectory(String, String, String, boolean)
 Map<String,EnumSet<IteratorUtil.IteratorScope>> TableOperations.listIterators(String tableName)
          Get a list of iterators for this table.
 Map<String,EnumSet<IteratorUtil.IteratorScope>> TableOperationsHelper.listIterators(String tableName)
           
 Set<String> SecurityOperationsImpl.listUsers()
          Return a list of users in accumulo
 Set<String> SecurityOperations.listUsers()
          Return a list of users in accumulo
 void TableOperations.merge(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end)
          Merge tablets between (start, end]
 void TableOperationsImpl.merge(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end)
           
 void TableOperations.offline(String tableName)
           
 void TableOperationsImpl.offline(String tableName)
           
 void TableOperations.online(String tableName)
           
 void TableOperationsImpl.online(String tableName)
           
 void TableOperations.removeIterator(String tableName, String name, EnumSet<IteratorUtil.IteratorScope> scopes)
          Remove an iterator from a table by name.
 void TableOperationsHelper.removeIterator(String tableName, String name, EnumSet<IteratorUtil.IteratorScope> scopes)
           
 void InstanceOperationsImpl.removeProperty(String property)
           
 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 TableOperationsImpl.removeProperty(String tableName, String property)
          Removes a property from a table
 void TableOperations.rename(String oldTableName, String newTableName)
          Rename a table
 void TableOperationsImpl.rename(String oldTableName, String newTableName)
          Rename a table
 void SecurityOperationsImpl.revokeSystemPermission(String user, SystemPermission permission)
          Revoke a system permission from a user
 void SecurityOperations.revokeSystemPermission(String user, SystemPermission permission)
          Revoke a system permission from a user
 void SecurityOperationsImpl.revokeTablePermission(String user, String table, TablePermission permission)
          Revoke a table permission for a specific user on a specific table
 void SecurityOperations.revokeTablePermission(String user, 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 tables locality groups.
 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 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 TableOperationsImpl.setProperty(String tableName, String property, String value)
          Sets a property on a table
 Set<Range> TableOperations.splitRangeByTablets(String tableName, Range range, int maxSplits)
           
 Set<Range> TableOperationsImpl.splitRangeByTablets(String tableName, Range range, int maxSplits)
           
 boolean InstanceOperationsImpl.testClassLoad(String className, String asTypeName)
           
 boolean InstanceOperations.testClassLoad(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)
           
 void RootTabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures)
           
 void TabletLocatorImpl.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures)
           
abstract  void TabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures)
           
 List<Range> RootTabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 List<Range> TabletLocatorImpl.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
abstract  List<Range> TabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
static void ServerClient.execute(Instance instance, ClientExec<ClientService.Iface> exec)
           
static void MasterClient.execute(Instance instance, ClientExec<MasterClientService.Iface> exec)
           
static
<T> T
ServerClient.execute(Instance instance, ClientExecReturn<T,ClientService.Iface> exec)
           
static
<T> T
MasterClient.execute(Instance instance, ClientExecReturn<T,MasterClientService.Iface> exec)
           
static boolean ThriftScanner.getBatchFromServer(AuthInfo credentials, org.apache.hadoop.io.Text startRow, KeyExtent extent, String server, SortedMap<Key,Value> results, SortedSet<Column> fetchedColumns, boolean skipStartKey, int size, Authorizations authorizations, boolean retry, AccumuloConfiguration conf)
           
 BatchWriter MultiTableBatchWriterImpl.getBatchWriter(String tableName)
           
 TabletLocator.TabletLocation RootTabletLocator.locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry)
           
 TabletLocator.TabletLocation TabletLocatorImpl.locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry)
           
abstract  TabletLocator.TabletLocation TabletLocator.locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry)
           
 TabletLocator.TabletLocations TabletLocatorImpl.TabletLocationObtainer.lookupTablet(TabletLocator.TabletLocation src, org.apache.hadoop.io.Text row, org.apache.hadoop.io.Text stopRow, TabletLocator parent)
           
 TabletLocator.TabletLocations MetadataLocationObtainer.lookupTablet(TabletLocator.TabletLocation src, org.apache.hadoop.io.Text row, org.apache.hadoop.io.Text stopRow, TabletLocator parent)
           
 List<TabletLocator.TabletLocation> TabletLocatorImpl.TabletLocationObtainer.lookupTablets(String tserver, Map<KeyExtent,List<Range>> map, TabletLocator parent)
           
 List<TabletLocator.TabletLocation> MetadataLocationObtainer.lookupTablets(String tserver, Map<KeyExtent,List<Range>> tabletsRanges, TabletLocator parent)
           
static List<KeyValue> ThriftScanner.scan(Instance instance, AuthInfo 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, String user, byte[] password)
          Deprecated. Not for client use
 

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

Methods in org.apache.accumulo.core.client.mock that throw AccumuloSecurityException
 void MockTableOperations.addAggregators(String tableName, List<? extends PerColumnIteratorConfig> aggregators)
          Deprecated. since 1.4 TableOperationsHelper.attachIterator(String, IteratorSetting)
 void MockTableOperations.addSplits(String tableName, SortedSet<org.apache.hadoop.io.Text> partitionKeys)
           
 boolean MockSecurityOperations.authenticateUser(String name, byte[] password)
           
 void MockTabletLocator.binMutations(List<Mutation> mutations, Map<String,TabletLocator.TabletServerMutations> binnedMutations, List<Mutation> failures)
           
 List<Range> MockTabletLocator.binRanges(List<Range> ranges, Map<String,Map<KeyExtent,List<Range>>> binnedRanges)
           
 void MockSecurityOperations.changeUserAuthorizations(String name, Authorizations authorizations)
           
 void MockSecurityOperations.changeUserPassword(String name, byte[] password)
           
 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.create(String tableName)
           
 void MockTableOperations.create(String tableName, boolean versioningIter)
           
 void MockTableOperations.create(String tableName, boolean versioningIter, TimeType timeType)
           
 void MockSecurityOperations.createUser(String user, byte[] password, Authorizations authorizations)
           
 void MockTableOperations.delete(String tableName)
           
 void MockTableOperations.deleteRows(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end)
           
 void MockSecurityOperations.dropUser(String user)
           
 void MockTableOperations.flush(String tableName)
           
 void MockTableOperations.flush(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end, boolean wait)
           
 List<ActiveScan> MockInstanceOperations.getActiveScans(String tserver)
           
 BatchWriter MockMultiTableBatchWriter.getBatchWriter(String table)
           
 Connector MockInstance.getConnector(AuthInfo auth)
           
 Connector MockInstance.getConnector(String user, byte[] pass)
           
 Connector MockInstance.getConnector(String user, ByteBuffer pass)
           
 Connector MockInstance.getConnector(String user, CharSequence pass)
           
 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 name)
           
 void MockSecurityOperations.grantSystemPermission(String name, SystemPermission permission)
           
 void MockSecurityOperations.grantTablePermission(String name, String tableName, TablePermission permission)
           
 boolean MockSecurityOperations.hasSystemPermission(String name, SystemPermission perm)
           
 boolean MockSecurityOperations.hasTablePermission(String name, String tableName, TablePermission perm)
           
 void MockTableOperations.importDirectory(String tableName, String dir, String failureDir, boolean setTime)
           
 BulkImportHelper.AssignmentStats MockTableOperations.importDirectory(String tableName, String dir, String failureDir, int numThreads, int numAssignThreads, boolean disableGC)
           
 Set<String> MockSecurityOperations.listUsers()
           
 TabletLocator.TabletLocation MockTabletLocator.locateTablet(org.apache.hadoop.io.Text row, boolean skipRow, boolean retry)
           
 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 name, SystemPermission permission)
           
 void MockSecurityOperations.revokeTablePermission(String name, 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)
           
 

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.Iface> exec)
           
static
<T> T
ThriftUtil.execute(String address, AccumuloConfiguration conf, ClientExecReturn<T,TabletClientService.Iface> exec)
           
static void MetadataTable.getEntries(Instance instance, AuthInfo 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
protected abstract  void Shell.TableOperation.doTableOp(Shell shellState, String tableName)
           
 void Shell.updateUser(AuthInfo authInfo)
           
 

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 OfflineCommand.doTableOp(Shell shellState, String tableName)
           
protected  void OnlineCommand.doTableOp(Shell shellState, String tableName)
           
protected  void FlushCommand.doTableOp(Shell shellState, String tableName)
           
protected  void CompactCommand.doTableOp(Shell shellState, String tableName)
           
 int SelectrowCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
          Deprecated.  
 int CreateTableCommand.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 SelectCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
          Deprecated.  
 int UserPermissionsCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int DeleteTableCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int DeleteIterCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int GrepCommand.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 RevokeCommand.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 AddSplitsCommand.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 UserCommand.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 DropUserCommand.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 PasswdCommand.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 TablesCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int ScanCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int GrantCommand.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 CreateUserCommand.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 ImportDirectoryCommand.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 GetSplitsCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int DeleteManyCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int MaxRowCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
 int GetAuthsCommand.execute(String fullCommand, org.apache.commons.cli.CommandLine cl, Shell shellState)
           
protected  Authorizations ScanCommand.getAuths(org.apache.commons.cli.CommandLine cl, Shell shellState)
           
protected  Authorizations MaxRowCommand.getAuths(org.apache.commons.cli.CommandLine cl, Shell shellState)
           
protected  void SetScanIterCommand.setTableProperties(org.apache.commons.cli.CommandLine cl, Shell shellState, String tableName, int priority, Map<String,String> options, String classname, String name)
           
protected  void SetIterCommand.setTableProperties(org.apache.commons.cli.CommandLine cl, Shell shellState, String tableName, int priority, Map<String,String> options, String classname, String name)
           
 



Copyright © 2014 The Apache Software Foundation. All Rights Reserved.