| Modifier and Type | Method and Description | 
|---|---|
| BatchWriter | MultiTableBatchWriter. getBatchWriter(String table)Returns a BatchWriter for a particular table. | 
| 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)withPasswordToken | 
| Connector | ZooKeeperInstance. getConnector(String principal,
            byte[] pass)Deprecated.  | 
| Connector | Instance. getConnector(String user,
            ByteBuffer pass)Deprecated. 
 since 1.5, use  Instance.getConnector(String, AuthenticationToken)withPasswordToken | 
| Connector | ZooKeeperInstance. getConnector(String user,
            ByteBuffer pass)Deprecated.  | 
| Connector | Instance. getConnector(String user,
            CharSequence pass)Deprecated. 
 since 1.5, use  Instance.getConnector(String, AuthenticationToken)withPasswordToken | 
| Connector | ZooKeeperInstance. getConnector(String user,
            CharSequence pass)Deprecated.  | 
| ConditionalWriter.Status | ConditionalWriter.Result. getStatus()If this method throws an exception, then its possible the mutation is still being actively processed. | 
| Modifier and Type | Method and Description | 
|---|---|
| int | NamespaceOperations. addConstraint(String namespace,
             String constraintClassName)Add a new constraint to a namespace. | 
| int | TableOperations. addConstraint(String tableName,
             String constraintClassName)Add a new constraint to a table. | 
| void | ReplicationOperations. addPeer(String name,
       String replicaType)Defines a cluster with the given name and the given name system. | 
| void | TableOperations. addSplits(String tableName,
         SortedSet<org.apache.hadoop.io.Text> partitionKeys)Ensures that tablets are split along a set of keys. | 
| void | NamespaceOperations. attachIterator(String namespace,
              IteratorSetting setting)Add an iterator to a namespace on all scopes. | 
| void | TableOperations. attachIterator(String tableName,
              IteratorSetting setting)Add an iterator to a table on all scopes. | 
| void | NamespaceOperations. attachIterator(String namespace,
              IteratorSetting setting,
              EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes)Add an iterator to a namespace on the given 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 | SecurityOperations. authenticateUser(String principal,
                AuthenticationToken token)Verify a username/password combination is valid | 
| boolean | SecurityOperations. authenticateUser(String user,
                byte[] password)Deprecated. 
 since 1.5.0; use  SecurityOperations.authenticateUser(String, AuthenticationToken)instead. | 
| void | TableOperations. cancelCompaction(String tableName)Cancels a user initiated major compaction of a table initiated with  TableOperations.compact(String, Text, Text, boolean, boolean)orTableOperations.compact(String, Text, Text, List, boolean, boolean). | 
| void | SecurityOperations. changeLocalUserPassword(String principal,
                       PasswordToken token)Set the user's password | 
| void | SecurityOperations. changeUserAuthorizations(String principal,
                        Authorizations authorizations)Set the user's record-level authorizations | 
| void | SecurityOperations. changeUserPassword(String user,
                  byte[] password)Deprecated. 
 since 1.5.0; use  SecurityOperations.changeLocalUserPassword(String, PasswordToken)or the user management functions of your configured authenticator
             instead. | 
