Uses of Class
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
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.security.User
AuthUtil.loginClient
(org.apache.hadoop.conf.Configuration conf) Deprecated.For kerberized cluster, return login user (from kinit or from keytab if specified).Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.util.JVMClusterUtil.MasterThread
LocalHBaseCluster.addMaster
(org.apache.hadoop.conf.Configuration c, int index, org.apache.hadoop.hbase.security.User user) org.apache.hadoop.hbase.util.JVMClusterUtil.RegionServerThread
LocalHBaseCluster.addRegionServer
(org.apache.hadoop.conf.Configuration config, int index, org.apache.hadoop.hbase.security.User user) org.apache.hadoop.hbase.HTableDescriptor
HTableDescriptor.setOwner
(org.apache.hadoop.hbase.security.User owner) Deprecated.since 0.94.1 -
Uses of org.apache.hadoop.hbase.security.User in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.security.User
ConnectionImplementation.user
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.security.User
AsyncConnectionImpl.getUser()
org.apache.hadoop.hbase.security.User
ClusterConnection.getUser()
Get theUser
associated with this connection.org.apache.hadoop.hbase.security.User
ConnectionImplementation.getUser()
Modifier and TypeMethodDescriptionstatic 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 passedconf
anduser
.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 passedconf
anduser
.static org.apache.hadoop.hbase.client.Connection
ConnectionFactory.createConnection
(org.apache.hadoop.conf.Configuration conf, ExecutorService pool, org.apache.hadoop.hbase.security.User user) Create a new Connection instance using the passedconf
instance.static org.apache.hadoop.hbase.client.Connection
ConnectionFactory.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 passedconf
instance.static org.apache.hadoop.hbase.client.Connection
ConnectionFactory.createConnection
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.security.User user) Create a new Connection instance using the passedconf
instance.static org.apache.hadoop.hbase.client.ClusterConnection
ServerConnectionUtils.createShortCircuitConnection
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.security.User user, org.apache.hadoop.hbase.ServerName serverName, org.apache.hadoop.hbase.shaded.protobuf.generated.AdminProtos.AdminService.BlockingInterface admin, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.BlockingInterface client, org.apache.hadoop.hbase.client.ConnectionRegistry registry) Creates a short-circuit connection that can bypass the RPC layer (serialization, deserialization, networking, etc..) when talking to a local server.org.apache.hadoop.hbase.client.TableDescriptorBuilder.ModifyableTableDescriptor
TableDescriptorBuilder.ModifyableTableDescriptor.setOwner
(org.apache.hadoop.hbase.security.User owner) Deprecated.since 2.0.0 and will be removed in 3.0.0.org.apache.hadoop.hbase.client.TableDescriptorBuilder
TableDescriptorBuilder.setOwner
(org.apache.hadoop.hbase.security.User owner) Deprecated.since 2.0.0 and will be removed in 3.0.0.ModifierConstructorDescriptionAsyncConnectionImpl
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.ConnectionRegistry registry, String clusterId, org.apache.hadoop.hbase.security.User user) AsyncConnectionImpl
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.ConnectionRegistry registry, String clusterId, 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
Modifier 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()
ModifierConstructorDescriptionObserverContextImpl
(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
Modifier and TypeFieldDescriptionprotected final org.apache.hadoop.hbase.security.User
AbstractRpcClient.AbstractRpcChannel.ticket
protected final org.apache.hadoop.hbase.security.User
AbstractRpcClient.AbstractRpcChannel.ticket
protected final org.apache.hadoop.hbase.security.User
ServerCall.user
Modifier 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()
Modifier and TypeMethodDescriptionorg.apache.hbase.thirdparty.com.google.protobuf.BlockingRpcChannel
AbstractRpcClient.createBlockingRpcChannel
(org.apache.hadoop.hbase.ServerName sn, org.apache.hadoop.hbase.security.User ticket, int rpcTimeout) org.apache.hbase.thirdparty.com.google.protobuf.BlockingRpcChannel
RpcClient.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.RpcChannel
AbstractRpcClient.createRpcChannel
(org.apache.hadoop.hbase.ServerName sn, org.apache.hadoop.hbase.security.User user, int rpcTimeout) org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel
RpcClient.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.int
PriorityFunction.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.ModifierConstructorDescriptionprotected
BlockingRpcChannelImplementation
(org.apache.hadoop.hbase.ipc.AbstractRpcClient<?> rpcClient, org.apache.hadoop.hbase.net.Address addr, org.apache.hadoop.hbase.security.User ticket, int rpcTimeout) protected
RpcChannelImplementation
(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
Modifier and TypeMethodDescriptionint
MasterAnnotationReadingPriorityFunction.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) void
MasterCoprocessorHost.postCompletedCreateTableAction
(org.apache.hadoop.hbase.client.TableDescriptor htd, org.apache.hadoop.hbase.client.RegionInfo[] regions, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.postCompletedDeleteTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.postCompletedDisableTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.postCompletedEnableTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.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 operationvoid
MasterCoprocessorHost.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) void
MasterCoprocessorHost.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 splitvoid
MasterCoprocessorHost.postCompletedTruncateTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.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:metavoid
MasterCoprocessorHost.postRollBackMergeRegionsAction
(org.apache.hadoop.hbase.client.RegionInfo[] regionsToMerge, org.apache.hadoop.hbase.security.User user) Invoked after rollback merge regions operationvoid
MasterCoprocessorHost.postRollBackSplitRegionAction
(org.apache.hadoop.hbase.security.User user) Invoked just after the rollback of a failed splitvoid
MasterCoprocessorHost.postSnapshot
(org.apache.hadoop.hbase.client.SnapshotDescription snapshot, org.apache.hadoop.hbase.client.TableDescriptor hTableDescriptor, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.postTruncateRegionAction
(org.apache.hadoop.hbase.client.RegionInfo region, org.apache.hadoop.hbase.security.User user) Invoked after calling the truncate region procedurevoid
MasterCoprocessorHost.preCreateTableAction
(org.apache.hadoop.hbase.client.TableDescriptor htd, org.apache.hadoop.hbase.client.RegionInfo[] regions, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.preDeleteTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.preDisableTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.preEnableTableAction
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.preMergeRegionsAction
(org.apache.hadoop.hbase.client.RegionInfo[] regionsToMerge, org.apache.hadoop.hbase.security.User user) Invoked just before a mergevoid
MasterCoprocessorHost.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:metavoid
MasterCoprocessorHost.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) void
MasterCoprocessorHost.preSnapshot
(org.apache.hadoop.hbase.client.SnapshotDescription snapshot, org.apache.hadoop.hbase.client.TableDescriptor hTableDescriptor, org.apache.hadoop.hbase.security.User user) void
MasterCoprocessorHost.preSplitAfterMETAAction
(org.apache.hadoop.hbase.security.User user) This will be called after update META step as part of split table region procedure.void
MasterCoprocessorHost.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.void
MasterCoprocessorHost.preSplitRegionAction
(org.apache.hadoop.hbase.TableName tableName, byte[] splitRow, org.apache.hadoop.hbase.security.User user) Invoked just before a splitvoid
MasterCoprocessorHost.preTruncateRegionAction
(org.apache.hadoop.hbase.client.RegionInfo region, org.apache.hadoop.hbase.security.User user) Invoked just before calling the truncate region procedurevoid
MasterCoprocessorHost.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
Modifier 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
Modifier and TypeMethodDescriptionboolean
HRegion.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) 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) int
AnnotationReadingPriorityFunction.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.int
RSRpcServices.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) void
RegionCoprocessorHost.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.void
RegionCoprocessorHost.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 theHStoreFile
s to be compacted have been selected from the available candidates.void
RegionCoprocessorHost.preCleanupBulkLoad
(org.apache.hadoop.hbase.security.User user) org.apache.hadoop.hbase.regionserver.InternalScanner
RegionCoprocessorHost.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.ScanInfo
RegionCoprocessorHost.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.boolean
RegionCoprocessorHost.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 theHStoreFile
s for compaction from the list of currently available candidates.void
RegionCoprocessorHost.prePrepareBulkLoad
(org.apache.hadoop.hbase.security.User user) void
RegionServerCoprocessorHost.preStop
(String message, org.apache.hadoop.hbase.security.User user) void
CompactSplit.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) void
CompactSplit.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 void
CompactSplit.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) void
HRegionServer.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
Modifier and TypeClassDescriptionstatic final class
org.apache.hadoop.hbase.security.User.SecureHadoopUser
BridgesUser
invocations to underlying calls toUserGroupInformation
for secure Hadoop 0.20 and versions 0.21 and above.Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.security.User
User.create
(org.apache.hadoop.security.UserGroupInformation ugi) Wraps an underlyingUserGroupInformation
instance.org.apache.hadoop.hbase.security.User
UserProvider.create
(org.apache.hadoop.security.UserGroupInformation ugi) Wraps an underlyingUserGroupInformation
instance.static org.apache.hadoop.hbase.security.User
Generates a newUser
instance specifically for use in test code.static org.apache.hadoop.hbase.security.User
User.SecureHadoopUser.createUserForTesting
(org.apache.hadoop.conf.Configuration conf, String name, String[] groups) Create a user for testing.static org.apache.hadoop.hbase.security.User
User.getCurrent()
Returns theUser
instance within current execution context.org.apache.hadoop.hbase.security.User
UserProvider.getCurrent()
Return the current user within the current execution contextstatic org.apache.hadoop.hbase.security.User
Superusers.getSystemUser()
Modifier and TypeMethodDescriptionstatic boolean
Superusers.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
Modifier and TypeMethodDescriptionstatic boolean
SnapshotDescriptionUtils.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