Uses of Class
org.apache.hadoop.hbase.security.User
Packages that use org.apache.hadoop.hbase.security.User
Package
Description
Provides HBase Client
Table of Contents
Tools to help define network clients and servers.
-
Uses of org.apache.hadoop.hbase.security.User in org.apache.hadoop.hbase
Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.security.User in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.security.UserHBaseTestingUtility.getDifferentUser(org.apache.hadoop.conf.Configuration c, String differentiatingSuffix) Deprecated.This method clones the passedcconfiguration setting a new user into the clone.static org.apache.hadoop.hbase.security.UserAuthUtil.loginClient(org.apache.hadoop.conf.Configuration conf) Deprecated.For kerberized cluster, return login user (from kinit or from keytab if specified).Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.security.User in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.util.JVMClusterUtil.MasterThreadLocalHBaseCluster.addMaster(org.apache.hadoop.conf.Configuration c, int index, org.apache.hadoop.hbase.security.User user) org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThreadLocalHBaseCluster.addRegionServer(org.apache.hadoop.conf.Configuration config, int index, org.apache.hadoop.hbase.security.User user) org.apache.hadoop.hbase.client.AsyncClusterConnectionHBaseTestingUtility.getAsyncConnection(org.apache.hadoop.hbase.security.User user) Deprecated.Get a assigned AsyncClusterConnection to the cluster.org.apache.hadoop.hbase.client.ConnectionHBaseTestingUtility.getConnection(org.apache.hadoop.hbase.security.User user) Deprecated.Get a assigned Connection to the cluster.intHBaseRpcServicesBase.getPriority(org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header, org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hadoop.hbase.security.User user) -
Uses of org.apache.hadoop.hbase.security.User in org.apache.hadoop.hbase.client
Fields in org.apache.hadoop.hbase.client declared as org.apache.hadoop.hbase.security.User in inModifier and TypeFieldDescriptionprotected final org.apache.hadoop.hbase.security.UserAsyncConnectionImpl.userMethods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.security.User in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.security.UserAsyncConnectionImpl.getUser()Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.security.User in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.ConnectionRegistryConnectionRegistryURIFactory.create(URI uri, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.security.User user) Instantiate theConnectionRegistryusing the given parameters.org.apache.hadoop.hbase.client.ConnectionRegistryRpcConnectionRegistryURIFactory.create(URI uri, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.security.User user) org.apache.hadoop.hbase.client.ConnectionRegistryZKConnectionRegistryURIFactory.create(URI uri, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.security.User user) static org.apache.hadoop.hbase.client.AsyncClusterConnectionClusterConnectionFactory.createAsyncClusterConnection(URI uri, org.apache.hadoop.conf.Configuration conf, SocketAddress localAddress, org.apache.hadoop.hbase.security.User user) Create a newAsyncClusterConnectioninstance.static org.apache.hadoop.hbase.client.AsyncClusterConnectionClusterConnectionFactory.createAsyncClusterConnection(org.apache.hadoop.conf.Configuration conf, SocketAddress localAddress, org.apache.hadoop.hbase.security.User user) Create a newAsyncClusterConnectioninstance.static org.apache.hadoop.hbase.client.AsyncClusterConnectionClusterConnectionFactory.createAsyncClusterConnection(org.apache.hadoop.hbase.client.ConnectionRegistryEndpoint endpoint, org.apache.hadoop.conf.Configuration conf, SocketAddress localAddress, org.apache.hadoop.hbase.security.User user) Create a newAsyncClusterConnectioninstance to be used at server side where we have aConnectionRegistryEndpoint.static CompletableFuture<org.apache.hadoop.hbase.client.AsyncConnection>ConnectionFactory.createAsyncConnection(URI connectionUri, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.security.User user) Create a new AsyncConnection instance using the passedconnectionUri,confanduser.static CompletableFuture<org.apache.hadoop.hbase.client.AsyncConnection>ConnectionFactory.createAsyncConnection(URI connectionUri, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.security.User user, Map<String, byte[]> connectionAttributes) Create a new AsyncConnection instance using the passedconnectionUri,confanduser.static CompletableFuture<org.apache.hadoop.hbase.client.AsyncConnection>ConnectionFactory.createAsyncConnection(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.security.User user) Create a new AsyncConnection instance using the passedconfanduser.static CompletableFuture<org.apache.hadoop.hbase.client.AsyncConnection>ConnectionFactory.createAsyncConnection(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.security.User user, Map<String, byte[]> connectionAttributes) Create a new AsyncConnection instance using the passedconfanduser.static org.apache.hadoop.hbase.client.ConnectionConnectionFactory.createConnection(URI connectionUri, org.apache.hadoop.conf.Configuration conf, ExecutorService pool, org.apache.hadoop.hbase.security.User user) Create a new Connection instance using the passedconfinstance.static org.apache.hadoop.hbase.client.ConnectionConnectionFactory.createConnection(URI connectionUri, org.apache.hadoop.conf.Configuration conf, ExecutorService pool, org.apache.hadoop.hbase.security.User user, Map<String, byte[]> connectionAttributes) Create a new Connection instance using the passedconfinstance.static org.apache.hadoop.hbase.client.ConnectionConnectionFactory.createConnection(URI connectionUri, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.security.User user) Create a new Connection instance using the passedconfinstance.static org.apache.hadoop.hbase.client.ConnectionConnectionFactory.createConnection(org.apache.hadoop.conf.Configuration conf, ExecutorService pool, org.apache.hadoop.hbase.security.User user) Create a new Connection instance using the passedconfinstance.static org.apache.hadoop.hbase.client.ConnectionConnectionFactory.createConnection(org.apache.hadoop.conf.Configuration conf, ExecutorService pool, org.apache.hadoop.hbase.security.User user, Map<String, byte[]> connectionAttributes) Create a new Connection instance using the passedconfinstance.static org.apache.hadoop.hbase.client.ConnectionConnectionFactory.createConnection(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.security.User user) Create a new Connection instance using the passedconfinstance.Constructors in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.security.User in inModifierConstructorDescriptionAsyncConnectionImpl(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.ConnectionRegistry registry, String clusterId, SocketAddress localAddress, org.apache.hadoop.hbase.security.User user) AsyncConnectionImpl(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.ConnectionRegistry registry, String clusterId, SocketAddress localAddress, org.apache.hadoop.hbase.security.User user, Map<String, byte[]> connectionAttributes) -
Uses of org.apache.hadoop.hbase.security.User in org.apache.hadoop.hbase.coprocessor
Methods in org.apache.hadoop.hbase.coprocessor that return types with arguments of type org.apache.hadoop.hbase.security.User in inModifier and TypeMethodDescriptionOptional<org.apache.hadoop.hbase.security.User>ObserverContext.getCaller()Returns the active user for the coprocessor call.Optional<org.apache.hadoop.hbase.security.User>ObserverContextImpl.getCaller()Constructors in org.apache.hadoop.hbase.coprocessor with parameters of type org.apache.hadoop.hbase.security.User in inModifierConstructorDescriptionObserverContextImpl(org.apache.hadoop.hbase.security.User caller) ObserverContextImpl(org.apache.hadoop.hbase.security.User caller, boolean bypassable) ObserverOperationWithoutResult(org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverGetter<C, O> observerGetter, org.apache.hadoop.hbase.security.User user) ObserverOperationWithoutResult(org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverGetter<C, O> observerGetter, org.apache.hadoop.hbase.security.User user, boolean bypassable) ObserverOperationWithResult(org.apache.hadoop.hbase.coprocessor.CoprocessorHost.ObserverGetter<C, O> observerGetter, R result, org.apache.hadoop.hbase.security.User user) -
Uses of org.apache.hadoop.hbase.security.User in org.apache.hadoop.hbase.ipc
Fields in org.apache.hadoop.hbase.ipc declared as org.apache.hadoop.hbase.security.User in inModifier and TypeFieldDescriptionprotected final org.apache.hadoop.hbase.security.UserAbstractRpcClient.AbstractRpcChannel.ticketprotected final org.apache.hadoop.hbase.security.UserAbstractRpcClient.AbstractRpcChannel.ticketprotected final org.apache.hadoop.hbase.security.UserServerCall.userMethods in org.apache.hadoop.hbase.ipc that return types with arguments of type org.apache.hadoop.hbase.security.User in inModifier and TypeMethodDescriptionOptional<org.apache.hadoop.hbase.security.User>RpcCallContext.getRequestUser()Returns the user credentials associated with the current RPC request or not present if no credentials were provided.static Optional<org.apache.hadoop.hbase.security.User>RpcServer.getRequestUser()Returns the user credentials associated with the current RPC request or not present if no credentials were provided.Optional<org.apache.hadoop.hbase.security.User>ServerCall.getRequestUser()Methods in org.apache.hadoop.hbase.ipc with parameters of type org.apache.hadoop.hbase.security.User in inModifier and TypeMethodDescriptionorg.apache.hbase.thirdparty.com.google.protobuf.BlockingRpcChannelAbstractRpcClient.createBlockingRpcChannel(org.apache.hadoop.hbase.ServerName sn, org.apache.hadoop.hbase.security.User ticket, int rpcTimeout) org.apache.hbase.thirdparty.com.google.protobuf.BlockingRpcChannelRpcClient.createBlockingRpcChannel(org.apache.hadoop.hbase.ServerName sn, org.apache.hadoop.hbase.security.User user, int rpcTimeout) Creates a "channel" that can be used by a blocking protobuf service.org.apache.hbase.thirdparty.com.google.protobuf.RpcChannelAbstractRpcClient.createRpcChannel(org.apache.hadoop.hbase.ServerName sn, org.apache.hadoop.hbase.security.User user, int rpcTimeout) org.apache.hbase.thirdparty.com.google.protobuf.RpcChannelRpcClient.createRpcChannel(org.apache.hadoop.hbase.ServerName sn, org.apache.hadoop.hbase.security.User user, int rpcTimeout) Creates a "channel" that can be used by a protobuf service.intAnnotationReadingPriorityFunction.getPriority(org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header, org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hadoop.hbase.security.User user) Returns a 'priority' based on the request type.intPriorityFunction.getPriority(org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader header, org.apache.hbase.thirdparty.com.google.protobuf.Message param, org.apache.hadoop.hbase.security.User user) Returns the 'priority type' of the specified request.Constructors in org.apache.hadoop.hbase.ipc with parameters of type org.apache.hadoop.hbase.security.User in inModifierConstructorDescriptionprotectedBlockingRpcChannelImplementation(org.apache.hadoop.hbase.ipc.AbstractRpcClient<?> rpcClient, org.apache.hadoop.hbase.net.Address addr, org.apache.hadoop.hbase.security.User ticket, int rpcTimeout) protectedRpcChannelImplementation(org.apache.hadoop.hbase.ipc.AbstractRpcClient<?> rpcClient, org.apache.hadoop.hbase.net.Address addr, org.apache.hadoop.hbase.security.User ticket, int rpcTimeout) -
Uses of org.apache.hadoop.hbase.security.User in org.apache.hadoop.hbase.master
Methods in org.apache.hadoop.hbase.master with parameters of type org.apache.hadoop.hbase.security.User in inModifier and TypeMethodDescriptionvoidMasterCoprocessorHost.postCompletedCreateTableAction(org.apache.hadoop.hbase.client.TableDescriptor htd, org.apache.hadoop.hbase.client.RegionInfo[] regions, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.postCompletedDeleteTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.postCompletedDisableTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.postCompletedEnableTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.postCompletedMergeRegionsAction(org.apache.hadoop.hbase.client.RegionInfo[] regionsToMerge, org.apache.hadoop.hbase.client.RegionInfo mergedRegion, org.apache.hadoop.hbase.security.User user) Invoked after completing merge regions operationvoidMasterCoprocessorHost.postCompletedModifyTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor oldDescriptor, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.postCompletedSplitRegionAction(org.apache.hadoop.hbase.client.RegionInfo regionInfoA, org.apache.hadoop.hbase.client.RegionInfo regionInfoB, org.apache.hadoop.hbase.security.User user) Invoked just after a splitvoidMasterCoprocessorHost.postCompletedTruncateTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.postMergeRegionsCommit(org.apache.hadoop.hbase.client.RegionInfo[] regionsToMerge, org.apache.hadoop.hbase.client.RegionInfo mergedRegion, org.apache.hadoop.hbase.security.User user) Invoked after merge regions operation writes the new region to hbase:metavoidMasterCoprocessorHost.postRollBackMergeRegionsAction(org.apache.hadoop.hbase.client.RegionInfo[] regionsToMerge, org.apache.hadoop.hbase.security.User user) Invoked after rollback merge regions operationvoidMasterCoprocessorHost.postRollBackSplitRegionAction(org.apache.hadoop.hbase.security.User user) Invoked just after the rollback of a failed splitvoidMasterCoprocessorHost.postSnapshot(org.apache.hadoop.hbase.client.SnapshotDescription snapshot, org.apache.hadoop.hbase.client.TableDescriptor hTableDescriptor, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.postTruncateRegionAction(org.apache.hadoop.hbase.client.RegionInfo region, org.apache.hadoop.hbase.security.User user) Invoked after calling the truncate region procedurevoidMasterCoprocessorHost.preCreateTableAction(org.apache.hadoop.hbase.client.TableDescriptor htd, org.apache.hadoop.hbase.client.RegionInfo[] regions, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.preDeleteTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.preDisableTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.preEnableTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.preMergeRegionsAction(org.apache.hadoop.hbase.client.RegionInfo[] regionsToMerge, org.apache.hadoop.hbase.security.User user) Invoked just before a mergevoidMasterCoprocessorHost.preMergeRegionsCommit(org.apache.hadoop.hbase.client.RegionInfo[] regionsToMerge, List<org.apache.hadoop.hbase.client.Mutation> metaEntries, org.apache.hadoop.hbase.security.User user) Invoked before merge regions operation writes the new region to hbase:metavoidMasterCoprocessorHost.preModifyTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.client.TableDescriptor currentDescriptor, org.apache.hadoop.hbase.client.TableDescriptor newDescriptor, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.preSnapshot(org.apache.hadoop.hbase.client.SnapshotDescription snapshot, org.apache.hadoop.hbase.client.TableDescriptor hTableDescriptor, org.apache.hadoop.hbase.security.User user) voidMasterCoprocessorHost.preSplitAfterMETAAction(org.apache.hadoop.hbase.security.User user) This will be called after update META step as part of split table region procedure.voidMasterCoprocessorHost.preSplitBeforeMETAAction(byte[] splitKey, List<org.apache.hadoop.hbase.client.Mutation> metaEntries, org.apache.hadoop.hbase.security.User user) This will be called before update META step as part of split table region procedure.voidMasterCoprocessorHost.preSplitRegionAction(org.apache.hadoop.hbase.TableName tableName, byte[] splitRow, org.apache.hadoop.hbase.security.User user) Invoked just before a splitvoidMasterCoprocessorHost.preTruncateRegionAction(org.apache.hadoop.hbase.client.RegionInfo region, org.apache.hadoop.hbase.security.User user) Invoked just before calling the truncate region procedurevoidMasterCoprocessorHost.preTruncateTableAction(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) -
Uses of org.apache.hadoop.hbase.security.User in org.apache.hadoop.hbase.mob
Methods in org.apache.hadoop.hbase.mob with parameters of type org.apache.hadoop.hbase.security.User in inModifier and TypeMethodDescriptionList<org.apache.hadoop.fs.Path>DefaultMobStoreCompactor.compact(org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl request, org.apache.hadoop.hbase.regionserver.throttle.ThroughputController throughputController, org.apache.hadoop.hbase.security.User user) -
Uses of org.apache.hadoop.hbase.security.User in org.apache.hadoop.hbase.regionserver
Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.security.User in inModifier and TypeMethodDescriptionbooleanHRegion.compact(org.apache.hadoop.hbase.regionserver.compactions.CompactionContext compaction, org.apache.hadoop.hbase.regionserver.HStore store, org.apache.hadoop.hbase.regionserver.throttle.ThroughputController throughputController, org.apache.hadoop.hbase.security.User user) We are trying to remove / relax the region read lock for compaction.List<org.apache.hadoop.hbase.regionserver.HStoreFile>HStore.compact(org.apache.hadoop.hbase.regionserver.compactions.CompactionContext compaction, org.apache.hadoop.hbase.regionserver.throttle.ThroughputController throughputController, org.apache.hadoop.hbase.security.User user) Compact the StoreFiles.protected List<org.apache.hadoop.hbase.regionserver.HStoreFile>HStore.doCompaction(org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl cr, Collection<org.apache.hadoop.hbase.regionserver.HStoreFile> filesToCompact, org.apache.hadoop.hbase.security.User user, long compactionStartTime, List<org.apache.hadoop.fs.Path> newFiles) voidRegionCoprocessorHost.postCompact(org.apache.hadoop.hbase.regionserver.HStore store, org.apache.hadoop.hbase.regionserver.HStoreFile resultFile, org.apache.hadoop.hbase.regionserver.compactions.CompactionLifeCycleTracker tracker, org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest request, org.apache.hadoop.hbase.security.User user) Called after the store compaction has completed.voidRegionCoprocessorHost.postCompactSelection(org.apache.hadoop.hbase.regionserver.HStore store, List<org.apache.hadoop.hbase.regionserver.HStoreFile> selected, org.apache.hadoop.hbase.regionserver.compactions.CompactionLifeCycleTracker tracker, org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest request, org.apache.hadoop.hbase.security.User user) Called after theHStoreFiles to be compacted have been selected from the available candidates.voidRegionCoprocessorHost.preCleanupBulkLoad(org.apache.hadoop.hbase.security.User user) org.apache.hadoop.hbase.regionserver.InternalScannerRegionCoprocessorHost.preCompact(org.apache.hadoop.hbase.regionserver.HStore store, org.apache.hadoop.hbase.regionserver.InternalScanner scanner, org.apache.hadoop.hbase.regionserver.ScanType scanType, org.apache.hadoop.hbase.regionserver.compactions.CompactionLifeCycleTracker tracker, org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest request, org.apache.hadoop.hbase.security.User user) Called prior to rewriting the store files selected for compactionorg.apache.hadoop.hbase.regionserver.ScanInfoRegionCoprocessorHost.preCompactScannerOpen(org.apache.hadoop.hbase.regionserver.HStore store, org.apache.hadoop.hbase.regionserver.ScanType scanType, org.apache.hadoop.hbase.regionserver.compactions.CompactionLifeCycleTracker tracker, org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest request, org.apache.hadoop.hbase.security.User user) Called prior to opening store scanner for compaction.booleanRegionCoprocessorHost.preCompactSelection(org.apache.hadoop.hbase.regionserver.HStore store, List<org.apache.hadoop.hbase.regionserver.HStoreFile> candidates, org.apache.hadoop.hbase.regionserver.compactions.CompactionLifeCycleTracker tracker, org.apache.hadoop.hbase.security.User user) Called prior to selecting theHStoreFiles for compaction from the list of currently available candidates.voidRegionCoprocessorHost.prePrepareBulkLoad(org.apache.hadoop.hbase.security.User user) voidRegionServerCoprocessorHost.preStop(String message, org.apache.hadoop.hbase.security.User user) voidCompactSplit.requestCompaction(org.apache.hadoop.hbase.regionserver.HRegion region, String why, int priority, org.apache.hadoop.hbase.regionserver.compactions.CompactionLifeCycleTracker tracker, org.apache.hadoop.hbase.security.User user) voidCompactSplit.requestCompaction(org.apache.hadoop.hbase.regionserver.HRegion region, org.apache.hadoop.hbase.regionserver.HStore store, String why, int priority, org.apache.hadoop.hbase.regionserver.compactions.CompactionLifeCycleTracker tracker, org.apache.hadoop.hbase.security.User user) Optional<org.apache.hadoop.hbase.regionserver.compactions.CompactionContext>HStore.requestCompaction(int priority, org.apache.hadoop.hbase.regionserver.compactions.CompactionLifeCycleTracker tracker, org.apache.hadoop.hbase.security.User user) protected voidCompactSplit.requestCompactionInternal(org.apache.hadoop.hbase.regionserver.HRegion region, org.apache.hadoop.hbase.regionserver.HStore store, String why, int priority, boolean selectNow, org.apache.hadoop.hbase.regionserver.compactions.CompactionLifeCycleTracker tracker, org.apache.hadoop.hbase.regionserver.CompactSplit.CompactionCompleteTracker completeTracker, org.apache.hadoop.hbase.security.User user) voidHRegionServer.stop(String msg, boolean force, org.apache.hadoop.hbase.security.User user) Stops the regionserver. -
Uses of org.apache.hadoop.hbase.security.User in org.apache.hadoop.hbase.security
Subclasses of org.apache.hadoop.hbase.security.User in in org.apache.hadoop.hbase.securityModifier and TypeClassDescriptionstatic final classorg.apache.hadoop.hbase.security.User.SecureHadoopUserBridgesUserinvocations to underlying calls toUserGroupInformationfor secure Hadoop 0.20 and versions 0.21 and above.Methods in org.apache.hadoop.hbase.security that return org.apache.hadoop.hbase.security.User in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.security.UserUser.create(org.apache.hadoop.security.UserGroupInformation ugi) Wraps an underlyingUserGroupInformationinstance.org.apache.hadoop.hbase.security.UserUserProvider.create(org.apache.hadoop.security.UserGroupInformation ugi) Wraps an underlyingUserGroupInformationinstance.static org.apache.hadoop.hbase.security.UserGenerates a newUserinstance specifically for use in test code.static org.apache.hadoop.hbase.security.UserUser.SecureHadoopUser.createUserForTesting(org.apache.hadoop.conf.Configuration conf, String name, String[] groups) Create a user for testing.static org.apache.hadoop.hbase.security.UserUser.getCurrent()Returns theUserinstance within current execution context.org.apache.hadoop.hbase.security.UserUserProvider.getCurrent()Return the current user within the current execution contextstatic org.apache.hadoop.hbase.security.UserSuperusers.getSystemUser()Methods in org.apache.hadoop.hbase.security with parameters of type org.apache.hadoop.hbase.security.User in inModifier and TypeMethodDescriptionstatic booleanSuperusers.isSuperUser(org.apache.hadoop.hbase.security.User user) Check if the current user is a super user -
Uses of org.apache.hadoop.hbase.security.User in org.apache.hadoop.hbase.snapshot
Methods in org.apache.hadoop.hbase.snapshot with parameters of type org.apache.hadoop.hbase.security.User in inModifier and TypeMethodDescriptionstatic booleanSnapshotDescriptionUtils.isSnapshotOwner(org.apache.hadoop.hbase.client.SnapshotDescription snapshot, org.apache.hadoop.hbase.security.User user) Check if the user is this table snapshot's owner -
Uses of org.apache.hadoop.hbase.security.User in org.apache.hadoop.hbase.util
Constructors in org.apache.hadoop.hbase.util with parameters of type org.apache.hadoop.hbase.security.User in inModifierConstructorDescriptionMultiThreadedUpdaterWithACL(org.apache.hadoop.hbase.util.test.LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, double updatePercent, org.apache.hadoop.hbase.security.User userOwner, String userNames) MultiThreadedWriterWithACL(org.apache.hadoop.hbase.util.test.LoadTestDataGenerator dataGen, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User userOwner)