Uses of Class
org.apache.accumulo.core.client.AccumuloSecurityException
Packages that use AccumuloSecurityException
Package
Description
Mock framework for Accumulo
-
Uses of AccumuloSecurityException in org.apache.accumulo.core.client
Methods in org.apache.accumulo.core.client that throw AccumuloSecurityExceptionModifier and TypeMethodDescriptionMultiTableBatchWriter.getBatchWriter(String table) Returns a BatchWriter for a particular table.Instance.getConnector(String user, byte[] pass) Deprecated.Instance.getConnector(String user, CharSequence pass) Deprecated.since 1.5, useInstance.getConnector(String, AuthenticationToken)withPasswordTokenInstance.getConnector(String user, ByteBuffer pass) Deprecated.since 1.5, useInstance.getConnector(String, AuthenticationToken)withPasswordTokenInstance.getConnector(String principal, AuthenticationToken token) Returns a connection to this instance of accumulo.ZooKeeperInstance.getConnector(String principal, byte[] pass) Deprecated.ZooKeeperInstance.getConnector(String user, CharSequence pass) Deprecated.ZooKeeperInstance.getConnector(String user, ByteBuffer pass) Deprecated.ZooKeeperInstance.getConnector(String principal, AuthenticationToken token) ConditionalWriter.Result.getStatus()If this method throws an exception, then its possible the mutation is still being actively processed. -
Uses of AccumuloSecurityException in org.apache.accumulo.core.client.admin
Methods in org.apache.accumulo.core.client.admin that throw AccumuloSecurityExceptionModifier 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.voidDefines a cluster with the given name and the given name system.voidEnsures that tablets are split along a set of keys.voidNamespaceOperations.attachIterator(String namespace, IteratorSetting setting) Add an iterator to a namespace on all scopes.voidNamespaceOperations.attachIterator(String namespace, IteratorSetting setting, EnumSet<org.apache.accumulo.core.iterators.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<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes) Add an iterator to a table on the given scopes.booleanSecurityOperations.authenticateUser(String user, byte[] password) Deprecated.since 1.5.0; useSecurityOperations.authenticateUser(String, AuthenticationToken)instead.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 authorizationsvoidSecurityOperations.changeUserPassword(String user, byte[] password) Deprecated.since 1.5.0; useSecurityOperations.changeLocalUserPassword(String, PasswordToken)or the user management functions of your configured authenticator instead.voidNamespaceOperations.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.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 configurationvoidDeprecated.since 1.7.0; useTableOperations.create(String, NewTableConfiguration)instead.voidDeprecated.since 1.7.0; useTableOperations.create(String, NewTableConfiguration)instead.voidTableOperations.create(String tableName, NewTableConfiguration ntc) voidSecurityOperations.createLocalUser(String principal, PasswordToken password) Create a uservoidSecurityOperations.createUser(String user, byte[] password, Authorizations authorizations) Deprecated.since 1.5.0; useSecurityOperations.createLocalUser(String, PasswordToken)or the user management functions of your configured authenticator instead.voidDelete 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]voidWaits 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.voidGiven 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 uservoidDeprecated.since 1.5.0; useSecurityOperations.dropUser(String)or the user management functions of your configured authenticator instead.booleanA method to check if a namespace exists in Accumulo.voidTableOperations.exportTable(String tableName, String exportDir) Exports a table.voidDeprecated.since 1.4; useTableOperations.flush(String, Text, Text, boolean)insteadvoidTableOperations.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(String tserver) List the active compaction running on a tablet serverInstanceOperations.getActiveScans(String tserver) List the active scans on tablet server.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 in the files for a set of tablesNamespaceOperations.getIteratorSetting(String namespace, String name, org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope scope) Get the settings for an iterator.TableOperations.getIteratorSetting(String tableName, String name, org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope scope) Get the settings for an iterator.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.getProperties(String namespace) Gets properties of a namespace, which are inherited by tables in this namespace.TableOperations.getSamplerConfiguration(String tableName) Reads the sampling configuration properties for a table.InstanceOperations.getSiteConfiguration()InstanceOperations.getSystemConfiguration()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) Bulk import all the files in a directory into a table.voidTableOperations.importTable(String tableName, String importDir) Imports a table exported via exportTable and copied via hadoop distcp.NamespaceOperations.list()Retrieve a list of namespaces in Accumulo.NamespaceOperations.listConstraints(String namespace) List constraints on a namespace 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) SecurityOperations.listUsers()Deprecated.since 1.5.0; useSecurityOperations.listLocalUsers()or the user management functions of your configured authenticator instead.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]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 completevoidReplicationOperations.referencedFiles(String tableName) 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<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes) Remove an iterator from a namespace by name.voidTableOperations.removeIterator(String tableName, String name, EnumSet<org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope> scopes) Remove an iterator from a table by name.voidReplicationOperations.removePeer(String name) 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.voidRename a namespacevoidRename a tablevoidSecurityOperations.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 an 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. -
Uses of AccumuloSecurityException in org.apache.accumulo.core.client.mapred
Methods in org.apache.accumulo.core.client.mapred that throw AccumuloSecurityExceptionModifier and TypeMethodDescriptionvoidAccumuloOutputFormat.AccumuloRecordWriter.addTable(org.apache.hadoop.io.Text tableName) static voidAbstractInputFormat.setConnectorInfo(org.apache.hadoop.mapred.JobConf job, String principal, String tokenFile) Sets the connector information needed to communicate with Accumulo in this job.static voidAbstractInputFormat.setConnectorInfo(org.apache.hadoop.mapred.JobConf job, String principal, AuthenticationToken token) Sets the connector information needed to communicate with Accumulo in this job.static voidAccumuloOutputFormat.setConnectorInfo(org.apache.hadoop.mapred.JobConf job, String principal, String tokenFile) Sets the connector information needed to communicate with Accumulo in this job.static voidAccumuloOutputFormat.setConnectorInfo(org.apache.hadoop.mapred.JobConf job, String principal, AuthenticationToken token) Sets the connector information needed to communicate with Accumulo in this job.Constructors in org.apache.accumulo.core.client.mapred that throw AccumuloSecurityExceptionModifierConstructorDescriptionprotectedAccumuloRecordWriter(org.apache.hadoop.mapred.JobConf job) -
Uses of AccumuloSecurityException in org.apache.accumulo.core.client.mapreduce
Methods in org.apache.accumulo.core.client.mapreduce that throw AccumuloSecurityExceptionModifier and TypeMethodDescriptionvoidAccumuloOutputFormat.AccumuloRecordWriter.addTable(org.apache.hadoop.io.Text tableName) static voidAbstractInputFormat.setConnectorInfo(org.apache.hadoop.mapreduce.Job job, String principal, String tokenFile) Sets the connector information needed to communicate with Accumulo in this job.static voidAbstractInputFormat.setConnectorInfo(org.apache.hadoop.mapreduce.Job job, String principal, AuthenticationToken token) Sets the connector information needed to communicate with Accumulo in this job.static voidAccumuloOutputFormat.setConnectorInfo(org.apache.hadoop.mapreduce.Job job, String principal, String tokenFile) Sets the connector information needed to communicate with Accumulo in this job.static voidAccumuloOutputFormat.setConnectorInfo(org.apache.hadoop.mapreduce.Job job, String principal, AuthenticationToken token) Sets the connector information needed to communicate with Accumulo in this job.Constructors in org.apache.accumulo.core.client.mapreduce that throw AccumuloSecurityExceptionModifierConstructorDescriptionprotectedAccumuloRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context) -
Uses of AccumuloSecurityException in org.apache.accumulo.core.client.mapreduce.lib.util
Methods in org.apache.accumulo.core.client.mapreduce.lib.util that throw AccumuloSecurityExceptionModifier and TypeMethodDescriptionstatic voidConfiguratorBase.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. -
Uses of AccumuloSecurityException in org.apache.accumulo.core.client.mock
Methods in org.apache.accumulo.core.client.mock that throw AccumuloSecurityExceptionModifier and TypeMethodDescriptionMockMultiTableBatchWriter.getBatchWriter(String table) Deprecated.MockInstance.getConnector(String user, byte[] pass) Deprecated.MockInstance.getConnector(String user, CharSequence pass) Deprecated.MockInstance.getConnector(String user, ByteBuffer pass) Deprecated.MockInstance.getConnector(String principal, AuthenticationToken token) Deprecated. -
Uses of AccumuloSecurityException in org.apache.accumulo.minicluster
Methods in org.apache.accumulo.minicluster that throw AccumuloSecurityExceptionModifier and TypeMethodDescriptionMiniAccumuloCluster.getConnector(String user, String passwd) Utility method to get a connector to the MAC.
Instance.getConnector(String, AuthenticationToken)withPasswordToken