| Modifier and Type | Class and Description | 
|---|---|
| class  | MutationsRejectedExceptionCommunicate the failed mutations of a BatchWriter back to the client. | 
| Modifier and Type | Method and Description | 
|---|---|
| BatchWriter | MultiTableBatchWriter. getBatchWriter(String table)Returns a BatchWriter for a particular table. | 
| Connector | ZooKeeperInstance. getConnector(org.apache.accumulo.core.security.thrift.AuthInfo auth)Deprecated.  | 
| Connector | Instance. getConnector(org.apache.accumulo.core.security.thrift.AuthInfo auth)Deprecated. 
 since 1.5, use  Instance.getConnector(String, AuthenticationToken)withPasswordToken | 
| 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)withPasswordToken | 
| Connector | ZooKeeperInstance. getConnector(String user,
            ByteBuffer pass)Deprecated.  | 
| Connector | Instance. getConnector(String user,
            ByteBuffer pass)Deprecated. 
 since 1.5, use  Instance.getConnector(String, AuthenticationToken)withPasswordToken | 
| Connector | ZooKeeperInstance. getConnector(String user,
            CharSequence pass)Deprecated.  | 
| Connector | Instance. getConnector(String user,
            CharSequence pass)Deprecated. 
 since 1.5, use  Instance.getConnector(String, AuthenticationToken)withPasswordToken | 
| Modifier and Type | Method and Description | 
|---|---|
| int | TableOperationsImpl. addConstraint(String tableName,
             String constraintClassName) | 
| int | TableOperationsHelper. 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)Ensures that tablets are split along a set of keys. | 
| void | TableOperationsHelper. attachIterator(String tableName,
              IteratorSetting setting) | 
| void | TableOperations. attachIterator(String tableName,
              IteratorSetting setting)Add an iterator to a table on all scopes. | 
| void | TableOperationsImpl. attachIterator(String tableName,
              IteratorSetting setting,
              EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes) | 
| void | TableOperationsHelper. attachIterator(String tableName,
              IteratorSetting setting,
              EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes) | 
| void | TableOperations. attachIterator(String tableName,
              IteratorSetting setting,
              EnumSet<org.apache.accumulo.core.iterators.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)orTableOperations.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 | TableOperationsHelper. checkIteratorConflicts(String tableName,
                      IteratorSetting setting,
                      EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes) | 
| void | TableOperations. checkIteratorConflicts(String tableName,
                      IteratorSetting setting,
                      EnumSet<org.apache.accumulo.core.iterators.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 | 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. 
 | 
| 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> | InstanceOperationsImpl. getActiveCompactions(String tserver) | 
| List<ActiveCompaction> | InstanceOperations. getActiveCompactions(String tserver)List the active compaction running on a tablet server | 
| List<ActiveScan> | InstanceOperationsImpl. getActiveScans(String tserver) | 
| List<ActiveScan> | InstanceOperations. getActiveScans(String tserver)List the active scans on tablet server. | 
| IteratorSetting | TableOperationsHelper. getIteratorSetting(String tableName,
                  String name,
                  org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope scope) | 
| IteratorSetting | TableOperations. getIteratorSetting(String tableName,
                  String name,
                  org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope scope)Get the settings for an iterator. | 
| Map<String,Set<org.apache.hadoop.io.Text>> | TableOperationsImpl. getLocalityGroups(String tableName)Gets the locality groups currently set for a table. | 
| 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 | 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. | 
| Iterable<Map.Entry<String,String>> | TableOperationsImpl. getProperties(String tableName)Gets properties of a table | 
| Iterable<Map.Entry<String,String>> | TableOperations. getProperties(String tableName)Gets properties of a table. | 
| Map<String,String> | InstanceOperationsImpl. getSiteConfiguration() | 
| Map<String,String> | InstanceOperations. getSiteConfiguration() | 
| Map<String,String> | InstanceOperationsImpl. getSystemConfiguration() | 
| Map<String,String> | InstanceOperations. 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,Integer> | TableOperationsHelper. listConstraints(String tableName) | 
| Map<String,Integer> | TableOperations. listConstraints(String tableName)List constraints on a table with their assigned numbers. | 
| Map<String,EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope>> | TableOperationsHelper. listIterators(String tableName) | 
| Map<String,EnumSet<org.apache.accumulo.core.iterators.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> | TableOperations. listSplits(String tableName) | 
| 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 | InstanceOperationsImpl. ping(String tserver) | 
| void | InstanceOperations. ping(String tserver)Throws an exception if a tablet server can not be contacted. | 
| 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<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes) | 
| void | TableOperations. removeIterator(String tableName,
              String name,
              EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes)Remove an iterator from a table by name. | 
| void | InstanceOperationsImpl. removeProperty(String property) | 
| void | InstanceOperations. removeProperty(String property)Removes a system property from zookeeper. | 
| 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 | InstanceOperationsImpl. setProperty(String property,
           String value) | 
| void | InstanceOperations. setProperty(String property,
           String value)Sets an system property in zookeeper. | 
| 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 | 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. | 
| 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. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AccumuloOutputFormat.AccumuloRecordWriter. addTable(org.apache.hadoop.io.Text tableName) | 
| Constructor and Description | 
|---|
| AccumuloOutputFormat.AccumuloRecordWriter(org.apache.hadoop.mapred.JobConf job) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AccumuloOutputFormat.AccumuloRecordWriter. addTable(org.apache.hadoop.io.Text tableName) | 
| Constructor and Description | 
|---|
| AccumuloOutputFormat.AccumuloRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context) | 
| Modifier and Type | Method and Description | 
|---|---|
| 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,org.apache.accumulo.core.client.impl.TabletLocator.TabletServerMutations> binnedMutations,
            List<Mutation> failures,
            org.apache.accumulo.core.security.thrift.TCredentials credentials) | 
| List<Range> | MockTabletLocator. binRanges(List<Range> ranges,
         Map<String,Map<KeyExtent,List<Range>>> binnedRanges,
         org.apache.accumulo.core.security.thrift.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(org.apache.accumulo.core.security.thrift.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.  | 
| Map<String,Set<org.apache.hadoop.io.Text>> | MockTableOperations. getLocalityGroups(String tableName) | 
| 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.  | 
| org.apache.accumulo.core.client.impl.TabletLocator.TabletLocation | MockTabletLocator. locateTablet(org.apache.hadoop.io.Text row,
            boolean skipRow,
            boolean retry,
            org.apache.accumulo.core.security.thrift.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. ping(String tserver) | 
| 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) | 
Copyright © 2011-2016 The Apache Software Foundation. All Rights Reserved.