Uses of Class
org.apache.accumulo.core.client.AccumuloException
Packages that use AccumuloException
Package
Description
-
Uses of AccumuloException in org.apache.accumulo.core.client
Subclasses of AccumuloException in org.apache.accumulo.core.clientModifier and TypeClassDescriptionclassCommunicate the failed mutations of a BatchWriter back to the client.Methods in org.apache.accumulo.core.client that throw AccumuloExceptionModifier and TypeMethodDescriptionAccumuloClient.createBatchScanner(String tableName) Factory method to create a BatchScanner with all of user's authorizations and the number of query threads configured when AccumuloClient was created.AccumuloClient.createScanner(String tableName) Factory method to create a Scanner with all of the user's authorizations.static ConnectorConnector.from(AccumuloClient client) Deprecated.Creates a Connector from an AccumuloClient.MultiTableBatchWriter.getBatchWriter(String table) Returns a BatchWriter for a particular table.default ConnectorInstance.getConnector(String user, byte[] pass) Deprecated.default ConnectorInstance.getConnector(String user, CharSequence pass) Deprecated.since 1.5, useInstance.getConnector(String, AuthenticationToken)withPasswordTokendefault ConnectorInstance.getConnector(String user, ByteBuffer pass) Deprecated.since 1.5, useInstance.getConnector(String, AuthenticationToken)withPasswordTokenInstance.getConnector(String principal, AuthenticationToken token) Deprecated.Returns a connection to this instance of accumulo.ZooKeeperInstance.getConnector(String principal, AuthenticationToken token) Deprecated.ConditionalWriter.Result.getStatus()If this method throws an exception, then its possible the mutation is still being actively processed. -
Uses of AccumuloException in org.apache.accumulo.core.client.admin
Methods in org.apache.accumulo.core.client.admin that throw AccumuloExceptionModifier and TypeMethodDescriptionintNamespaceOperations.addConstraint(String namespace, String constraintClassName) Add a new constraint to a namespace.intTableOperations.addConstraint(String tableName, String constraintClassName) Add a new constraint to a table.voidDeprecated.Defines a cluster with the given name and the given name system.voidEnsures that tablets are split along a set of keys.default voidTableOperations.addSummarizers(String tableName, SummarizerConfiguration... summarizers) Enables summary generation for this table for future compactions.voidNamespaceOperations.attachIterator(String namespace, IteratorSetting setting) Add an iterator to a namespace on all scopes.voidNamespaceOperations.attachIterator(String namespace, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes) Add an iterator to a namespace on the given scopes.voidTableOperations.attachIterator(String tableName, IteratorSetting setting) Add an iterator to a table on all scopes.voidTableOperations.attachIterator(String tableName, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes) Add an iterator to a table on the given scopes.booleanSecurityOperations.authenticateUser(String principal, AuthenticationToken token) Verify a username/password combination is validvoidTableOperations.cancelCompaction(String tableName) Cancels a user initiated major compaction of a table initiated withTableOperations.compact(String, Text, Text, boolean, boolean)orTableOperations.compact(String, Text, Text, List, boolean, boolean).voidSecurityOperations.changeLocalUserPassword(String principal, PasswordToken token) Set the user's passwordvoidSecurityOperations.changeUserAuthorizations(String principal, Authorizations authorizations) Set the user's record-level authorizationsvoidNamespaceOperations.checkIteratorConflicts(String namespace, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes) Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for the specified scopes.voidTableOperations.checkIteratorConflicts(String tableName, IteratorSetting setting, EnumSet<IteratorUtil.IteratorScope> scopes) Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for the specified scopes.voidTableOperations.clearSamplerConfiguration(String tableName) Clear all sampling configuration properties on the table.voidTableOperations.clone(String srcTableName, String newTableName, boolean flush, Map<String, String> propertiesToSet, Set<String> propertiesToExclude) Clone a table from an existing table.voidTableOperations.clone(String srcTableName, String newTableName, CloneConfiguration config) Clone a table from an existing table.voidTableOperations.compact(String tableName, CompactionConfig config) Starts a full major compaction of the tablets in the range (start, end].voidTableOperations.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].voidTableOperations.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].voidCreate an empty namespace with no initial configuration.voidCreate a table with no special configuration.default voidDeprecated.since 1.7.0; useTableOperations.create(String, NewTableConfiguration)instead.default voidDeprecated.since 1.7.0; useTableOperations.create(String, NewTableConfiguration)instead.voidTableOperations.create(String tableName, NewTableConfiguration ntc) Create a table with specified configuration.voidSecurityOperations.createLocalUser(String principal, PasswordToken password) Create a uservoidDelete an empty namespacevoidDelete a tablevoidTableOperations.deleteRows(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end) Delete rows between (start, end]voidDeprecated.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.voidDeprecated.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.voidSecurityOperations.dropLocalUser(String principal) Delete a userbooleanA method to check if a namespace exists in Accumulo.voidTableOperations.exportTable(String tableName, String exportDir) Exports a table.voidInitiate a flush of a table's data that is in memory.voidTableOperations.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.InstanceOperations.getActiveCompactions()List all internal and external compactions running in Accumulo.InstanceOperations.getActiveCompactions(String tserver) List the active compaction running on a TabletServer or Compactor.InstanceOperations.getActiveScans(String tserver) List the active scans on a tablet server.NamespaceOperations.getConfiguration(String namespace) Gets a merged view of the properties of a namespace with its parent configuration.TableOperations.getConfiguration(String tableName) Gets a merged view of the properties of a table with its parent configuration.SecurityOperations.getDelegationToken(DelegationTokenConfig cfg) Obtain aDelegationTokenfor use when Kerberos credentials cannot be used (e.g.TableOperations.getDiskUsage(Set<String> tables) Gets the number of bytes being used by the files for a set of tables.NamespaceOperations.getIteratorSetting(String namespace, String name, IteratorUtil.IteratorScope scope) Get the settings for an iterator.TableOperations.getIteratorSetting(String tableName, String name, IteratorUtil.IteratorScope scope) Get the settings for an iterator.TableOperations.getLocalityGroups(String tableName) Gets the locality groups currently set for a table.org.apache.hadoop.io.TextTableOperations.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.NamespaceOperations.getNamespaceProperties(String namespace) Gets properties specific to this namespace.NamespaceOperations.getProperties(String namespace) Gets a merged view of the properties of a namespace with its parent configuration.TableOperations.getProperties(String tableName) Gets a merged view of the properties of a table with its parent configuration.TableOperations.getSamplerConfiguration(String tableName) Reads the sampling configuration properties for a table.InstanceOperations.getSiteConfiguration()Retrieve the site configuration (that is set in the server configuration file).InstanceOperations.getSystemConfiguration()Retrieve the system-wide configuration.TableOperations.getTableProperties(String tableName) Gets per-table properties of a table.SecurityOperations.getUserAuthorizations(String principal) Retrieves the user's authorizations for scanningvoidSecurityOperations.grantNamespacePermission(String principal, String namespace, NamespacePermission permission) Grant a user a specific permission for a specific namespacevoidSecurityOperations.grantSystemPermission(String principal, SystemPermission permission) Grant a user a system permissionvoidSecurityOperations.grantTablePermission(String principal, String table, TablePermission permission) Grant a user a specific permission for a specific tablebooleanSecurityOperations.hasNamespacePermission(String principal, String namespace, NamespacePermission perm) Verify the user has a particular namespace permissionbooleanSecurityOperations.hasSystemPermission(String principal, SystemPermission perm) Verify the user has a particular system permissionbooleanSecurityOperations.hasTablePermission(String principal, String table, TablePermission perm) Verify the user has a particular table permissionvoidTableOperations.importDirectory(String tableName, String dir, String failureDir, boolean setTime) Deprecated.since 2.0.0 useTableOperations.importDirectory(String)instead.default voidTableOperations.importTable(String tableName, String importDir) Imports a table exported via exportTable and copied via hadoop distcp.voidTableOperations.importTable(String tableName, Set<String> importDirs, ImportConfiguration ic) Imports a table exported viaTableOperations.exportTable(String, String)and then copied via hadoop distcp.booleanCheck if a table is online through its current goal state only.NamespaceOperations.list()Retrieve a list of namespaces in Accumulo.NamespaceOperations.listConstraints(String namespace) List constraints on a namespace with their assigned numbers.TableOperations.listConstraints(String tableName) List constraints on a table with their assigned numbers.NamespaceOperations.listIterators(String namespace) Get a list of iterators for this namespace.TableOperations.listIterators(String tableName) Get a list of iterators for this table.SecurityOperations.listLocalUsers()Return a list of users in accumuloCollection<org.apache.hadoop.io.Text>TableOperations.listSplits(String tableName) Collection<org.apache.hadoop.io.Text>TableOperations.listSplits(String tableName, int maxSplits) default List<SummarizerConfiguration>TableOperations.listSummarizers(String tableName) voidTableOperations.ImportOptions.load()Loads the files into the table.TableOperations.locate(String tableName, Collection<Range> ranges) Locates the tablet servers and tablets that would service a collections of ranges.voidTableOperations.merge(String tableName, org.apache.hadoop.io.Text start, org.apache.hadoop.io.Text end) Merge tablets between (start, end]InstanceOperations.modifyProperties(Consumer<Map<String, String>> mapMutator) Modify system properties using a Consumer that accepts a mutable map containing the current system property overrides stored in ZooKeeper.For a detailed overview of the behavior of this method seeInstanceOperations.modifyProperties(Consumer)which operates on a different layer of properties but has the same behavior and better documentation.For a detailed overview of the behavior of this method seeInstanceOperations.modifyProperties(Consumer)which operates on a different layer of properties but has the same behavior and better documentation.NamespaceOperations.namespaceIdMap()Get a mapping of namespace name to internal namespace id.voidInitiates taking a table offline, but does not wait for action to completevoidvoidInitiates bringing a table online, but does not wait for action to completevoidvoidThrows an exception if a tablet server can not be contacted.ReplicationOperations.referencedFiles(String tableName) Deprecated.Gets all of the referenced files for a table from the metadata table.voidNamespaceOperations.removeConstraint(String namespace, int id) Remove a constraint from a namespace.voidTableOperations.removeConstraint(String tableName, int number) Remove a constraint from a table.voidNamespaceOperations.removeIterator(String namespace, String name, EnumSet<IteratorUtil.IteratorScope> scopes) Remove an iterator from a namespace by name.voidTableOperations.removeIterator(String tableName, String name, EnumSet<IteratorUtil.IteratorScope> scopes) Remove an iterator from a table by name.voidReplicationOperations.removePeer(String name) Deprecated.Removes a cluster with the given name.voidInstanceOperations.removeProperty(String property) Removes a system property from zookeeper.voidNamespaceOperations.removeProperty(String namespace, String property) Removes a property from a namespace.voidTableOperations.removeProperty(String tableName, String property) Removes a property from a table.default voidTableOperations.removeSummarizers(String tableName, Predicate<SummarizerConfiguration> predicate) Removes summary generation for this table for the matching summarizers.voidRename a namespacevoidRename a tableSummaryRetriever.retrieve()voidSecurityOperations.revokeNamespacePermission(String principal, String namespace, NamespacePermission permission) Revoke a namespace permission for a specific user on a specific namespacevoidSecurityOperations.revokeSystemPermission(String principal, SystemPermission permission) Revoke a system permission from a uservoidSecurityOperations.revokeTablePermission(String principal, String table, TablePermission permission) Revoke a table permission for a specific user on a specific tablevoidTableOperations.setLocalityGroups(String tableName, Map<String, Set<org.apache.hadoop.io.Text>> groups) Sets a table's locality groups.voidInstanceOperations.setProperty(String property, String value) Sets a system property in zookeeper.voidNamespaceOperations.setProperty(String namespace, String property, String value) Sets a property on a namespace which applies to all tables in the namespace.voidTableOperations.setProperty(String tableName, String property, String value) Sets a property on a table.voidTableOperations.setSamplerConfiguration(String tableName, SamplerConfiguration samplerConfiguration) Set or update the sampler configuration for a table.TableOperations.splitRangeByTablets(String tableName, Range range, int maxSplits) booleanInstanceOperations.testClassLoad(String className, String asTypeName) Test to see if the instance can load the given class as the given type.booleanNamespaceOperations.testClassLoad(String namespace, String className, String asTypeName) Test to see if the instance can load the given class as the given type.booleanTableOperations.testClassLoad(String tableName, String className, String asTypeName) Test to see if the instance can load the given class as the given type.voidInstanceOperations.waitForBalance()Waits for the tablet balancer to run and return no migrations. -
Uses of AccumuloException in org.apache.accumulo.core.client.mapred
Methods in org.apache.accumulo.core.client.mapred that throw AccumuloExceptionModifier and TypeMethodDescriptionvoidAccumuloOutputFormat.AccumuloRecordWriter.addTable(org.apache.hadoop.io.Text tableName) Constructors in org.apache.accumulo.core.client.mapred that throw AccumuloExceptionModifierConstructorDescriptionprotectedAccumuloRecordWriter(org.apache.hadoop.mapred.JobConf job) -
Uses of AccumuloException in org.apache.accumulo.core.client.mapreduce
Methods in org.apache.accumulo.core.client.mapreduce that throw AccumuloExceptionModifier and TypeMethodDescriptionvoidAccumuloOutputFormat.AccumuloRecordWriter.addTable(org.apache.hadoop.io.Text tableName) Constructors in org.apache.accumulo.core.client.mapreduce that throw AccumuloExceptionModifierConstructorDescriptionprotectedAccumuloRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context) -
Uses of AccumuloException in org.apache.accumulo.core.spi.balancer
Methods in org.apache.accumulo.core.spi.balancer that throw AccumuloExceptionModifier and TypeMethodDescriptionprotected List<TabletStatistics>HostRegexTableLoadBalancer.getOnlineTabletsForTable(TabletServerId tabletServerId, TableId tableId) protected List<TabletStatistics>SimpleLoadBalancer.getOnlineTabletsForTable(TabletServerId tabletServerId, TableId tableId) BalancerEnvironment.listOnlineTabletsForTable(TabletServerId tabletServerId, TableId tableId) Fetch the tablets for the given table by asking the tablet server. -
Uses of AccumuloException in org.apache.accumulo.hadoop.mapreduce
Methods in org.apache.accumulo.hadoop.mapreduce that throw AccumuloException -
Uses of AccumuloException in org.apache.accumulo.minicluster
Methods in org.apache.accumulo.minicluster that throw AccumuloExceptionModifier and TypeMethodDescriptionMiniAccumuloCluster.getConnector(String user, String passwd) Deprecated.since 2.0.0, replaced byMiniAccumuloCluster.createAccumuloClient(String, AuthenticationToken)
Instance.getConnector(String, AuthenticationToken)withPasswordToken