| void | NamespaceOperations. checkIteratorConflicts(String namespace,
                      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 | TableOperations. clone(String srcTableName,
     String newTableName,
     boolean flush,
     Map<String,String> propertiesToSet,
     Set<String> propertiesToExclude)Clone a table from an existing table. | 
| void | TableOperations. compact(String tableName,
       CompactionConfig config)Starts a full major compaction of the tablets in the range (start, end]. | 
| void | TableOperations. compact(String tableName,
       org.apache.hadoop.io.Text start,
       org.apache.hadoop.io.Text end,
       boolean flush,
       boolean wait)Starts a full major compaction of the tablets in the range (start, end]. | 
| void | TableOperations. compact(String tableName,
       org.apache.hadoop.io.Text start,
       org.apache.hadoop.io.Text end,
       List<IteratorSetting> iterators,
       boolean flush,
       boolean wait)Starts a full major compaction of the tablets in the range (start, end]. | 
| void | NamespaceOperations. create(String namespace)Create an empty namespace with no initial configuration. | 
| void | TableOperations. create(String tableName)Create a table with no special configuration | 
| void | TableOperations. create(String tableName,
      boolean limitVersion)Deprecated. 
 since 1.7.0; use  TableOperations.create(String, NewTableConfiguration)instead. | 
| void | TableOperations. create(String tableName,
      boolean versioningIter,
      TimeType timeType)Deprecated. 
 since 1.7.0; use  TableOperations.create(String, NewTableConfiguration)instead. | 
| void | TableOperations. create(String tableName,
      NewTableConfiguration ntc) | 
| void | SecurityOperations. createLocalUser(String principal,
               PasswordToken password)Create a user | 
| void | SecurityOperations. createUser(String user,
          byte[] password,
          Authorizations authorizations)Deprecated. 
 since 1.5.0; use  SecurityOperations.createLocalUser(String, PasswordToken)or the user management functions of your configured authenticator instead. | 
| void | NamespaceOperations. delete(String namespace)Delete an empty namespace | 
| void | TableOperations. 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 | ReplicationOperations. drain(String tableName)Waits for a table to be fully replicated, given the state of files pending replication for the provided table at the point in time which this method is
 invoked. | 
| void | ReplicationOperations. drain(String tableName,
     Set<String> files)Given the provided set of files that are pending replication for a table, wait for those files to be fully replicated to all configured peers. | 
| void | SecurityOperations. dropLocalUser(String principal)Delete a user | 
| void | SecurityOperations. dropUser(String user)Deprecated. 
 since 1.5.0; use  SecurityOperations.dropUser(String)or the user management functions of your configured authenticator instead. | 
| boolean | NamespaceOperations. exists(String namespace)A method to check if a namespace exists in Accumulo. | 
| void | TableOperations. exportTable(String tableName,
           String exportDir)Exports a table. | 
| void | TableOperations. flush(String tableName)Deprecated. 
 since 1.4; use  TableOperations.flush(String, Text, Text, boolean)instead | 
| void | TableOperations. flush(String tableName,
     org.apache.hadoop.io.Text start,
     org.apache.hadoop.io.Text end,
     boolean wait)Flush a table's data that is currently in memory. | 
| List<ActiveCompaction> | InstanceOperations. getActiveCompactions(String tserver)List the active compaction running on a tablet server | 
| List<ActiveScan> | InstanceOperations. getActiveScans(String tserver)List the active scans on tablet server. | 
| DelegationToken | SecurityOperations. getDelegationToken(DelegationTokenConfig cfg)Obtain a  DelegationTokenfor use when Kerberos credentials cannot be used (e.g. | 
| List<DiskUsage> | TableOperations. getDiskUsage(Set<String> tables)Gets the number of bytes being used in the files for a set of tables | 
| IteratorSetting | NamespaceOperations. getIteratorSetting(String namespace,
                  String name,
                  org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope scope)Get the settings for an iterator. | 
| IteratorSetting | TableOperations. getIteratorSetting(String tableName,
                  String name,
                  org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope scope)Get the settings for an iterator. | 
| 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>> | NamespaceOperations. getProperties(String namespace)Gets properties of a namespace, which are inherited by tables in this namespace. | 
| Map<String,String> | InstanceOperations. getSiteConfiguration() | 
| Map<String,String> | InstanceOperations. getSystemConfiguration() | 
| Authorizations | SecurityOperations. getUserAuthorizations(String principal)Retrieves the user's authorizations for scanning | 
| void | SecurityOperations. grantNamespacePermission(String principal,
                        String namespace,
                        NamespacePermission permission)Grant a user a specific permission for a specific namespace | 
| void | SecurityOperations. grantSystemPermission(String principal,
                     SystemPermission permission)Grant a user a system permission | 
| void | SecurityOperations. grantTablePermission(String principal,
                    String table,
                    TablePermission permission)Grant a user a specific permission for a specific table | 
| boolean | SecurityOperations. hasNamespacePermission(String principal,
                      String namespace,
                      NamespacePermission perm)Verify the user has a particular namespace permission | 
| boolean | SecurityOperations. hasSystemPermission(String principal,
                   SystemPermission perm)Verify the user has a particular system permission | 
| boolean | SecurityOperations. hasTablePermission(String principal,
                  String table,
                  TablePermission perm)Verify the user has a particular table permission | 
| void | TableOperations. importDirectory(String tableName,
               String dir,
               String failureDir,
               boolean setTime)Bulk import all the files in a directory into a table. | 
| void | TableOperations. importTable(String tableName,
           String importDir)Imports a table exported via exportTable and copied via hadoop distcp. | 
| SortedSet<String> | NamespaceOperations. list()Retrieve a list of namespaces in Accumulo. | 
| Map<String,Integer> | NamespaceOperations. listConstraints(String namespace)List constraints on a namespace with their assigned numbers. | 
| Map<String,EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope>> | NamespaceOperations. listIterators(String namespace)Get a list of iterators for this namespace. | 
| Map<String,EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope>> | TableOperations. listIterators(String tableName)Get a list of iterators for this table. | 
| Set<String> | SecurityOperations. listLocalUsers()Return a list of users in accumulo | 
| Collection<org.apache.hadoop.io.Text> | TableOperations. listSplits(String tableName) | 
| Collection<org.apache.hadoop.io.Text> | TableOperations. listSplits(String tableName,
          int maxSplits) | 
| Set<String> | SecurityOperations. listUsers()Deprecated. 
 since 1.5.0; use  SecurityOperations.listLocalUsers()or the user management functions of your configured authenticator instead. | 
| void | TableOperations. merge(String tableName,
     org.apache.hadoop.io.Text start,
     org.apache.hadoop.io.Text end)Merge tablets between (start, end] | 
| Map<String,String> | NamespaceOperations. namespaceIdMap()Get a mapping of namespace name to internal namespace id. | 
| void | TableOperations. offline(String tableName)Initiates taking a table offline, but does not wait for action to complete | 
| void | TableOperations. offline(String tableName,
       boolean wait) | 
| void | TableOperations. online(String tableName)Initiates bringing a table online, but does not wait for action to complete | 
| void | TableOperations. online(String tableName,
      boolean wait) | 
| Set<String> | ReplicationOperations. referencedFiles(String tableName)Gets all of the referenced files for a table from the metadata table. | 
| void | NamespaceOperations. removeConstraint(String namespace,
                int id)Remove a constraint from a namespace. | 
| void | TableOperations. removeConstraint(String tableName,
                int number)Remove a constraint from a table. | 
| void | NamespaceOperations. removeIterator(String namespace,
              String name,
              EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes)Remove an iterator from a namespace by name. | 
| 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 | ReplicationOperations. removePeer(String name)Removes a cluster with the given name. | 
| void | InstanceOperations. removeProperty(String property)Removes a system property from zookeeper. | 
| void | NamespaceOperations. removeProperty(String namespace,
              String property)Removes a property from a namespace. | 
| void | TableOperations. removeProperty(String tableName,
              String property)Removes a property from a table. | 
| void | NamespaceOperations. rename(String oldNamespaceName,
      String newNamespaceName)Rename a namespace | 
| void | TableOperations. rename(String oldTableName,
      String newTableName)Rename a table | 
| void | SecurityOperations. revokeNamespacePermission(String principal,
                         String namespace,
                         NamespacePermission permission)Revoke a namespace permission for a specific user on a specific namespace | 
| void | SecurityOperations. revokeSystemPermission(String principal,
                      SystemPermission permission)Revoke a system permission from a user | 
| void | SecurityOperations. revokeTablePermission(String principal,
                     String table,
                     TablePermission permission)Revoke a table permission for a specific user on a specific table | 
| void | TableOperations. setLocalityGroups(String tableName,
                 Map<String,Set<org.apache.hadoop.io.Text>> groups)Sets a table's locality groups. | 
| void | InstanceOperations. setProperty(String property,
           String value)Sets an system property in zookeeper. | 
| void | NamespaceOperations. setProperty(String namespace,
           String property,
           String value)Sets a property on a namespace which applies to all tables in the namespace. | 
| void | TableOperations. setProperty(String tableName,
           String property,
           String value)Sets a property on a table. | 
| 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 | NamespaceOperations. testClassLoad(String namespace,
             String className,
             String asTypeName)Test to see if the instance can load the given class as the given type. | 
| boolean | TableOperations. testClassLoad(String tableName,
             String className,
             String asTypeName)Test to see if the instance can load the given class as the given type. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AccumuloOutputFormat.AccumuloRecordWriter. addTable(org.apache.hadoop.io.Text tableName) | 
| static void | AbstractInputFormat. 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 | 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 | AbstractInputFormat. setConnectorInfo(org.apache.hadoop.mapred.JobConf job,
                String principal,
                String tokenFile)Sets the connector information needed to communicate with Accumulo in this job. | 
| static void | AccumuloOutputFormat. setConnectorInfo(org.apache.hadoop.mapred.JobConf job,
                String principal,
                String tokenFile)Sets the connector information needed to communicate with Accumulo in this job. | 
| Constructor and Description | 
|---|
| AccumuloRecordWriter(org.apache.hadoop.mapred.JobConf job) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AccumuloOutputFormat.AccumuloRecordWriter. addTable(org.apache.hadoop.io.Text tableName) | 
| static void | AbstractInputFormat. 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 | 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 | AbstractInputFormat. setConnectorInfo(org.apache.hadoop.mapreduce.Job job,
                String principal,
                String tokenFile)Sets the connector information needed to communicate with Accumulo in this job. | 
| static void | AccumuloOutputFormat. setConnectorInfo(org.apache.hadoop.mapreduce.Job job,
                String principal,
                String tokenFile)Sets the connector information needed to communicate with Accumulo in this job. | 
| Constructor and Description | 
|---|
| AccumuloRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context) | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | ConfiguratorBase. setConnectorInfo(Class<?> implementingClass,
                org.apache.hadoop.conf.Configuration conf,
                String principal,
                AuthenticationToken token)Deprecated. 
 since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat. | 
| Modifier and Type | Method and Description | 
|---|---|
| BatchWriter | MockMultiTableBatchWriter. getBatchWriter(String table) | 
| Connector | MockInstance. getConnector(String principal,
            AuthenticationToken token) | 
| Connector | MockInstance. getConnector(String user,
            byte[] pass)Deprecated.  | 
| Connector | MockInstance. getConnector(String user,
            ByteBuffer pass)Deprecated.  | 
| Connector | MockInstance. getConnector(String user,
            CharSequence pass)Deprecated.  | 
| Modifier and Type | Method and Description | 
|---|---|
| Connector | MiniAccumuloCluster. getConnector(String user,
            String passwd)Utility method to get a connector to the MAC. | 
Copyright © 2011–2018 The Apache Software Foundation. All rights reserved.