- A - Static variable in class org.apache.hadoop.hbase.coprocessor.TestRegionObserverInterface
-
- A - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
ASCII code for 'A'
- abort(String, Throwable) - Method in interface org.apache.hadoop.hbase.Abortable
-
Abort the server or client.
- abort(String, Throwable) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- abort(Void) - Method in class org.apache.hadoop.hbase.master.procedure.TestMasterProcedureQueue.TestTableProcedure
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.master.TestActiveMasterManager.DummyMaster
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.master.TestMetaShutdownHandler.MyRegionServer
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster.MiniHBaseClusterRegionServer
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
-
- abort(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.procedure.SimpleRSProcedureManager.SimpleSubprocedurePool
-
- abort(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinatorRpcs
-
Receive a notification and propagate it to the local coordinator
- abort(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureMemberRpcs
-
Pass along the found abort notification to the listener
- abort(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
The abort() call is asynchronous and each procedure must decide how to deal
with that, if they want to be abortable.
- abort(long) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Send an abort notification the specified procedure.
- abort(long, boolean) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
-
Send an abort notification the specified procedure.
- abort(Void) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureTestingUtility.TestProcedure
-
- abort(Void) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.TestWALProcedureStore.TestSequentialProcedure
-
- abort(Void) - Method in class org.apache.hadoop.hbase.procedure2.TestProcedureExecution.TestFaultyRollback
-
- abort(Void) - Method in class org.apache.hadoop.hbase.procedure2.TestProcedureExecution.TestSequentialProcedure
-
- abort(Void) - Method in class org.apache.hadoop.hbase.procedure2.TestProcedureExecution.TestWaitingProcedure
-
- abort(Void) - Method in class org.apache.hadoop.hbase.procedure2.TestProcedureExecution.TestWaitingProcedure.TestWaitChild
-
- abort(Void) - Method in class org.apache.hadoop.hbase.procedure2.TestProcedureRecovery.BaseTestStepProcedure
-
- abort(Void) - Method in class org.apache.hadoop.hbase.procedure2.TestProcedureRecovery.TestSingleStepProcedure
-
- abort(Void) - Method in class org.apache.hadoop.hbase.procedure2.TestProcedureRecovery.TestStateMachineProcedure
-
- abort(TestProcedureReplayOrder.TestProcedureEnv) - Method in class org.apache.hadoop.hbase.procedure2.TestProcedureReplayOrder.TestSingleStepProcedure
-
- abort(TestProcedureReplayOrder.TestProcedureEnv) - Method in class org.apache.hadoop.hbase.procedure2.TestProcedureReplayOrder.TestTwoStepProcedure
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
Cause the server to exit without closing the regions it is serving, the log
it is using and without notifying the master.
- abort(String) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.master.ReplicationLogCleaner
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeerZKImpl
-
- abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.security.access.TestAccessController.TestTableDDLProcedure
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.util.MockServer
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.zookeeper.TestZooKeeperNodeTracker.StubAbortable
-
- abort(String, Throwable) - Method in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- ABORT_FLUSH_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.FlushAction
-
ABORT_FLUSH = 2;
- ABORT_ON_ERROR_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- ABORT_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- Abortable - Interface in org.apache.hadoop.hbase
-
Interface to support the aborting of a given server or client.
- abortable - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- abortable - Variable in class org.apache.hadoop.hbase.replication.ReplicationStateZKBase
-
- abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperNodeTracker
-
Used to abort if a fatal error occurs
- abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- abortCacheFlush(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- abortCacheFlush(byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Abort a cache flush.
- aborted - Variable in class org.apache.hadoop.hbase.util.MultiThreadedReader
-
- abortingHConnectionRemovesItselfFromHCM() - Method in class org.apache.hadoop.hbase.client.TestHCM
-
- abortMaster(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Cause a master to exit without shutting down entire cluster.
- abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
abort a procedure
- abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Abort a procedure
- abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- abortProcedure(RpcController, MasterProtos.AbortProcedureRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Abort a procedure.
- abortProcedure(String, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
-
Abort the procedure with the given name
- abortProcedure(com.google.protobuf.RpcController, MasterProtos.AbortProcedureRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc AbortProcedure(.AbortProcedureRequest) returns (.AbortProcedureResponse);
- abortProcedure(com.google.protobuf.RpcController, MasterProtos.AbortProcedureRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- abortProcedure(com.google.protobuf.RpcController, MasterProtos.AbortProcedureRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc AbortProcedure(.AbortProcedureRequest) returns (.AbortProcedureResponse);
- abortProcedure(com.google.protobuf.RpcController, MasterProtos.AbortProcedureRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- abortProcedureAsync(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Abort a procedure but does not block and wait for it be completely removed.
- abortProcedureAsync(long, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Abort a procedure but does not block and wait for it be completely removed.
- abortProcedureResult(MasterProtos.AbortProcedureRequest) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
-
- abortProcess() - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureEnv.MasterProcedureStoreListener
-
- abortProcess() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureStoreListener
-
triggered when the store is not able to write out data.
- abortRegionServer(int) - Method in class org.apache.hadoop.hbase.MiniHBaseCluster
-
Cause a region server to exit doing basic clean up only on its way out.
- abortServer(CoprocessorEnvironment, Throwable) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- abortServer(String, Throwable) - Method in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
-
- abortTask(TaskAttemptContext) - Method in class org.apache.hadoop.hbase.mapreduce.TableOutputCommitter
-
- abortWriters() - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter
-
- abortZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- absoluteValueOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeCell
-
- AbstractByteRange - Class in org.apache.hadoop.hbase.util
-
An abstract implementation of the ByteRange API
- AbstractByteRange() - Constructor for class org.apache.hadoop.hbase.util.AbstractByteRange
-
- AbstractClientScanner - Class in org.apache.hadoop.hbase.client
-
Helper class for custom client scanners.
- AbstractClientScanner() - Constructor for class org.apache.hadoop.hbase.client.AbstractClientScanner
-
- AbstractHBaseTool - Class in org.apache.hadoop.hbase.util
-
Common base class used for HBase command-line tools.
- AbstractHBaseTool() - Constructor for class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- AbstractHFileReader - Class in org.apache.hadoop.hbase.io.hfile
-
Common functionality needed by all versions of
HFile
readers.
- AbstractHFileReader(Path, FixedFileTrailer, long, CacheConfig, HFileSystem, Configuration) - Constructor for class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
- AbstractHFileReader.BlockIndexNotLoadedException - Exception in org.apache.hadoop.hbase.io.hfile
-
- AbstractHFileReader.NotSeekedException - Exception in org.apache.hadoop.hbase.io.hfile
-
An exception thrown when an operation requiring a scanner to be seeked
is invoked on a scanner that is not seeked.
- AbstractHFileReader.Scanner - Class in org.apache.hadoop.hbase.io.hfile
-
- AbstractHFileWriter - Class in org.apache.hadoop.hbase.io.hfile
-
Common functionality needed by all versions of
HFile
writers.
- AbstractHFileWriter(CacheConfig, FSDataOutputStream, Path, KeyValue.KVComparator, HFileContext) - Constructor for class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
- AbstractPositionedByteRange - Class in org.apache.hadoop.hbase.util
-
- AbstractPositionedByteRange() - Constructor for class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
-
- AbstractRpcClient - Class in org.apache.hadoop.hbase.ipc
-
Provides the basics for a RpcClient implementation like configuration and Logging.
- AbstractRpcClient(Configuration, String, SocketAddress) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient
-
Construct an IPC client for the cluster clusterId
- AbstractRpcClient.BlockingRpcChannelImplementation - Class in org.apache.hadoop.hbase.ipc
-
Blocking rpc channel that goes via hbase rpc.
- AbstractScannerV2(HFileReaderV2, boolean, boolean, boolean) - Constructor for class org.apache.hadoop.hbase.io.hfile.HFileReaderV2.AbstractScannerV2
-
- AbstractTestIPC - Class in org.apache.hadoop.hbase.ipc
-
Some basic ipc tests.
- AbstractTestIPC() - Constructor for class org.apache.hadoop.hbase.ipc.AbstractTestIPC
-
- AbstractTestShell - Class in org.apache.hadoop.hbase.client
-
- AbstractTestShell() - Constructor for class org.apache.hadoop.hbase.client.AbstractTestShell
-
- ACCENT - Static variable in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabels
-
- ACCENT - Static variable in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabelsReplication
-
- accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
-
- accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
-
- accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.BlackListDirFilter
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.FamilyDirFilter
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.HFileFilter
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.ReferenceFileFilter
-
- accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
-
- ACCEPT_POLICY_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
The strategy for handling new accepted connections.
- ACCEPT_QUEUE_SIZE_PER_THREAD_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.HThreadedSelectorServerArgs
-
Maximum number of accepted elements per selector
- access(long) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
-
Block has been accessed.
- AccessControlClient - Class in org.apache.hadoop.hbase.security.access
-
Utility client for doing access control admin operations.
- AccessControlClient() - Constructor for class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- AccessControlConstants - Interface in org.apache.hadoop.hbase.security.access
-
- AccessController - Class in org.apache.hadoop.hbase.security.access
-
Provides basic authorization checks for data access and administrative
operations.
- AccessController() - Constructor for class org.apache.hadoop.hbase.security.access.AccessController
-
- AccessControlLists - Class in org.apache.hadoop.hbase.security.access
-
Maintains lists of permission grants to users and groups to allow for
authorization checks by
AccessController
.
- AccessControlLists() - Constructor for class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- AccessControlProtos - Class in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.AccessControlService - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf service AccessControlService
- AccessControlProtos.AccessControlService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.AccessControlService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.AccessControlService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.CheckPermissionsRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CheckPermissionsRequest
- AccessControlProtos.CheckPermissionsRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CheckPermissionsRequest
- AccessControlProtos.CheckPermissionsRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.CheckPermissionsResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CheckPermissionsResponse
- AccessControlProtos.CheckPermissionsResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CheckPermissionsResponse
- AccessControlProtos.CheckPermissionsResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.GetUserPermissionsRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetUserPermissionsRequest
- AccessControlProtos.GetUserPermissionsRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetUserPermissionsRequest
- AccessControlProtos.GetUserPermissionsRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.GetUserPermissionsResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetUserPermissionsResponse
- AccessControlProtos.GetUserPermissionsResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetUserPermissionsResponse
- AccessControlProtos.GetUserPermissionsResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.GlobalPermission - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GlobalPermission
- AccessControlProtos.GlobalPermission.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GlobalPermission
- AccessControlProtos.GlobalPermissionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.GrantRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GrantRequest
- AccessControlProtos.GrantRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GrantRequest
- AccessControlProtos.GrantRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.GrantResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GrantResponse
- AccessControlProtos.GrantResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GrantResponse
- AccessControlProtos.GrantResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.NamespacePermission - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type NamespacePermission
- AccessControlProtos.NamespacePermission.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type NamespacePermission
- AccessControlProtos.NamespacePermissionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.Permission - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Permission
- AccessControlProtos.Permission.Action - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum Permission.Action
- AccessControlProtos.Permission.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Permission
- AccessControlProtos.Permission.Type - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum Permission.Type
- AccessControlProtos.PermissionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.RevokeRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RevokeRequest
- AccessControlProtos.RevokeRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RevokeRequest
- AccessControlProtos.RevokeRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.RevokeResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RevokeResponse
- AccessControlProtos.RevokeResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RevokeResponse
- AccessControlProtos.RevokeResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.TablePermission - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type TablePermission
- AccessControlProtos.TablePermission.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type TablePermission
- AccessControlProtos.TablePermissionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.UserPermission - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UserPermission
- AccessControlProtos.UserPermission.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UserPermission
- AccessControlProtos.UserPermissionOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.UsersAndPermissions - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UsersAndPermissions
- AccessControlProtos.UsersAndPermissions.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UsersAndPermissions
- AccessControlProtos.UsersAndPermissions.UserPermissions - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UsersAndPermissions.UserPermissions
- AccessControlProtos.UsersAndPermissions.UserPermissions.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UsersAndPermissions.UserPermissions
- AccessControlProtos.UsersAndPermissions.UserPermissionsOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlProtos.UsersAndPermissionsOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AccessControlService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.AccessControlService
-
- AccessDeniedException - Exception in org.apache.hadoop.hbase.security
-
Exception thrown by access-related methods.
- AccessDeniedException() - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
-
- AccessDeniedException(Class<?>, String) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
-
- AccessDeniedException(String) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
-
- AccessDeniedException(Throwable) - Constructor for exception org.apache.hadoop.hbase.security.AccessDeniedException
-
- ACL_GLOBAL_NAME - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- ACL_KEY_DELIMITER - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Delimiter to separate user, column family, and qualifier in
_acl_ table info: column keys
- ACL_LIST_FAMILY - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
- ACL_LIST_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Column family used to store ACL grants
- ACL_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlClient
-
- ACL_TABLE_NAME - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
Internal storage table for access control lists
- ACL_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.security.access.AccessControlLists
-
KV tag to store per cell access control lists
- ACL_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
-
- acquire() - Method in interface org.apache.hadoop.hbase.InterProcessLock
-
Acquire the lock, waiting indefinitely until the lock is released or
the thread is interrupted.
- acquire() - Method in class org.apache.hadoop.hbase.master.procedure.TestMasterProcedureQueue.TestTableProcSet
-
- acquire() - Method in interface org.apache.hadoop.hbase.master.TableLockManager.TableLock
-
Acquire the lock, with the configured lock timeout.
- acquire() - Method in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
Acquire the lock, waiting indefinitely until the lock is released or
the thread is interrupted.
- acquireBarrier() - Method in class org.apache.hadoop.hbase.procedure.flush.FlushTableSubprocedure
-
Flush the online regions on this rs for the target table.
- acquireBarrier() - Method in class org.apache.hadoop.hbase.procedure.SimpleRSProcedureManager.SimpleSubprocedure
-
- acquireBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure
-
The implementation of this method should gather and hold required resources (locks, disk
space, etc) to satisfy the Procedures barrier condition.
- acquireBarrier() - Method in class org.apache.hadoop.hbase.procedure.Subprocedure.SubprocedureImpl
-
- acquireBarrier() - Method in class org.apache.hadoop.hbase.regionserver.snapshot.FlushSnapshotSubprocedure
-
- ACQUIRED_BARRIER_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- acquireDelegationToken(FileSystem) - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
-
Acquire the delegation token for the specified filesytem.
- acquiredLock - Variable in class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase
-
- AcquiredLock(String, int) - Constructor for class org.apache.hadoop.hbase.zookeeper.lock.ZKInterProcessLockBase.AcquiredLock
-
Store information about a lock.
- acquiredZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteColumnFamilyProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DisableTableProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.EnableTableProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyColumnFamilyProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
-
- acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.TruncateTableProcedure
-
- acquireLock(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
The user should override this method, and try to take a lock if necessary.
- acquireLock(TestProcedureReplayOrder.TestProcedureEnv) - Method in class org.apache.hadoop.hbase.procedure2.TestProcedureReplayOrder.TestSingleStepProcedure
-
- acquireLock(TestProcedureReplayOrder.TestProcedureEnv) - Method in class org.apache.hadoop.hbase.procedure2.TestProcedureReplayOrder.TestTwoStepProcedure
-
- acquireLock(K) - Method in class org.apache.hadoop.hbase.util.KeyLocker
-
Return a lock for the given key.
- acquireLocks(Set<? extends K>) - Method in class org.apache.hadoop.hbase.util.KeyLocker
-
Acquire locks for a set of keys.
- acquireRegionLock(String) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
To avoid racing with AM, external entities may need to lock a region,
for example, when SSH checks what regions to skip re-assigning.
- Action - Class in org.apache.hadoop.hbase.chaos.actions
-
A (possibly mischievous) action that the ChaosMonkey can perform.
- Action() - Constructor for class org.apache.hadoop.hbase.chaos.actions.Action
-
- Action<R> - Class in org.apache.hadoop.hbase.client
-
A Get, Put, Increment, Append, or Delete associated with it's region.
- Action(Row, int) - Constructor for class org.apache.hadoop.hbase.client.Action
-
- Action(Action<R>, int) - Constructor for class org.apache.hadoop.hbase.client.Action
-
Creates an action for a particular replica from original action.
- Action(BaseLoadBalancer.Cluster.Action.Type) - Constructor for class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.Action
-
- Action.ActionContext - Class in org.apache.hadoop.hbase.chaos.actions
-
Context for Action's
- ACTION_BY_CODE - Static variable in class org.apache.hadoop.hbase.security.access.Permission
-
- ACTION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission
-
- ACTION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission
-
- ACTION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission
-
- ACTION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
- ACTION_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor
-
- ActionContext(IntegrationTestingUtility) - Constructor for class org.apache.hadoop.hbase.chaos.actions.Action.ActionContext
-
- actions - Variable in class org.apache.hadoop.hbase.client.MultiAction
-
- actions - Variable in class org.apache.hadoop.hbase.security.access.Permission
-
- activateFailure - Static variable in class org.apache.hadoop.hbase.regionserver.wal.InstrumentedLogWriter
-
- ActiveMasterManager - Class in org.apache.hadoop.hbase.master
-
Handles everything on master-side related to master election.
- actualErrorRate() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Computes the error rate for this Bloom filter, taking into account the
actual number of hash functions and keys inserted.
- actualErrorRate(long, long, int) - Static method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
Computes the actual error rate for the given number of elements, number
of bits, and number of hash functions.
- add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Append
-
Add the specified column and value to this Append operation.
- add(Cell) - Method in class org.apache.hadoop.hbase.client.Append
-
Add column and value to this Append operation.
- add(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
-
- add(Double, Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
-
- add(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
-
- add(Map.Entry<byte[], List<Action<T>>>) - Method in class org.apache.hadoop.hbase.client.DelayingRunner
-
- add(Cell) - Method in class org.apache.hadoop.hbase.client.Increment
-
Add the specified KeyValue to this operation.
- add(byte[], Action<R>) - Method in class org.apache.hadoop.hbase.client.MultiAction
-
Add an Action to this container based on it's regionName.
- add(byte[], List<Action<R>>) - Method in class org.apache.hadoop.hbase.client.MultiAction
-
Add an Action to this container based on it's regionName.
- add(byte[], int, Object) - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
Add the pair to the container, grouped by the regionName
- add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
- add(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
- add(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
-
- add(Cell) - Method in class org.apache.hadoop.hbase.client.Put
-
Add the specified KeyValue to this Put operation.
- add(Put) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
Add a
Put
operation to the list of mutations
- add(Delete) - Method in class org.apache.hadoop.hbase.client.RowMutations
-
Add a
Delete
operation to the list of mutations
- add(byte) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.CellTypeEncoder
-
methods
- add(long) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.LongEncoder
-
methods
- add(Configuration) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
Add Hadoop Configuration object to config list.
- add(HTableDescriptor, Class<? extends Constraint>...) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Add configuration-less constraints to the table.
- add(HTableDescriptor, Pair<Class<? extends Constraint>, Configuration>...) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Add constraints and their associated configurations to the table.
- add(HTableDescriptor, Class<? extends Constraint>, Configuration) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
-
Add a
Constraint
to the table with the given configuration
- add(S, S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
-
- add(HDFSBlocksDistribution) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
This will add the distribution from input to this object
- add(Map.Entry<BlockCacheKey, BucketCache.BucketEntry>) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
-
Attempt to add the specified entry to this queue.
- add(LruCachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
-
Attempt to add the specified cached block to this queue.
- add(ServerName) - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Adds the server to the dead server list if it's not there already.
- add(String) - Method in class org.apache.hadoop.hbase.monitoring.MemoryBoundedLogMessageBuffer
-
Append the given message to this buffer, automatically evicting
older messages until the desired memory limit is achieved.
- add(TKey, TQueue) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureFairRunQueues
-
- add(E) - Method in class org.apache.hadoop.hbase.procedure2.util.TimeoutBlockingQueue
-
- add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DefaultMemStore
-
Write an update
- add(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.DeleteTracker
-
Add the specified cell to the list of deletes to check against for
this row operation.
- add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- add(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
-
Write an update
- add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ScanDeleteTracker
-
Add the specified KeyValue to the list of deletes to check against for
this row operation.
- add(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
Adds a value to the memstore
- add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.wal.WALEdit
-
- add(String) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
Add a node to the cluster
- add(String, int) - Method in class org.apache.hadoop.hbase.rest.client.Cluster
-
Add a node to the cluster
- add(TableRegionModel) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
-
Add a region model to the list
- add(TableModel) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
-
Add the table name model to the list
- add(Cell) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
-
- add(HTableDescriptor) - Method in interface org.apache.hadoop.hbase.TableDescriptors
-
Add or update descriptor
- add(MetricsTag) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl.MockRecordBuilder
-
- add(AbstractMetric) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl.MockRecordBuilder
-
- add(Runnable) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- add(DataType<?>) - Method in class org.apache.hadoop.hbase.types.StructBuilder
-
Append field
to the sequence of accumulated fields.
- add(byte[], int, int) - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Add the specified binary to the bloom filter.
- add(byte[]) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- add(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- add(ByteRange) - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
-
Check if the incoming byte range exists.
- add(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- add(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- add(byte[][]) - Static method in class org.apache.hadoop.hbase.util.Bytes
-
- add(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
Adds a Bloom filter key.
- add(T) - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- add(E) - Method in class org.apache.hadoop.hbase.util.ConstantDelayQueue
-
- add(long) - Method in class org.apache.hadoop.hbase.util.Counter
-
- add(HTableDescriptor) - Method in class org.apache.hadoop.hbase.util.FSTableDescriptors
-
Adds (or updates) the table descriptor to the FileSystem
and updates the local cache with it.
- add(R) - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
-
Adds an edge to the split calculator
- add(E) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- add(long) - Method in class org.apache.hadoop.metrics2.lib.MetricMutableQuantiles
-
- add(long) - Method in class org.apache.hadoop.metrics2.lib.MutableHistogram
-
- add(long) - Method in interface org.apache.hadoop.metrics2.MetricHistogram
-
Add a single value to a histogram's stream of values.
- ADD_COLUMN_FAMILY_POST_OPERATION_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyState
-
ADD_COLUMN_FAMILY_POST_OPERATION = 4;
- ADD_COLUMN_FAMILY_PRE_OPERATION_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyState
-
ADD_COLUMN_FAMILY_PRE_OPERATION = 2;
- ADD_COLUMN_FAMILY_PREPARE_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyState
-
ADD_COLUMN_FAMILY_PREPARE = 1;
- ADD_COLUMN_FAMILY_REOPEN_ALL_REGIONS_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyState
-
ADD_COLUMN_FAMILY_REOPEN_ALL_REGIONS = 5;
- ADD_COLUMN_FAMILY_UPDATE_TABLE_DESCRIPTOR_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.AddColumnFamilyState
-
ADD_COLUMN_FAMILY_UPDATE_TABLE_DESCRIPTOR = 3;
- addAction(AccessControlProtos.Permission.Action) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission.Builder
-
repeated .Permission.Action action = 1;
- addAction(AccessControlProtos.Permission.Action) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
repeated .Permission.Action action = 2;
- addAction(AccessControlProtos.Permission.Action) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
repeated .Permission.Action action = 4;
- addAction(ClientProtos.Action) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- addAction(int, ClientProtos.Action) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- addAction(ClientProtos.Action.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- addAction(int, ClientProtos.Action.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- addActionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- addActionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- addAll(ArrayList<ByteRange>) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
building
- addAll(Collection<? extends Cell>) - Method in class org.apache.hadoop.hbase.regionserver.CellSkipListSet
-
- addAll(Collection<? extends Runnable>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
-
- addAll(Collection<? extends T>) - Method in class org.apache.hadoop.hbase.util.BoundedConcurrentLinkedQueue
-
- addAll(Collection<? extends T>) - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- addAll(Collection<? extends E>) - Method in class org.apache.hadoop.hbase.util.ConstantDelayQueue
-
- addAll(Collection<? extends E>) - Method in class org.apache.hadoop.hbase.util.SortedCopyOnWriteSet
-
- addAllAction(Iterable<? extends AccessControlProtos.Permission.Action>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GlobalPermission.Builder
-
repeated .Permission.Action action = 1;
- addAllAction(Iterable<? extends AccessControlProtos.Permission.Action>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.NamespacePermission.Builder
-
repeated .Permission.Action action = 2;
- addAllAction(Iterable<? extends AccessControlProtos.Permission.Action>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.TablePermission.Builder
-
repeated .Permission.Action action = 4;
- addAllAction(Iterable<? extends ClientProtos.Action>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction.Builder
-
repeated .Action action = 3;
- addAllAttribute(Iterable<? extends HBaseProtos.NameBytesPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- addAllAttribute(Iterable<? extends HBaseProtos.NameBytesPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- addAllAttribute(Iterable<? extends HBaseProtos.NameBytesPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- addAllAttributes(Iterable<? extends HBaseProtos.BytesBytesPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- addAllAttributes(Iterable<? extends HBaseProtos.BytesBytesPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- addAllAttrs(Iterable<? extends ColumnSchemaMessage.ColumnSchema.Attribute>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- addAllAttrs(Iterable<? extends TableSchemaMessage.TableSchema.Attribute>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- addAllAuth(Iterable<? extends com.google.protobuf.ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
repeated bytes auth = 2;
- addAllAuth(Iterable<? extends com.google.protobuf.ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
repeated bytes auth = 2;
- addAllAuth(Iterable<? extends Integer>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
repeated uint32 auth = 2;
- addAllBackupMasters(Iterable<? extends HBaseProtos.ServerName>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- addAllCell(Iterable<? extends CellProtos.Cell>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- addAllCellsPerResult(Iterable<? extends Integer>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated uint32 cells_per_result = 1;
- addAllClusterIds(Iterable<? extends HBaseProtos.UUID>) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- addAllColumn(Iterable<? extends ClientProtos.Column>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- addAllColumn(Iterable<? extends ClientProtos.Column>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- addAllColumnFamilies(Iterable<? extends HBaseProtos.ColumnFamilySchema>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- addAllColumns(Iterable<? extends com.google.protobuf.ByteString>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
repeated bytes columns = 3;
- addAllColumns(Iterable<? extends ColumnSchemaMessage.ColumnSchema>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- addAllColumnValue(Iterable<? extends ClientProtos.MutationProto.ColumnValue>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- addAllCompactionInput(Iterable<String>) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_input = 4;
- addAllCompactionOutput(Iterable<String>) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_output = 5;
- addAllConfiguration(Iterable<? extends HBaseProtos.NameStringPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- addAllConfiguration(Iterable<? extends HBaseProtos.NameStringPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- addAllConfiguration(Iterable<? extends HBaseProtos.NameStringPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- addAllConfiguration(Iterable<? extends HBaseProtos.NameStringPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- addAllConfiguration(Iterable<? extends HBaseProtos.NameStringPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- addAllCoprocessors(Iterable<? extends HBaseProtos.Coprocessor>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- addAllData(Iterable<? extends HBaseProtos.BytesBytesPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- addAllDeadNodes(Iterable<String>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated string deadNodes = 2;
- addAllDeadServers(Iterable<? extends HBaseProtos.ServerName>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- addAllDeleted(Iterable<? extends Long>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
repeated uint64 deleted = 3;
- addAllEntry(Iterable<? extends AdminProtos.WALEntry>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- addAllFamily(Iterable<? extends com.google.protobuf.ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
repeated bytes family = 2;
- addAllFamilyFiles(Iterable<? extends SnapshotProtos.SnapshotRegionManifest.FamilyFiles>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- addAllFamilyPath(Iterable<? extends ClientProtos.BulkLoadHFileRequest.FamilyPath>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- addAllFamilyPath(Iterable<? extends ClientProtos.BulkLoadHFileRequest.FamilyPath>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- addAllFavoredNode(Iterable<? extends HBaseProtos.ServerName>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- addAllFavoredNodes(Iterable<? extends HBaseProtos.ServerName>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- addAllFavoredNodes(Iterable<? extends HBaseProtos.ServerName>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- addAllFilters(Iterable<? extends FilterProtos.Filter>) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- addAllFirstPart(Iterable<? extends com.google.protobuf.ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
repeated bytes first_part = 1;
- addAllFlushOutput(Iterable<String>) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
repeated string flush_output = 3;
- addAllFuzzyKeysData(Iterable<? extends HBaseProtos.BytesBytesPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- addAllKeyValueBytes(Iterable<? extends com.google.protobuf.ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
repeated bytes key_value_bytes = 2;
- addAllLabel(Iterable<String>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
-
repeated string label = 1;
- addAllLabel(Iterable<? extends com.google.protobuf.ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse.Builder
-
repeated bytes label = 1;
- addAllLabels(Iterable<String>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
repeated string labels = 10;
- addAllLiveNodes(Iterable<? extends StorageClusterStatusMessage.StorageClusterStatus.Node>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- addAllLiveServers(Iterable<? extends ClusterStatusProtos.LiveServerInfo>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- addAllLocations(Iterable<String>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
repeated string locations = 2;
- addAllMapEntries(Iterable<? extends HBaseProtos.NameStringPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- addAllMapEntry(Iterable<? extends HBaseProtos.BytesBytesPair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- addAllMasterCoprocessors(Iterable<? extends HBaseProtos.Coprocessor>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- addAllMetrics(Iterable<? extends HBaseProtos.NameInt64Pair>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- addAllMutationRequest(Iterable<? extends ClientProtos.MutationProto>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- addAllName(Iterable<String>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
repeated string name = 1;
- addAllNamespaceDescriptor(Iterable<? extends HBaseProtos.NamespaceDescriptor>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- addAllNode(Iterable<? extends ProcedureProtos.ProcedureStoreTracker.TrackerNode>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- addAllocation(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
- addAllOpenInfo(Iterable<? extends AdminProtos.OpenRegionRequest.RegionOpenInfo>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- addAllOpeningState(Iterable<? extends AdminProtos.OpenRegionResponse.RegionOpeningState>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
-
repeated .OpenRegionResponse.RegionOpeningState opening_state = 1;
- addAllPartialFlagPerResult(Iterable<? extends Boolean>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated bool partial_flag_per_result = 7;
- addAllPermission(Iterable<? extends AccessControlProtos.Permission>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- addAllPermissions(Iterable<? extends AccessControlProtos.Permission>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- addAllProcedure(Iterable<? extends ProcedureProtos.Procedure>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- addAllProcedure(Iterable<? extends ProcedureProtos.Procedure>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- addAllQualifier(Iterable<? extends com.google.protobuf.ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
repeated bytes qualifier = 2;
- addAllQualifiers(Iterable<? extends com.google.protobuf.ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
-
repeated bytes qualifiers = 1;
- addAllQualifierValue(Iterable<? extends ClientProtos.MutationProto.ColumnValue.QualifierValue>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- addAllRegionAction(Iterable<? extends ClientProtos.RegionAction>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- addAllRegionActionResult(Iterable<? extends ClientProtos.RegionActionResult>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- addAllRegionInfo(Iterable<? extends HBaseProtos.RegionInfo>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- addAllRegionInfo(Iterable<? extends HBaseProtos.RegionInfo>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- addAllRegionInfo(Iterable<? extends HBaseProtos.RegionInfo>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- addAllRegionInfo(Iterable<? extends HBaseProtos.RegionInfo>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- addAllRegionInfo(Iterable<? extends HBaseProtos.RegionInfo>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- addAllRegionLoads(Iterable<? extends ClusterStatusProtos.RegionLoad>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- addAllRegionManifests(Iterable<? extends SnapshotProtos.SnapshotRegionManifest>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- addAllRegions(Iterable<? extends StorageClusterStatusMessage.StorageClusterStatus.Region>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- addAllRegions(Iterable<? extends TableInfoMessage.TableInfo.Region>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- addAllRegionsInTransition(Iterable<? extends ClusterStatusProtos.RegionInTransition>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- addAllRegionToFlush(Iterable<? extends com.google.protobuf.ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
-
repeated bytes region_to_flush = 1;
- addAllReplLoadSource(Iterable<? extends ClusterStatusProtos.ReplicationLoadSource>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- addAllResult(Iterable<String>) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest.Builder
-
repeated string result = 3;
- addAllResult(Iterable<String>) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse.Builder
-
repeated string result = 1;
- addAllResult(Iterable<? extends ClientProtos.RegionActionResult>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- addAllResultOrException(Iterable<? extends ClientProtos.ResultOrException>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- addAllResults(Iterable<? extends ClientProtos.Result>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- addAllRowRangeList(Iterable<? extends FilterProtos.RowRange>) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- addAllRows(Iterable<? extends CellSetMessage.CellSet.Row>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- addAllScopes(Iterable<? extends WALProtos.FamilyScope>) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- addAllSnapshots(Iterable<? extends HBaseProtos.SnapshotDescription>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- addAllSortedPrefixes(Iterable<? extends com.google.protobuf.ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
-
repeated bytes sorted_prefixes = 1;
- addAllSplitKeys(Iterable<? extends com.google.protobuf.ByteString>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
repeated bytes split_keys = 2;
- addAllStackId(Iterable<? extends Integer>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
repeated uint32 stack_id = 7;
- addAllState(Iterable<? extends Integer>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData.Builder
-
repeated uint32 state = 1;
- addAllStoreCompleteSequenceId(Iterable<? extends ClusterStatusProtos.StoreSequenceId>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- addAllStoreFile(Iterable<String>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
-
repeated string store_file = 1;
- addAllStoreFile(Iterable<String>) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
repeated string store_file = 3;
- addAllStoreFiles(Iterable<? extends SnapshotProtos.SnapshotRegionManifest.StoreFile>) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- addAllStoreFlushes(Iterable<? extends WALProtos.FlushDescriptor.StoreFlushDescriptor>) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- addAllStoreLastFlushedSequenceId(Iterable<? extends ClusterStatusProtos.StoreSequenceId>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- addAllStores(Iterable<? extends WALProtos.StoreDescriptor>) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- addAllStores(Iterable<? extends WALProtos.StoreDescriptor>) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- addAllStoreSequenceId(Iterable<? extends ClusterStatusProtos.StoreSequenceId>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- addAllSublists(List<? extends List<T>>) - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- addAllTableName(Iterable<? extends HBaseProtos.TableName>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- addAllTableNames(Iterable<? extends HBaseProtos.TableName>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- addAllTableNames(Iterable<? extends HBaseProtos.TableName>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- addAllTableSchema(Iterable<? extends HBaseProtos.TableSchema>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- addAllTableSchema(Iterable<? extends HBaseProtos.TableSchema>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- addAllTimestamps(Iterable<? extends Long>) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
-
repeated int64 timestamps = 1 [packed = true];
- addAllTrace(Iterable<? extends ErrorHandlingProtos.StackTraceElementMessage>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- addAllTransition(Iterable<? extends RegionServerStatusProtos.RegionStateTransition>) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- addAllUpdated(Iterable<? extends Long>) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
repeated uint64 updated = 2;
- addAllUpdateInfo(Iterable<? extends AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- addAllUserAuths(Iterable<? extends VisibilityLabelsProtos.UserAuthorizations>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- addAllUserPermission(Iterable<? extends AccessControlProtos.UserPermission>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- addAllUserPermissions(Iterable<? extends AccessControlProtos.UsersAndPermissions.UserPermissions>) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- addAllValues(Iterable<? extends CellMessage.Cell>) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- addAllVisLabel(Iterable<? extends VisibilityLabelsProtos.VisibilityLabel>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- addAndGetGlobalMemstoreSize(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Increase the size of mem store in this region and the size of global mem
store
- addAndGetGlobalMemstoreSize(long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
- addAndGetRegionReplayEditsSize(byte[], long) - Method in class org.apache.hadoop.hbase.regionserver.RegionServerAccounting
-
Add memStoreSize to replayEditsPerRegion.
- addAttribute(HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- addAttribute(int, HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- addAttribute(HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- addAttribute(int, HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- addAttribute(HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- addAttribute(int, HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- addAttribute(HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- addAttribute(int, HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- addAttribute(HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- addAttribute(int, HBaseProtos.NameBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- addAttribute(HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- addAttribute(int, HBaseProtos.NameBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- addAttribute(String, Object) - Method in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
-
Add an attribute to the column family schema
- addAttribute(String, Object) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Add an attribute to the table descriptor
- addAttributeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- addAttributeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .NameBytesPair attribute = 3;
- addAttributeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- addAttributeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .NameBytesPair attribute = 5;
- addAttributeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- addAttributeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .NameBytesPair attribute = 2;
- addAttributes(HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- addAttributes(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- addAttributes(HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- addAttributes(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- addAttributes(HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- addAttributes(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- addAttributes(HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- addAttributes(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- addAttributesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- addAttributesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- addAttributesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- addAttributesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .BytesBytesPair attributes = 2;
- addAttrs(ColumnSchemaMessage.ColumnSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- addAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- addAttrs(ColumnSchemaMessage.ColumnSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- addAttrs(int, ColumnSchemaMessage.ColumnSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- addAttrs(TableSchemaMessage.TableSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- addAttrs(int, TableSchemaMessage.TableSchema.Attribute) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- addAttrs(TableSchemaMessage.TableSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- addAttrs(int, TableSchemaMessage.TableSchema.Attribute.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- addAttrsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- addAttrsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema.Attribute attrs = 2;
- addAttrsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- addAttrsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableSchema.Attribute attrs = 2;
- addAuth(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse.Builder
-
repeated bytes auth = 2;
- addAuth(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest.Builder
-
repeated bytes auth = 2;
- addAuth(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations.Builder
-
repeated uint32 auth = 2;
- addBack(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
- addBack(TableProcedureInterface) - Method in class org.apache.hadoop.hbase.master.procedure.TestMasterProcedureQueue.TestTableProcSet
-
- addBack(Procedure) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureRunnableSet
-
Inserts the specified element at the end of this queue.
- addBack(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureSimpleRunQueue
-
- addBackupMasters(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- addBackupMasters(int, HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- addBackupMasters(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- addBackupMasters(int, HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- addBackupMastersBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- addBackupMastersBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName backup_masters = 8;
- addCallSize(long) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
- addCallSize(long) - Method in interface org.apache.hadoop.hbase.ipc.RpcServerInterface
-
Add/subtract from the current size of all outstanding calls.
- addCell(CellProtos.Cell) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- addCell(int, CellProtos.Cell) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- addCell(CellProtos.Cell.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- addCell(int, CellProtos.Cell.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- addCell(CellModel) - Method in class org.apache.hadoop.hbase.rest.model.RowModel
-
Adds a cell to the list of cells for this row
- addCellBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- addCellBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result.Builder
-
repeated .Cell cell = 1;
- addCellsPerResult(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated uint32 cells_per_result = 1;
- addChangedReaderObserver(ChangedReadersObserver) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- addChangedReaderObserver(ChangedReadersObserver) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- addChild(TokenizerNode) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- addChildExp(ExpressionNode) - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- addChildExps(List<ExpressionNode>) - Method in class org.apache.hadoop.hbase.security.visibility.expression.NonLeafExpressionNode
-
- addClientPort(int) - Method in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
-
Add a client port to the list.
- addClusterId(UUID) - Method in class org.apache.hadoop.hbase.wal.WALKey
-
Marks that the cluster with the given clusterId has consumed the change
- addClusterIds(HBaseProtos.UUID) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- addClusterIds(int, HBaseProtos.UUID) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- addClusterIds(HBaseProtos.UUID.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- addClusterIds(int, HBaseProtos.UUID.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- addClusterIdsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- addClusterIdsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .UUID cluster_ids = 8;
- addColumn(TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
-
Add a column to an existing table.
- addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete the latest version of the specified column.
- addColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete the specified version of the specified column.
- addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Get
-
Get the column from the specific family with the specified qualifier.
- addColumn(byte[], HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Add a column to an existing table.
- addColumn(String, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Add a column to an existing table.
- addColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
Add a column to an existing table.
- addColumn(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Increment
-
Increment the column from the specific family with the specified qualifier
by the specified amount.
- addColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
Add the specified column and value to this Put operation.
- addColumn(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
Add the specified column and value, with the specified timestamp as
its version to this Put operation.
- addColumn(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
-
Add the specified column and value, with the specified timestamp as
its version to this Put operation.
- addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get the column from the specified family with the specified qualifier.
- addColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- addColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.master.MasterFileSystem
-
Add column to a table
- addColumn(RpcController, MasterProtos.AddColumnRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- addColumn(TableName, HColumnDescriptor) - Method in interface org.apache.hadoop.hbase.master.MasterServices
-
Add a new column to an existing table
- addColumn(ClientProtos.Column) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- addColumn(int, ClientProtos.Column) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- addColumn(ClientProtos.Column.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- addColumn(int, ClientProtos.Column.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- addColumn(ClientProtos.Column) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- addColumn(int, ClientProtos.Column) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- addColumn(ClientProtos.Column.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- addColumn(int, ClientProtos.Column.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- addColumn(com.google.protobuf.RpcController, MasterProtos.AddColumnRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc AddColumn(.AddColumnRequest) returns (.AddColumnResponse);
- addColumn(com.google.protobuf.RpcController, MasterProtos.AddColumnRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- addColumn(com.google.protobuf.RpcController, MasterProtos.AddColumnRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc AddColumn(.AddColumnRequest) returns (.AddColumnResponse);
- addColumn(com.google.protobuf.RpcController, MasterProtos.AddColumnRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- addColumn(byte[]) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Add a column to the column set
- addColumn(byte[]) - Method in class org.apache.hadoop.hbase.rest.RowSpec
-
- AddColumnAction - Class in org.apache.hadoop.hbase.chaos.actions
-
Action the adds a column family to a table.
- AddColumnAction(TableName) - Constructor for class org.apache.hadoop.hbase.chaos.actions.AddColumnAction
-
- addColumnBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- addColumnBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get.Builder
-
repeated .Column column = 2;
- addColumnBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- addColumnBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan.Builder
-
repeated .Column column = 1;
- addColumnFamilies(HBaseProtos.ColumnFamilySchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- addColumnFamilies(int, HBaseProtos.ColumnFamilySchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- addColumnFamilies(HBaseProtos.ColumnFamilySchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- addColumnFamilies(int, HBaseProtos.ColumnFamilySchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- addColumnFamiliesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- addColumnFamiliesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .ColumnFamilySchema column_families = 3;
- addColumnFamily(ColumnSchemaModel) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
-
Add a column family to the table descriptor
- AddColumnFamilyProcedure - Class in org.apache.hadoop.hbase.master.procedure
-
The procedure to add a column family to an existing table.
- AddColumnFamilyProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- AddColumnFamilyProcedure(MasterProcedureEnv, TableName, HColumnDescriptor) - Constructor for class org.apache.hadoop.hbase.master.procedure.AddColumnFamilyProcedure
-
- addColumns(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all versions of the specified column.
- addColumns(byte[], byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all versions of the specified column with a timestamp less than
or equal to the specified timestamp.
- addColumns(Scan, byte[][]) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
-
Adds an array of columns specified using old format, family:qualifier.
- addColumns(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
repeated bytes columns = 3;
- addColumns(ColumnSchemaMessage.ColumnSchema) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- addColumns(int, ColumnSchemaMessage.ColumnSchema) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- addColumns(ColumnSchemaMessage.ColumnSchema.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- addColumns(int, ColumnSchemaMessage.ColumnSchema.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- addColumnsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- addColumnsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchema columns = 3;
- addColumnValue(ClientProtos.MutationProto.ColumnValue) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- addColumnValue(int, ClientProtos.MutationProto.ColumnValue) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- addColumnValue(ClientProtos.MutationProto.ColumnValue.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- addColumnValue(int, ClientProtos.MutationProto.ColumnValue.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- addColumnValueBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- addColumnValueBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Builder
-
repeated .MutationProto.ColumnValue column_value = 3;
- addCommandDescriptor(Class<? extends PerformanceEvaluation.Test>, String, String) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluation
-
- addCommandDescriptor(Class<? extends PerformanceEvaluation.Test>, String, String) - Method in class org.apache.hadoop.hbase.rest.PerformanceEvaluation
-
- addCommas(Number) - Static method in class org.apache.hadoop.hbase.util.number.NumberFormatter
-
- addCompactionInput(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_input = 4;
- addCompactionInputBytes(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_input = 4;
- addCompactionOutput(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_output = 5;
- addCompactionOutputBytes(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor.Builder
-
repeated string compaction_output = 5;
- addCompactionResults(Collection<StoreFile>, Collection<StoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
-
Adds compaction results into the structure.
- addCompactionResults(Collection<StoreFile>, Collection<StoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
-
- addConfiguration(Map<String, String>) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
-
- addConfiguration(String, String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
-
- addConfiguration(HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- addConfiguration(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- addConfiguration(HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- addConfiguration(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- addConfiguration(HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- addConfiguration(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- addConfiguration(HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- addConfiguration(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- addConfiguration(HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- addConfiguration(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- addConfiguration(HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- addConfiguration(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- addConfiguration(HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- addConfiguration(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- addConfiguration(HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- addConfiguration(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- addConfiguration(HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- addConfiguration(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- addConfiguration(HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- addConfiguration(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- addConfigurationBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- addConfigurationBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema.Builder
-
repeated .NameStringPair configuration = 3;
- addConfigurationBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- addConfigurationBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.NamespaceDescriptor.Builder
-
repeated .NameStringPair configuration = 2;
- addConfigurationBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- addConfigurationBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ProcedureDescription.Builder
-
repeated .NameStringPair configuration = 4;
- addConfigurationBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- addConfigurationBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema.Builder
-
repeated .NameStringPair configuration = 4;
- addConfigurationBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- addConfigurationBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .NameStringPair configuration = 4;
- addContent(Region, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
Add content to region r
on the passed column
column
.
- addContent(Region, byte[]) - Static method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
- addContent(HBaseTestCase.Incommon, String) - Static method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
Add content to region r
on the passed column
column
.
- addContent(HBaseTestCase.Incommon, String, String) - Static method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
- addContent(HBaseTestCase.Incommon, String, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
Add content to region r
on the passed column
column
.
- addContent(HBaseTestCase.Incommon, String, String, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
- addContent(HBaseTestCase.Incommon, String, String, byte[], byte[], long) - Static method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
Add content to region r
on the passed column
column
.
- addContext(Context, boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- addContext(String, String, boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add a context
- addCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Add a table coprocessor to this table.
- addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Add a table coprocessor to this table.
- addCoprocessors(HBaseProtos.Coprocessor) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- addCoprocessors(int, HBaseProtos.Coprocessor) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- addCoprocessors(HBaseProtos.Coprocessor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- addCoprocessors(int, HBaseProtos.Coprocessor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- addCoprocessorsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- addCoprocessorsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .Coprocessor coprocessors = 6;
- addCounter(MetricsInfo, int) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl.MockRecordBuilder
-
- addCounter(MetricsInfo, long) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl.MockRecordBuilder
-
- addData(HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- addData(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- addData(HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- addData(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- addDataBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- addDataBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ZooKeeperProtos.ReplicationPeer.Builder
-
repeated .BytesBytesPair data = 3;
- addDaughter(Connection, HRegionInfo, ServerName, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Adds a daughter region entry to meta.
- addDaughtersToPut(Put, HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Adds split daughters to the Put
- addDeadNode(String) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
Add a dead node to the cluster representation.
- addDeadNodes(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated string deadNodes = 2;
- addDeadNodesBytes(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated string deadNodes = 2;
- addDeadServers(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- addDeadServers(int, HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- addDeadServers(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- addDeadServers(int, HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- addDeadServersBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- addDeadServersBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .ServerName dead_servers = 3;
- addDefaultApps(ContextHandlerCollection, String, Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add default apps.
- addDefaultServlets() - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add default servlets.
- addDeleted(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
repeated uint64 deleted = 3;
- addDeleteFamilyBloomFilter(BloomFilterWriter) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Store delete family Bloom filter in the file, which is only supported in
HFile V2.
- addDeleteFamilyBloomFilter(BloomFilterWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
- addDeleteMarker(Cell) - Method in class org.apache.hadoop.hbase.client.Delete
-
Advanced use only.
- addDependencyJars(JobConf) - Static method in class org.apache.hadoop.hbase.mapred.TableMapReduceUtil
-
- addDependencyJars(Job) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Add the HBase dependency jars as well as jars for any of the configured
job classes to the job configuration, so that JobClient will ship them
to the cluster and add them to the DistributedCache.
- addDependencyJars(Configuration, Class<?>...) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Add the jars containing the given classes to the job's configuration
such that JobClient will ship them to the cluster and add them to
the DistributedCache.
- addEdits(WAL, HRegionInfo, HTableDescriptor, int, AtomicLong) - Method in class org.apache.hadoop.hbase.regionserver.wal.TestFSHLog
-
- addEdits(WAL, HRegionInfo, HTableDescriptor, int, AtomicLong) - Method in class org.apache.hadoop.hbase.wal.TestDefaultWALProvider
-
- addEmptyLocation(Put, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- addEndpoint(URI) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
-
Add an endpoint that the HTTP server should listen to.
- addEntry(byte[], long, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexWriter
-
Add one index entry to the current leaf-level block.
- addEntry(byte[], int, int) - Method in interface org.apache.hadoop.hbase.io.util.Dictionary
-
Adds an entry to the dictionary.
- addEntry(byte[], int, int) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
-
- addEntry(AdminProtos.WALEntry) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- addEntry(int, AdminProtos.WALEntry) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- addEntry(AdminProtos.WALEntry.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- addEntry(int, AdminProtos.WALEntry.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- addEntryBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- addEntryBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.ReplicateWALEntryRequest.Builder
-
repeated .WALEntry entry = 1;
- addException(byte[], Throwable) - Method in class org.apache.hadoop.hbase.client.MultiResponse
-
- addExtraHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
-
Add extra headers.
- addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all versions of all columns of the specified family.
- addFamily(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all columns of the specified family with a timestamp less than
or equal to the specified timestamp.
- addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Get
-
Get all columns from the specified family.
- addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
-
Get all columns from the specified family.
- addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.UnmodifyableHTableDescriptor
-
Does NOT add a column family.
- addFamily(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
-
Adds a column family.
- addFamily(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileRequest.Builder
-
repeated bytes family = 2;
- addFamilyFiles(SnapshotProtos.SnapshotRegionManifest.FamilyFiles) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- addFamilyFiles(int, SnapshotProtos.SnapshotRegionManifest.FamilyFiles) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- addFamilyFiles(SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- addFamilyFiles(int, SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- addFamilyFilesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- addFamilyFilesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.Builder
-
repeated .SnapshotRegionManifest.FamilyFiles family_files = 3;
- addFamilyPath(ClientProtos.BulkLoadHFileRequest.FamilyPath) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- addFamilyPath(int, ClientProtos.BulkLoadHFileRequest.FamilyPath) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- addFamilyPath(ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- addFamilyPath(int, ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- addFamilyPath(ClientProtos.BulkLoadHFileRequest.FamilyPath) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- addFamilyPath(int, ClientProtos.BulkLoadHFileRequest.FamilyPath) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- addFamilyPath(ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- addFamilyPath(int, ClientProtos.BulkLoadHFileRequest.FamilyPath.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- addFamilyPathBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- addFamilyPathBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 2;
- addFamilyPathBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- addFamilyPathBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest.Builder
-
repeated .BulkLoadHFileRequest.FamilyPath family_path = 1;
- addFamilyVersion(byte[], long) - Method in class org.apache.hadoop.hbase.client.Delete
-
Delete all columns of the specified family with a timestamp equal to
the specified timestamp.
- addFavoredNode(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- addFavoredNode(int, HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- addFavoredNode(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- addFavoredNode(int, HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- addFavoredNodeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- addFavoredNodeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.FavoredNodes.Builder
-
repeated .ServerName favored_node = 1;
- addFavoredNodes(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- addFavoredNodes(int, HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- addFavoredNodes(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- addFavoredNodes(int, HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- addFavoredNodes(HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- addFavoredNodes(int, HBaseProtos.ServerName) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- addFavoredNodes(HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- addFavoredNodes(int, HBaseProtos.ServerName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- addFavoredNodesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- addFavoredNodesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder
-
repeated .ServerName favored_nodes = 3;
- addFavoredNodesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- addFavoredNodesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder
-
repeated .ServerName favored_nodes = 2;
- addFileInfoToException(IOException) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogReader
-
- addFilter(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterList
-
Add a filter.
- addFilter(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.http.FilterContainer
-
Add a filter to the container.
- addFilter(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- addFilterAndArguments(Configuration, Class<? extends Filter>, List<String>) - Static method in class org.apache.hadoop.hbase.mapreduce.Import
-
Add a Filter to be instantiated on import
- addFilterPathMapping(String, Context) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add the path spec to the filter path mapping.
- addFilters(FilterProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- addFilters(int, FilterProtos.Filter) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- addFilters(FilterProtos.Filter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- addFilters(int, FilterProtos.Filter.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- addFiltersBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- addFiltersBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FilterList.Builder
-
repeated .Filter filters = 2;
- addFirstPart(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateResponse.Builder
-
repeated bytes first_part = 1;
- addFlushOutput(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
repeated string flush_output = 3;
- addFlushOutputBytes(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder
-
repeated string flush_output = 3;
- addFront(Procedure) - Method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureQueue
-
- addFront(TableProcedureInterface) - Method in class org.apache.hadoop.hbase.master.procedure.TestMasterProcedureQueue.TestTableProcSet
-
- addFront(Procedure) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureRunnableSet
-
Inserts the specified element at the front of this queue.
- addFront(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureSimpleRunQueue
-
- addFuzzyKeysData(HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- addFuzzyKeysData(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- addFuzzyKeysData(HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- addFuzzyKeysData(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- addFuzzyKeysDataBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- addFuzzyKeysDataBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FuzzyRowFilter.Builder
-
repeated .BytesBytesPair fuzzy_keys_data = 1;
- addGauge(MetricsInfo, int) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl.MockRecordBuilder
-
- addGauge(MetricsInfo, long) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl.MockRecordBuilder
-
- addGauge(MetricsInfo, float) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl.MockRecordBuilder
-
- addGauge(MetricsInfo, double) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl.MockRecordBuilder
-
- addGeneralBloomFilter(BloomFilterWriter) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Store general Bloom filter in the file.
- addGeneralBloomFilter(BloomFilterWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
- addGetResult(Result) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- addGetResult(Result) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Add a get result.
- addGetResult(Result) - Method in class org.apache.hadoop.hbase.quotas.OperationQuota.AvgOperationSize
-
- addGlobalFilter(String, String, Map<String, String>) - Method in interface org.apache.hadoop.hbase.http.FilterContainer
-
Add a global filter to the container - This global filter will be
applied to all available web contexts.
- addGlobalFilter(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
- addHBaseDependencyJars(Configuration) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
-
Add HBase and its dependencies (only) to the job configuration.
- addHbaseResources(Configuration) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
-
- addHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.filter.GZIPResponseWrapper
-
- addHostsAndBlockWeight(String[], long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
-
add some weight to a list of hosts, update the value of unique block weight
- addImmutable(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
- addImmutable(byte[], byte[], byte[], Tag[]) - Method in class org.apache.hadoop.hbase.client.Put
-
This expects that the underlying arrays won't change.
- addImmutable(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
-
- addImmutable(byte[], byte[], long, byte[], Tag[]) - Method in class org.apache.hadoop.hbase.client.Put
-
This expects that the underlying arrays won't change.
- addImmutable(byte[], ByteBuffer, long, ByteBuffer, Tag[]) - Method in class org.apache.hadoop.hbase.client.Put
-
This expects that the underlying arrays won't change.
- addImmutable(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
-
- addInfo(String, SecurityInfo) - Static method in class org.apache.hadoop.hbase.security.SecurityInfo
-
Adds a security configuration for a new service name.
- addInlineBlockWriter(InlineBlockWriter) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Adds an inline block writer such as a multi-level block index writer or
a compound Bloom filter writer.
- addInlineBlockWriter(InlineBlockWriter) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
- addInternalServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add an internal servlet in the server.
- addInternalServlet(String, String, Class<? extends HttpServlet>, boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add an internal servlet in the server, specifying whether or not to
protect with Kerberos authentication.
- addJarFilesToJar(File, String, File...) - Static method in class org.apache.hadoop.hbase.util.ClassLoaderTestHelper
-
Add a list of jar files to another jar file under a specific folder.
- addJerseyResourcePackage(String, String) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add a Jersey resource package.
- addJitter(long, float) - Static method in class org.apache.hadoop.hbase.client.ConnectionUtils
-
Adds / subs a 10% jitter to a pause time.
- addKey(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
- addKeyToZK(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
-
- addKeyValueBytes(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry.Builder
-
repeated bytes key_value_bytes = 2;
- addLabel(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
-
repeated string label = 1;
- addLabel(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.ListLabelsResponse.Builder
-
repeated bytes label = 1;
- addLabel(String) - Method in class org.apache.hadoop.hbase.rest.model.ScannerModel
-
Add a visibility label to the scan
- addLabel(Configuration, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Utility method for adding label to the system.
- addLabelBytes(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Authorizations.Builder
-
repeated string label = 1;
- addLabels(com.google.protobuf.RpcController, VisibilityLabelsProtos.VisibilityLabelsRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService
-
rpc addLabels(.VisibilityLabelsRequest) returns (.VisibilityLabelsResponse);
- addLabels(com.google.protobuf.RpcController, VisibilityLabelsProtos.VisibilityLabelsRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService.BlockingInterface
-
- addLabels(com.google.protobuf.RpcController, VisibilityLabelsProtos.VisibilityLabelsRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService.Interface
-
rpc addLabels(.VisibilityLabelsRequest) returns (.VisibilityLabelsResponse);
- addLabels(com.google.protobuf.RpcController, VisibilityLabelsProtos.VisibilityLabelsRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsService.Stub
-
- addLabels(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
repeated string labels = 10;
- addLabels(List<byte[]>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- addLabels(List<byte[]>) - Method in class org.apache.hadoop.hbase.security.visibility.ExpAsStringVisibilityLabelServiceImpl
-
- addLabels() - Static method in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabels
-
- addLabels() - Static method in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabelsReplication
-
- addLabels() - Static method in class org.apache.hadoop.hbase.security.visibility.TestVisibilityLabelsWithDeletes
-
- addLabels() - Static method in class org.apache.hadoop.hbase.security.visibility.TestVisibilityWithCheckAuths
-
- addLabels(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
-
Utility method for adding labels to the system.
- addLabels(RpcController, VisibilityLabelsProtos.VisibilityLabelsRequest, <any>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
-
VisibilityEndpoint service related methods
- addLabels(List<byte[]>) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
-
Adds the set of labels into the system.
- addLabelsBytes(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.ScannerMessage.Scanner.Builder
-
repeated string labels = 10;
- addLease(Leases.Lease) - Method in class org.apache.hadoop.hbase.regionserver.Leases
-
Inserts lease.
- addListener(ForeignExceptionListener) - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
-
Listen for failures to a given process.
- addLiveNode(String, long, int, int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
-
Add a live node to the cluster representation.
- addLiveNodes(StorageClusterStatusMessage.StorageClusterStatus.Node) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- addLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- addLiveNodes(StorageClusterStatusMessage.StorageClusterStatus.Node.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- addLiveNodes(int, StorageClusterStatusMessage.StorageClusterStatus.Node.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- addLiveNodesBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- addLiveNodesBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Node liveNodes = 1;
- addLiveServers(ClusterStatusProtos.LiveServerInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- addLiveServers(int, ClusterStatusProtos.LiveServerInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- addLiveServers(ClusterStatusProtos.LiveServerInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- addLiveServers(int, ClusterStatusProtos.LiveServerInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- addLiveServersBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- addLiveServersBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .LiveServerInfo live_servers = 2;
- addLocation(Put, ServerName, long, long, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
- addLocation(Put, ServerName, long) - Method in class org.apache.hadoop.hbase.regionserver.RegionMergeTransactionImpl
-
- addLocation(Put, ServerName, long) - Method in class org.apache.hadoop.hbase.regionserver.SplitTransactionImpl
-
- addLocations(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
repeated string locations = 2;
- addLocationsBytes(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.TableSnapshotRegionSplit.Builder
-
repeated string locations = 2;
- addLocationsOrderInterceptor(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
-
- addLog(String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueues
-
Add a new WAL file to the given queue.
- addLog(String, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationQueuesZKImpl
-
- addMapEntries(HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- addMapEntries(int, HBaseProtos.NameStringPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- addMapEntries(HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- addMapEntries(int, HBaseProtos.NameStringPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- addMapEntriesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- addMapEntriesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionServerStartupResponse.Builder
-
repeated .NameStringPair map_entries = 1;
- addMapEntry(HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- addMapEntry(int, HBaseProtos.BytesBytesPair) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- addMapEntry(HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- addMapEntry(int, HBaseProtos.BytesBytesPair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- addMapEntryBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- addMapEntryBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.HFileProtos.FileInfoProto.Builder
-
repeated .BytesBytesPair map_entry = 1;
- addMaster() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addMaster(Configuration, int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addMaster(Configuration, int, User) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addMasterCoprocessors(HBaseProtos.Coprocessor) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- addMasterCoprocessors(int, HBaseProtos.Coprocessor) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- addMasterCoprocessors(HBaseProtos.Coprocessor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- addMasterCoprocessors(int, HBaseProtos.Coprocessor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- addMasterCoprocessorsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- addMasterCoprocessorsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .Coprocessor master_coprocessors = 6;
- addMetaWALSplit(long, long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
-
Record a single instance of a split
- addMetrics(HBaseProtos.NameInt64Pair) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- addMetrics(int, HBaseProtos.NameInt64Pair) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- addMetrics(HBaseProtos.NameInt64Pair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- addMetrics(int, HBaseProtos.NameInt64Pair.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- addMetricsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- addMetricsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MapReduceProtos.ScanMetrics.Builder
-
repeated .NameInt64Pair metrics = 1;
- addMutation(Mutation) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- addMutation(Mutation) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Add a mutation result.
- addMutation(Mutation) - Method in class org.apache.hadoop.hbase.quotas.OperationQuota.AvgOperationSize
-
- addMutationRequest(ClientProtos.MutationProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- addMutationRequest(int, ClientProtos.MutationProto) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- addMutationRequest(ClientProtos.MutationProto.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- addMutationRequest(int, ClientProtos.MutationProto.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- addMutationRequestBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- addMutationRequestBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MultiRowMutationProtos.MutateRowsRequest.Builder
-
repeated .MutationProto mutation_request = 1;
- addName(String) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
repeated string name = 1;
- addNameBytes(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableListMessage.TableList.Builder
-
repeated string name = 1;
- addNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
-
- addNamespaceDescriptor(HBaseProtos.NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- addNamespaceDescriptor(int, HBaseProtos.NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- addNamespaceDescriptor(HBaseProtos.NamespaceDescriptor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- addNamespaceDescriptor(int, HBaseProtos.NamespaceDescriptor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- addNamespaceDescriptorBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- addNamespaceDescriptorBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListNamespaceDescriptorsResponse.Builder
-
repeated .NamespaceDescriptor namespaceDescriptor = 1;
- addNamespaceQuota(Connection, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- addNode(TokenizerNode, int, int, ByteRange, int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
- addNode(ProcedureProtos.ProcedureStoreTracker.TrackerNode) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- addNode(int, ProcedureProtos.ProcedureStoreTracker.TrackerNode) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- addNode(ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- addNode(int, ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- addNodeBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- addNodeBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.Builder
-
repeated .ProcedureStoreTracker.TrackerNode node = 1;
- addOpenInfo(AdminProtos.OpenRegionRequest.RegionOpenInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- addOpenInfo(int, AdminProtos.OpenRegionRequest.RegionOpenInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- addOpenInfo(AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- addOpenInfo(int, AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- addOpenInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- addOpenInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionRequest.Builder
-
repeated .OpenRegionRequest.RegionOpenInfo open_info = 1;
- addOpeningState(AdminProtos.OpenRegionResponse.RegionOpeningState) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.Builder
-
repeated .OpenRegionResponse.RegionOpeningState opening_state = 1;
- addOperationSize(OperationQuota.OperationType, long) - Method in class org.apache.hadoop.hbase.quotas.OperationQuota.AvgOperationSize
-
- addOperationSize(OperationQuota.OperationType, long) - Method in interface org.apache.hadoop.hbase.quotas.QuotaLimiter
-
Add the average size of the specified operation type.
- addOperationSize(OperationQuota.OperationType, long) - Method in class org.apache.hadoop.hbase.quotas.TimeBasedLimiter
-
- addOptions() - Method in class org.apache.hadoop.hbase.chaos.util.ChaosMonkeyRunner
-
- addOptions() - Method in class org.apache.hadoop.hbase.IntegrationTestBase
-
- addOptions() - Method in class org.apache.hadoop.hbase.IntegrationTestIngestWithACL
-
- addOptions() - Method in class org.apache.hadoop.hbase.IntegrationTestRegionReplicaPerf
-
- addOptions() - Method in class org.apache.hadoop.hbase.IntegrationTestsDriver
-
- addOptions() - Method in class org.apache.hadoop.hbase.mapreduce.IntegrationTestBulkLoad
-
- addOptions() - Method in class org.apache.hadoop.hbase.ScanPerformanceEvaluation
-
- addOptions() - Method in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
-
- addOptions() - Method in class org.apache.hadoop.hbase.StripeCompactionsPerformanceEvaluation
-
- addOptions() - Method in class org.apache.hadoop.hbase.test.IntegrationTestBigLinkedListWithVisibility
-
- addOptions() - Method in class org.apache.hadoop.hbase.test.IntegrationTestReplication
-
- addOptions() - Method in class org.apache.hadoop.hbase.test.IntegrationTestWithCellVisibilityLoadAndVerify
-
- addOptions() - Method in class org.apache.hadoop.hbase.test.IntegrationTestZKAndFSPermissions
-
- addOptions() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addOptions() - Method in class org.apache.hadoop.hbase.util.LoadTestTool
-
- addOptions() - Method in class org.apache.hadoop.hbase.util.RestartMetaTest
-
- addOptNoArg(String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addOptNoArg(String, String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addOptWithArg(String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addOptWithArg(String, String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addPartialFlagPerResult(boolean) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated bool partial_flag_per_result = 7;
- addPeer(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
- addPeer(String, String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Deprecated.
- addPeer(String, ReplicationPeerConfig, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Add a new remote slave cluster for replication.
- addPeer(String, ReplicationPeerConfig, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeers
-
Add a new remote slave cluster for replication.
- addPeer(String, ReplicationPeerConfig, String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeersZKImpl
-
- addPermission(AccessControlProtos.Permission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- addPermission(int, AccessControlProtos.Permission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- addPermission(AccessControlProtos.Permission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- addPermission(int, AccessControlProtos.Permission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- addPermissionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- addPermissionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.CheckPermissionsRequest.Builder
-
repeated .Permission permission = 1;
- addPermissions(AccessControlProtos.Permission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- addPermissions(int, AccessControlProtos.Permission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- addPermissions(AccessControlProtos.Permission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- addPermissions(int, AccessControlProtos.Permission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- addPermissionsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- addPermissionsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.UserPermissions.Builder
-
repeated .Permission permissions = 2;
- addPlan(String, RegionPlan) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Add a regionPlan for the specified region.
- addPlans(Map<String, RegionPlan>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Add a map of region plans.
- addProcedure(ProcedureProtos.Procedure) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- addProcedure(int, ProcedureProtos.Procedure) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- addProcedure(ProcedureProtos.Procedure.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- addProcedure(int, ProcedureProtos.Procedure.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- addProcedure(ProcedureProtos.Procedure) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- addProcedure(int, ProcedureProtos.Procedure) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- addProcedure(ProcedureProtos.Procedure.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- addProcedure(int, ProcedureProtos.Procedure.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- addProcedureBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- addProcedureBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListProceduresResponse.Builder
-
repeated .Procedure procedure = 1;
- addProcedureBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- addProcedureBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureWALEntry.Builder
-
repeated .Procedure procedure = 2;
- addPushSize(int) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
-
Add current size to the current cycle's total push size
- addPutToKv(Put, Cell) - Method in class org.apache.hadoop.hbase.mapreduce.Import.Importer
-
- addQualifier(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Column.Builder
-
repeated bytes qualifier = 2;
- addQualifiers(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.FirstKeyValueMatchingQualifiersFilter.Builder
-
repeated bytes qualifiers = 1;
- addQualifierValue(ClientProtos.MutationProto.ColumnValue.QualifierValue) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- addQualifierValue(int, ClientProtos.MutationProto.ColumnValue.QualifierValue) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- addQualifierValue(ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- addQualifierValue(int, ClientProtos.MutationProto.ColumnValue.QualifierValue.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- addQualifierValueBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- addQualifierValueBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.ColumnValue.Builder
-
repeated .MutationProto.ColumnValue.QualifierValue qualifier_value = 2;
- addReaderThreads(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReader
-
- addReaderThreads(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedReaderWithACL
-
- addRecord(String) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl.MockMetricsBuilder
-
- addRecord(MetricsInfo) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl.MockMetricsBuilder
-
- addRegion(byte[], int, int, int, int, int, long, long, int, int, int, long, long) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel.Node
-
Add a region name to the list
- addRegion(HRegion) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Creates a 'manifest' for the specified region, by reading directly from the HRegion object.
- addRegion(Path, HRegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Creates a 'manifest' for the specified region, by reading directly from the disk.
- addRegion() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils.SnapshotMock.SnapshotBuilder
-
- addRegionAction(ClientProtos.RegionAction) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- addRegionAction(int, ClientProtos.RegionAction) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- addRegionAction(ClientProtos.RegionAction.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- addRegionAction(int, ClientProtos.RegionAction.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- addRegionActionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- addRegionActionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiRequest.Builder
-
repeated .RegionAction regionAction = 1;
- addRegionActionResult(ClientProtos.RegionActionResult) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- addRegionActionResult(int, ClientProtos.RegionActionResult) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- addRegionActionResult(ClientProtos.RegionActionResult.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- addRegionActionResult(int, ClientProtos.RegionActionResult.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- addRegionActionResultBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- addRegionActionResultBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MultiResponse.Builder
-
repeated .RegionActionResult regionActionResult = 1;
- addRegionInfo(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- addRegionInfo(int, HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- addRegionInfo(HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- addRegionInfo(int, HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- addRegionInfo(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- addRegionInfo(int, HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- addRegionInfo(HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- addRegionInfo(int, HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- addRegionInfo(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- addRegionInfo(int, HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- addRegionInfo(HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- addRegionInfo(int, HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- addRegionInfo(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- addRegionInfo(int, HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- addRegionInfo(HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- addRegionInfo(int, HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- addRegionInfo(HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- addRegionInfo(int, HBaseProtos.RegionInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- addRegionInfo(HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- addRegionInfo(int, HBaseProtos.RegionInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- addRegionInfo(HBaseFsck.HbckInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
- addRegionInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- addRegionInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetOnlineRegionResponse.Builder
-
repeated .RegionInfo region_info = 1;
- addRegionInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- addRegionInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.CreateTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- addRegionInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- addRegionInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.DeleteTableStateData.Builder
-
repeated .RegionInfo region_info = 3;
- addRegionInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- addRegionInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProcedureProtos.TruncateTableStateData.Builder
-
repeated .RegionInfo region_info = 5;
- addRegionInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- addRegionInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.RegionStateTransition.Builder
-
repeated .RegionInfo region_info = 2;
- addRegionLoads(ClusterStatusProtos.RegionLoad) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- addRegionLoads(int, ClusterStatusProtos.RegionLoad) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- addRegionLoads(ClusterStatusProtos.RegionLoad.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- addRegionLoads(int, ClusterStatusProtos.RegionLoad.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- addRegionLoadsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- addRegionLoadsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .RegionLoad region_loads = 5;
- addRegionManifests(SnapshotProtos.SnapshotRegionManifest) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- addRegionManifests(int, SnapshotProtos.SnapshotRegionManifest) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- addRegionManifests(SnapshotProtos.SnapshotRegionManifest.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- addRegionManifests(int, SnapshotProtos.SnapshotRegionManifest.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- addRegionManifestsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- addRegionManifestsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotDataManifest.Builder
-
repeated .SnapshotRegionManifest region_manifests = 2;
- addRegions(StorageClusterStatusMessage.StorageClusterStatus.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- addRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- addRegions(StorageClusterStatusMessage.StorageClusterStatus.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- addRegions(int, StorageClusterStatusMessage.StorageClusterStatus.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- addRegions(TableInfoMessage.TableInfo.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- addRegions(int, TableInfoMessage.TableInfo.Region) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- addRegions(TableInfoMessage.TableInfo.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- addRegions(int, TableInfoMessage.TableInfo.Region.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- addRegionsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- addRegionsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus.Node.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatus.Region regions = 6;
- addRegionsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- addRegionsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.TableInfoMessage.TableInfo.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.TableInfo.Region regions = 2;
- addRegionServer() - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addRegionServer(Configuration, int) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addRegionServer(Configuration, int, User) - Method in class org.apache.hadoop.hbase.LocalHBaseCluster
-
- addRegionsInTransition(ClusterStatusProtos.RegionInTransition) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- addRegionsInTransition(int, ClusterStatusProtos.RegionInTransition) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- addRegionsInTransition(ClusterStatusProtos.RegionInTransition.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- addRegionsInTransition(int, ClusterStatusProtos.RegionInTransition.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- addRegionsInTransitionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- addRegionsInTransitionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ClusterStatus.Builder
-
repeated .RegionInTransition regions_in_transition = 4;
- addRegionsToMeta(List<HRegionInfo>, int) - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
Add the specified set of regions to the hbase:meta table.
- addRegionsToMeta(MasterProcedureEnv, HTableDescriptor, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
Add the specified set of regions to the hbase:meta table.
- addRegionsToMeta(List<HRegionInfo>, int) - Method in class org.apache.hadoop.hbase.master.snapshot.CloneSnapshotHandler
-
- addRegionsToMeta(Connection, List<HRegionInfo>, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Adds a hbase:meta row for each of the specified new regions.
- addRegionsToMeta(Connection, List<HRegionInfo>, int, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Adds a hbase:meta row for each of the specified new regions.
- addRegionToFlush(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.RollWALWriterResponse.Builder
-
repeated bytes region_to_flush = 1;
- addRegionToMeta(Connection, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Adds a hbase:meta row for the specified new region.
- addRegionToMeta(Table, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Adds a hbase:meta row for the specified new region to the given catalog table.
- addRegionToMeta(Table, HRegionInfo, HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Adds a (single) hbase:meta row for the specified new region and its daughters.
- addRegionToMeta(Connection, HRegionInfo, HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
-
Adds a (single) hbase:meta row for the specified new region and its daughters.
- addRegionToMETA(HRegion, HRegion) - Static method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Inserts a new region's meta information into the passed
meta
region.
- addRegionToSnapshot(HBaseProtos.SnapshotDescription, ForeignExceptionSnare) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
Complete taking the snapshot on the region.
- addRegionV1() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils.SnapshotMock.SnapshotBuilder
-
- addRegionV2() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils.SnapshotMock.SnapshotBuilder
-
- addReplicas(HTableDescriptor, List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.handler.CreateTableHandler
-
Create any replicas for the regions (the default replicas that was
already created is passed to the method)
- addReplLoadSource(ClusterStatusProtos.ReplicationLoadSource) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- addReplLoadSource(int, ClusterStatusProtos.ReplicationLoadSource) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- addReplLoadSource(ClusterStatusProtos.ReplicationLoadSource.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- addReplLoadSource(int, ClusterStatusProtos.ReplicationLoadSource.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- addReplLoadSourceBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- addReplLoadSourceBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ServerLoad.Builder
-
repeated .ReplicationLoadSource replLoadSource = 10;
- addRequiredOptWithArg(String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addRequiredOptWithArg(String, String, String) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
-
- addResourceAnalyzer(ResourceChecker.ResourceAnalyzer) - Method in class org.apache.hadoop.hbase.ResourceChecker
-
Adds a resource analyzer to the resources checked.
- addResourceAnalyzer(ResourceChecker) - Method in class org.apache.hadoop.hbase.ResourceCheckerJUnitListener
-
To be implemented by sub classes if they want to add specific ResourceAnalyzer.
- addResourceAnalyzer(ResourceChecker) - Method in class org.apache.hadoop.hbase.ServerResourceCheckerJUnitListener
-
- ADDRESS - Static variable in class org.apache.hadoop.hbase.ipc.TestProtoBufRpc
-
- Addressing - Class in org.apache.hadoop.hbase.util
-
Utility for network addresses, resolving and naming.
- Addressing() - Constructor for class org.apache.hadoop.hbase.util.Addressing
-
- Addressing.AddressSelectionCondition - Interface in org.apache.hadoop.hbase.util
-
Interface for AddressSelectionCondition to check if address is acceptable
- addResult(String) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest.Builder
-
repeated string result = 3;
- addResult(String) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse.Builder
-
repeated string result = 1;
- addResult(ClientProtos.RegionActionResult) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- addResult(int, ClientProtos.RegionActionResult) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- addResult(ClientProtos.RegionActionResult.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- addResult(int, ClientProtos.RegionActionResult.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- addResultBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- addResultBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsResponse.Builder
-
repeated .RegionActionResult result = 1;
- addResultBytes(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorRequest.Builder
-
repeated string result = 3;
- addResultBytes(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.coprocessor.protobuf.generated.IncrementCounterProcessorTestProtos.FriendsOfFriendsProcessorResponse.Builder
-
repeated string result = 1;
- addResultOrException(ClientProtos.ResultOrException) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- addResultOrException(int, ClientProtos.ResultOrException) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- addResultOrException(ClientProtos.ResultOrException.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- addResultOrException(int, ClientProtos.ResultOrException.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- addResultOrExceptionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- addResultOrExceptionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionActionResult.Builder
-
repeated .ResultOrException resultOrException = 1;
- addResults(ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.Result
-
- addResults(ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- addResults(int, ClientProtos.Result) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- addResults(ClientProtos.Result.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- addResults(int, ClientProtos.Result.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- addResultsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- addResultsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.ScanResponse.Builder
-
repeated .Result results = 5;
- addRow(byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility.SeenRowTracker
-
- addRow(RowModel) - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
-
Add a row to this cell set
- addRowRangeList(FilterProtos.RowRange) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- addRowRangeList(int, FilterProtos.RowRange) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- addRowRangeList(FilterProtos.RowRange.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- addRowRangeList(int, FilterProtos.RowRange.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- addRowRangeListBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- addRowRangeListBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultiRowRangeFilter.Builder
-
repeated .RowRange row_range_list = 1;
- addRows(CellSetMessage.CellSet.Row) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- addRows(int, CellSetMessage.CellSet.Row) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- addRows(CellSetMessage.CellSet.Row.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- addRows(int, CellSetMessage.CellSet.Row.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- addRowsBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- addRowsBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.CellSet.Row rows = 1;
- addScanner(ResultScanner, boolean) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Assigns a unique ID to the scanner and adds the mapping to an internal
hash-map.
- addScanResult(List<Result>) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
-
- addScanResult(List<Result>) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
-
Add a scan result.
- addScanResult(List<Result>) - Method in class org.apache.hadoop.hbase.quotas.OperationQuota.AvgOperationSize
-
- addScopes(WALProtos.FamilyScope) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- addScopes(int, WALProtos.FamilyScope) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- addScopes(WALProtos.FamilyScope.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- addScopes(int, WALProtos.FamilyScope.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- addScopesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- addScopesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.WALKey.Builder
-
repeated .FamilyScope scopes = 6;
- addServer(HRegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.HbckInfo
-
- addServer(ServerName) - Method in class org.apache.hadoop.hbase.util.HBaseFsck.TableInfo
-
- addServerToDrainList(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
-
- addServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.HttpServer
-
Add a servlet in the server.
- addServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.InfoServer
-
- addShutdownHook(Thread, int) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- addSnapshot(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshot
-
Record a single instance of a snapshot
- addSnapshotClone(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshot
-
Record a single instance of a snapshot cloned table
- addSnapshotRestore(long) - Method in class org.apache.hadoop.hbase.master.MetricsSnapshot
-
Record a single instance of a snapshot
- addSnapshots(HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- addSnapshots(int, HBaseProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- addSnapshots(HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- addSnapshots(int, HBaseProtos.SnapshotDescription.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- addSnapshotsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- addSnapshotsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetCompletedSnapshotsResponse.Builder
-
repeated .SnapshotDescription snapshots = 1;
- addSorted(ByteRange) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
- addSorted(ByteRange) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
building
- addSortedPrefixes(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.MultipleColumnPrefixFilter.Builder
-
repeated bytes sorted_prefixes = 1;
- addSource(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
-
Add a new normal source to this region server
- addSplit(long, long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
-
Record a single instance of a split
- addSplitKeys(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.CreateTableRequest.Builder
-
repeated bytes split_keys = 2;
- addStackId(int) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureTestingUtility.TestProcedure
-
- addStackId(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.Procedure.Builder
-
repeated uint32 stack_id = 7;
- addStackIndex(int) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
-
Called by the RootProcedureState on procedure execution.
- addState(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.StateMachineProcedureData.Builder
-
repeated uint32 state = 1;
- addStoreCompleteSequenceId(ClusterStatusProtos.StoreSequenceId) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- addStoreCompleteSequenceId(int, ClusterStatusProtos.StoreSequenceId) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- addStoreCompleteSequenceId(ClusterStatusProtos.StoreSequenceId.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- addStoreCompleteSequenceId(int, ClusterStatusProtos.StoreSequenceId.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- addStoreCompleteSequenceIdBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- addStoreCompleteSequenceIdBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionLoad.Builder
-
repeated .StoreSequenceId store_complete_sequence_id = 18;
- addStoreFile(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
-
repeated string store_file = 1;
- addStoreFile(String) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
repeated string store_file = 3;
- addStoreFileBytes(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.GetStoreFileResponse.Builder
-
repeated string store_file = 1;
- addStoreFileBytes(com.google.protobuf.ByteString) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.StoreDescriptor.Builder
-
repeated string store_file = 3;
- addStoreFiles(SnapshotProtos.SnapshotRegionManifest.StoreFile) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- addStoreFiles(int, SnapshotProtos.SnapshotRegionManifest.StoreFile) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- addStoreFiles(SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- addStoreFiles(int, SnapshotProtos.SnapshotRegionManifest.StoreFile.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- addStoreFilesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- addStoreFilesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.SnapshotProtos.SnapshotRegionManifest.FamilyFiles.Builder
-
repeated .SnapshotRegionManifest.StoreFile store_files = 2;
- addStoreFlushes(WALProtos.FlushDescriptor.StoreFlushDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- addStoreFlushes(int, WALProtos.FlushDescriptor.StoreFlushDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- addStoreFlushes(WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- addStoreFlushes(int, WALProtos.FlushDescriptor.StoreFlushDescriptor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- addStoreFlushesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- addStoreFlushesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor.Builder
-
repeated .FlushDescriptor.StoreFlushDescriptor store_flushes = 5;
- addStoreLastFlushedSequenceId(ClusterStatusProtos.StoreSequenceId) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- addStoreLastFlushedSequenceId(int, ClusterStatusProtos.StoreSequenceId) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- addStoreLastFlushedSequenceId(ClusterStatusProtos.StoreSequenceId.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- addStoreLastFlushedSequenceId(int, ClusterStatusProtos.StoreSequenceId.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- addStoreLastFlushedSequenceIdBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- addStoreLastFlushedSequenceIdBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.GetLastFlushedSequenceIdResponse.Builder
-
repeated .StoreSequenceId store_last_flushed_sequence_id = 2;
- addStores(WALProtos.StoreDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- addStores(int, WALProtos.StoreDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- addStores(WALProtos.StoreDescriptor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- addStores(int, WALProtos.StoreDescriptor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- addStores(WALProtos.StoreDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- addStores(int, WALProtos.StoreDescriptor) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- addStores(WALProtos.StoreDescriptor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- addStores(int, WALProtos.StoreDescriptor.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- addStoresBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- addStoresBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor.Builder
-
repeated .StoreDescriptor stores = 3;
- addStoresBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- addStoresBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.WALProtos.RegionEventDescriptor.Builder
-
repeated .StoreDescriptor stores = 5;
- addStoreSequenceId(ClusterStatusProtos.StoreSequenceId) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- addStoreSequenceId(int, ClusterStatusProtos.StoreSequenceId) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- addStoreSequenceId(ClusterStatusProtos.StoreSequenceId.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- addStoreSequenceId(int, ClusterStatusProtos.StoreSequenceId.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- addStoreSequenceIdBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- addStoreSequenceIdBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.RegionStoreSequenceIds.Builder
-
repeated .StoreSequenceId store_sequence_id = 2;
- addStringMap(Map<String, String>) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
Add String map to config list.
- addSublist(List<T>) - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
-
- addSystemLabel(Region, Map<String, Integer>, Map<String, List<Integer>>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
-
- addTable(String) - Method in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
-
Add the named table to be those being archived.
- addTableDescriptor(HTableDescriptor) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
-
Add the table descriptor to the snapshot manifest
- addTableName(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- addTableName(int, HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- addTableName(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- addTableName(int, HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- addTableNameBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- addTableNameBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableNamesByNamespaceResponse.Builder
-
repeated .TableName tableName = 1;
- addTableNames(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- addTableNames(int, HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- addTableNames(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- addTableNames(int, HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- addTableNames(HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- addTableNames(int, HBaseProtos.TableName) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- addTableNames(HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- addTableNames(int, HBaseProtos.TableName.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- addTableNamesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- addTableNamesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsRequest.Builder
-
repeated .TableName table_names = 1;
- addTableNamesBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- addTableNamesBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableNamesResponse.Builder
-
repeated .TableName table_names = 1;
- addTableQuota(Connection, TableName, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- addTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- addTableSchema(int, HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- addTableSchema(HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- addTableSchema(int, HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- addTableSchema(HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- addTableSchema(int, HBaseProtos.TableSchema) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- addTableSchema(HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- addTableSchema(int, HBaseProtos.TableSchema.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- addTableSchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- addTableSchemaBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.GetTableDescriptorsResponse.Builder
-
repeated .TableSchema table_schema = 1;
- addTableSchemaBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- addTableSchemaBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.ListTableDescriptorsByNamespaceResponse.Builder
-
repeated .TableSchema tableSchema = 1;
- addTableToMeta(MasterProcedureEnv, HTableDescriptor, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- addThread(MultithreadedTestUtil.TestThread) - Method in class org.apache.hadoop.hbase.MultithreadedTestUtil.TestContext
-
- addTimestamps(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.FilterProtos.TimestampsFilter.Builder
-
repeated int64 timestamps = 1 [packed = true];
- addToColumnFamilies(ColumnDescriptor) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.createTable_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- addToColumns(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TScan
-
- addToColumns(TColumnValue) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- addToColumns(TColumn) - Method in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- addToColumns(TColumn) - Method in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- addToColumns(TColumnIncrement) - Method in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- addToColumns(TColumn) - Method in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- addToColumnValues(TColumnValue) - Method in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- addToColumnValues(TColumnValue) - Method in class org.apache.hadoop.hbase.thrift2.generated.TResult
-
- addToDeletes(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_args
-
- addToFailedServers(InetSocketAddress) - Method in class org.apache.hadoop.hbase.ipc.FailedServers
-
Add an address to the list of the failed servers list.
- addToGets(TGet) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_args
-
- addToIncrements(TIncrement) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.incrementRows_args
-
- addToken(<any>) - Method in class org.apache.hadoop.hbase.security.User
-
Adds the given Token to the user's credentials.
- addTokenForJob(Connection, JobConf, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
-
Checks for an authentication token for the given user, obtaining a new token if necessary,
and adds it to the credentials for the given map reduce job.
- addTokenForJob(Connection, User, Job) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
-
Checks for an authentication token for the given user, obtaining a new token if necessary,
and adds it to the credentials for the given map reduce job.
- addTokenIfMissing(Connection, User) - Static method in class org.apache.hadoop.hbase.security.token.TokenUtil
-
Checks if an authentication tokens exists for the connected cluster,
obtaining one if needed and adding it to the user's credentials.
- addToLabels(String) - Method in class org.apache.hadoop.hbase.thrift2.generated.TAuthorization
-
- addToMovedRegions(String, ServerName, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- addToMutations(Mutation) - Method in class org.apache.hadoop.hbase.thrift.generated.BatchMutation
-
- addToMutations(Mutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
- addToMutations(Mutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
- addToMutations(TMutation) - Method in class org.apache.hadoop.hbase.thrift2.generated.TRowMutations
-
- addToOnlineRegions(Region) - Method in class org.apache.hadoop.hbase.MockRegionServerServices
-
- addToOnlineRegions(Region) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
-
- addToOnlineRegions(Region) - Method in interface org.apache.hadoop.hbase.regionserver.OnlineRegions
-
Add to online regions.
- addToPuts(TPut) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.putMultiple_args
-
- addToRowBatches(BatchMutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
- addToRowBatches(BatchMutation) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
- addToRows(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
- addToRows(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
- addToRows(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
- addToRows(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
- addToSortedColumns(TColumn) - Method in class org.apache.hadoop.hbase.thrift.generated.TRowResult
-
- addToSortedRanges() - Method in class org.apache.hadoop.hbase.util.byterange.ByteRangeSet
-
abstract
- addToSortedRanges() - Method in class org.apache.hadoop.hbase.util.byterange.impl.ByteRangeHashSet
-
- addToSortedRanges() - Method in class org.apache.hadoop.hbase.util.byterange.impl.ByteRangeTreeSet
-
- addToSuccess(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- addToSuccess(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_result
-
- addToSuccess(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowOrBefore_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_result
-
- addToSuccess(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableNames_result
-
- addToSuccess(TRegionInfo) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getTableRegions_result
-
- addToSuccess(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_result
-
- addToSuccess(TCell) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGet_result
-
- addToSuccess(TRowResult) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerGetList_result
-
- addToSuccess(TDelete) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.deleteMultiple_result
-
- addToSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getMultiple_result
-
- addToSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerResults_result
-
- addToSuccess(TResult) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.getScannerRows_result
-
- addToValues(ByteBuffer) - Method in class org.apache.hadoop.hbase.thrift.generated.TAppend
-
- addTrace(ErrorHandlingProtos.StackTraceElementMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- addTrace(int, ErrorHandlingProtos.StackTraceElementMessage) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- addTrace(ErrorHandlingProtos.StackTraceElementMessage.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- addTrace(int, ErrorHandlingProtos.StackTraceElementMessage.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- addTraceBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- addTraceBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.ErrorHandlingProtos.GenericExceptionMessage.Builder
-
repeated .StackTraceElementMessage trace = 4;
- addTransition(RegionServerStatusProtos.RegionStateTransition) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- addTransition(int, RegionServerStatusProtos.RegionStateTransition) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- addTransition(RegionServerStatusProtos.RegionStateTransition.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- addTransition(int, RegionServerStatusProtos.RegionStateTransition.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- addTransitionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- addTransitionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.RegionServerStatusProtos.ReportRegionStateTransitionRequest.Builder
-
repeated .RegionStateTransition transition = 2;
- addTypeFilter(QuotaType) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
-
Add a type to the filter list
- addUpdated(long) - Method in class org.apache.hadoop.hbase.protobuf.generated.ProcedureProtos.ProcedureStoreTracker.TrackerNode.Builder
-
repeated uint64 updated = 2;
- addUpdateInfo(AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- addUpdateInfo(int, AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- addUpdateInfo(AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- addUpdateInfo(int, AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- addUpdateInfoBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- addUpdateInfoBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.UpdateFavoredNodesRequest.Builder
-
repeated .UpdateFavoredNodesRequest.RegionUpdateInfo update_info = 1;
- addUpdaterThreads(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdater
-
- addUpdaterThreads(int) - Method in class org.apache.hadoop.hbase.util.MultiThreadedUpdaterWithACL
-
- addUserAuths(VisibilityLabelsProtos.UserAuthorizations) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- addUserAuths(int, VisibilityLabelsProtos.UserAuthorizations) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- addUserAuths(VisibilityLabelsProtos.UserAuthorizations.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- addUserAuths(int, VisibilityLabelsProtos.UserAuthorizations.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- addUserAuthsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- addUserAuthsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.MultiUserAuthorizations.Builder
-
repeated .UserAuthorizations userAuths = 1;
- addUserPermission(AccessControlProtos.UserPermission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- addUserPermission(int, AccessControlProtos.UserPermission) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- addUserPermission(AccessControlProtos.UserPermission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- addUserPermission(int, AccessControlProtos.UserPermission.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- addUserPermissionBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- addUserPermissionBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.GetUserPermissionsResponse.Builder
-
repeated .UserPermission user_permission = 1;
- addUserPermissions(AccessControlProtos.UsersAndPermissions.UserPermissions) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- addUserPermissions(int, AccessControlProtos.UsersAndPermissions.UserPermissions) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- addUserPermissions(AccessControlProtos.UsersAndPermissions.UserPermissions.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- addUserPermissions(int, AccessControlProtos.UsersAndPermissions.UserPermissions.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- addUserPermissionsBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- addUserPermissionsBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.UsersAndPermissions.Builder
-
repeated .UsersAndPermissions.UserPermissions user_permissions = 1;
- addUserQuota(Connection, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- addUserQuota(Connection, String, TableName, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- addUserQuota(Connection, String, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
-
- addValues(CellMessage.Cell) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- addValues(int, CellMessage.Cell) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- addValues(CellMessage.Cell.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- addValues(int, CellMessage.Cell.Builder) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- addValuesBuilder() - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- addValuesBuilder(int) - Method in class org.apache.hadoop.hbase.rest.protobuf.generated.CellSetMessage.CellSet.Row.Builder
-
repeated .org.apache.hadoop.hbase.rest.protobuf.generated.Cell values = 2;
- addVisLabel(VisibilityLabelsProtos.VisibilityLabel) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- addVisLabel(int, VisibilityLabelsProtos.VisibilityLabel) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- addVisLabel(VisibilityLabelsProtos.VisibilityLabel.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- addVisLabel(int, VisibilityLabelsProtos.VisibilityLabel.Builder) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- addVisLabelBuilder() - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- addVisLabelBuilder(int) - Method in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.VisibilityLabelsRequest.Builder
-
repeated .VisibilityLabel visLabel = 1;
- addWAL(WAL) - Method in class org.apache.hadoop.hbase.regionserver.LogRoller
-
- addWeight(long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
-
add weight
- addWritableMap(Map<ImmutableBytesWritable, ImmutableBytesWritable>) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
-
Add ImmutableBytesWritable map to config list.
- Admin - Interface in org.apache.hadoop.hbase.client
-
The administrative API for HBase.
- admin - Static variable in class org.apache.hadoop.hbase.replication.TestReplicationBase
-
- admin - Static variable in class org.apache.hadoop.hbase.TestNamespace
-
- admin - Variable in class org.apache.hadoop.hbase.tool.Canary.Monitor
-
- ADMIN_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
-
- ADMIN_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AccessControlProtos.Permission.Action
-
ADMIN = 4;
- AdminAuthorizedServlet - Class in org.apache.hadoop.hbase.http
-
General servlet which is admin-authorized.
- AdminAuthorizedServlet() - Constructor for class org.apache.hadoop.hbase.http.AdminAuthorizedServlet
-
- AdminProtos - Class in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.AdminService - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf service AdminService
- AdminProtos.AdminService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.AdminService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.AdminService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.CloseRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CloseRegionRequest
- AdminProtos.CloseRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CloseRegionRequest
- AdminProtos.CloseRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.CloseRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CloseRegionResponse
- AdminProtos.CloseRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CloseRegionResponse
- AdminProtos.CloseRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.CompactRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CompactRegionRequest
- AdminProtos.CompactRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CompactRegionRequest
- AdminProtos.CompactRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.CompactRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CompactRegionResponse
- AdminProtos.CompactRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type CompactRegionResponse
- AdminProtos.CompactRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.FlushRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type FlushRegionRequest
- AdminProtos.FlushRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type FlushRegionRequest
- AdminProtos.FlushRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.FlushRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type FlushRegionResponse
- AdminProtos.FlushRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type FlushRegionResponse
- AdminProtos.FlushRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.GetOnlineRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetOnlineRegionRequest
- AdminProtos.GetOnlineRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetOnlineRegionRequest
- AdminProtos.GetOnlineRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.GetOnlineRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetOnlineRegionResponse
- AdminProtos.GetOnlineRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetOnlineRegionResponse
- AdminProtos.GetOnlineRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.GetRegionInfoRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetRegionInfoRequest
- AdminProtos.GetRegionInfoRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetRegionInfoRequest
- AdminProtos.GetRegionInfoRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.GetRegionInfoResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetRegionInfoResponse
- AdminProtos.GetRegionInfoResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetRegionInfoResponse
- AdminProtos.GetRegionInfoResponse.CompactionState - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum GetRegionInfoResponse.CompactionState
- AdminProtos.GetRegionInfoResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.GetServerInfoRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetServerInfoRequest
- AdminProtos.GetServerInfoRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetServerInfoRequest
- AdminProtos.GetServerInfoRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.GetServerInfoResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetServerInfoResponse
- AdminProtos.GetServerInfoResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetServerInfoResponse
- AdminProtos.GetServerInfoResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.GetStoreFileRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetStoreFileRequest
- AdminProtos.GetStoreFileRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetStoreFileRequest
- AdminProtos.GetStoreFileRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.GetStoreFileResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetStoreFileResponse
- AdminProtos.GetStoreFileResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetStoreFileResponse
- AdminProtos.GetStoreFileResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.MergeRegionsRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MergeRegionsRequest
- AdminProtos.MergeRegionsRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MergeRegionsRequest
- AdminProtos.MergeRegionsRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.MergeRegionsResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MergeRegionsResponse
- AdminProtos.MergeRegionsResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type MergeRegionsResponse
- AdminProtos.MergeRegionsResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.OpenRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type OpenRegionRequest
- AdminProtos.OpenRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type OpenRegionRequest
- AdminProtos.OpenRegionRequest.RegionOpenInfo - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type OpenRegionRequest.RegionOpenInfo
- AdminProtos.OpenRegionRequest.RegionOpenInfo.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type OpenRegionRequest.RegionOpenInfo
- AdminProtos.OpenRegionRequest.RegionOpenInfoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.OpenRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.OpenRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type OpenRegionResponse
- AdminProtos.OpenRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type OpenRegionResponse
- AdminProtos.OpenRegionResponse.RegionOpeningState - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum OpenRegionResponse.RegionOpeningState
- AdminProtos.OpenRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.ReplicateWALEntryRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ReplicateWALEntryRequest
- AdminProtos.ReplicateWALEntryRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ReplicateWALEntryRequest
- AdminProtos.ReplicateWALEntryRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.ReplicateWALEntryResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ReplicateWALEntryResponse
- AdminProtos.ReplicateWALEntryResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ReplicateWALEntryResponse
- AdminProtos.ReplicateWALEntryResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.RollWALWriterRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RollWALWriterRequest
- AdminProtos.RollWALWriterRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RollWALWriterRequest
- AdminProtos.RollWALWriterRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.RollWALWriterResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RollWALWriterResponse
- AdminProtos.RollWALWriterResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type RollWALWriterResponse
- AdminProtos.RollWALWriterResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.ServerInfo - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ServerInfo
- AdminProtos.ServerInfo.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type ServerInfo
- AdminProtos.ServerInfoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.SplitRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SplitRegionRequest
- AdminProtos.SplitRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SplitRegionRequest
- AdminProtos.SplitRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.SplitRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SplitRegionResponse
- AdminProtos.SplitRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type SplitRegionResponse
- AdminProtos.SplitRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.StopServerRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type StopServerRequest
- AdminProtos.StopServerRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type StopServerRequest
- AdminProtos.StopServerRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.StopServerResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type StopServerResponse
- AdminProtos.StopServerResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type StopServerResponse
- AdminProtos.StopServerResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.UpdateConfigurationRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UpdateConfigurationRequest
- AdminProtos.UpdateConfigurationRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UpdateConfigurationRequest
- AdminProtos.UpdateConfigurationRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.UpdateConfigurationResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UpdateConfigurationResponse
- AdminProtos.UpdateConfigurationResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UpdateConfigurationResponse
- AdminProtos.UpdateConfigurationResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.UpdateFavoredNodesRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UpdateFavoredNodesRequest
- AdminProtos.UpdateFavoredNodesRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UpdateFavoredNodesRequest
- AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UpdateFavoredNodesRequest.RegionUpdateInfo
- AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfo.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UpdateFavoredNodesRequest.RegionUpdateInfo
- AdminProtos.UpdateFavoredNodesRequest.RegionUpdateInfoOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.UpdateFavoredNodesRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.UpdateFavoredNodesResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UpdateFavoredNodesResponse
- AdminProtos.UpdateFavoredNodesResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type UpdateFavoredNodesResponse
- AdminProtos.UpdateFavoredNodesResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.WALEntry - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type WALEntry
- AdminProtos.WALEntry.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type WALEntry
- AdminProtos.WALEntryOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.WarmupRegionRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type WarmupRegionRequest
- AdminProtos.WarmupRegionRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type WarmupRegionRequest
- AdminProtos.WarmupRegionRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AdminProtos.WarmupRegionResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type WarmupRegionResponse
- AdminProtos.WarmupRegionResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type WarmupRegionResponse
- AdminProtos.WarmupRegionResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- ADMINS_ACL - Static variable in class org.apache.hadoop.hbase.http.HttpServer
-
- AdminService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.AdminService
-
- advance() - Method in interface org.apache.hadoop.hbase.CellScanner
-
Advance the scanner 1 cell.
- advance() - Method in class org.apache.hadoop.hbase.client.Result
-
- advance() - Method in class org.apache.hadoop.hbase.codec.BaseDecoder
-
- advance() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- advance() - Method in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeSeeker
-
- AES - Class in org.apache.hadoop.hbase.io.crypto.aes
-
AES-128, provided by the JCE
- AES(CipherProvider) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.AES
-
- AESDecryptor - Class in org.apache.hadoop.hbase.io.crypto.aes
-
- AESDecryptor(Cipher) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.AESDecryptor
-
- AESEncryptor - Class in org.apache.hadoop.hbase.io.crypto.aes
-
- AESEncryptor(Cipher, SecureRandom) - Constructor for class org.apache.hadoop.hbase.io.crypto.aes.AESEncryptor
-
- affixShutdownHook(Thread, int) - Static method in class org.apache.hadoop.hbase.util.ShutdownHookManager
-
- after() - Method in class org.apache.hadoop.hbase.client.TestReplicasClient
-
- after() - Method in class org.apache.hadoop.hbase.coprocessor.TestHTableWrapper
-
- after() - Method in class org.apache.hadoop.hbase.io.TestBoundedByteBufferPool
-
- after() - Method in class org.apache.hadoop.hbase.mapreduce.TestTimeRangeMapRed
-
- after() - Method in class org.apache.hadoop.hbase.master.TestAssignmentManager
-
- after() - Method in class org.apache.hadoop.hbase.master.TestDistributedLogSplitting
-
- after() - Static method in class org.apache.hadoop.hbase.master.TestMasterMetrics
-
- after() - Static method in class org.apache.hadoop.hbase.mttr.IntegrationTestMTTR
-
- after() - Method in class org.apache.hadoop.hbase.quotas.TestQuotaTableUtil
-
- after() - Static method in class org.apache.hadoop.hbase.regionserver.handler.TestCloseRegionHandler
-
- after() - Static method in class org.apache.hadoop.hbase.regionserver.handler.TestOpenRegionHandler
-
- after() - Method in class org.apache.hadoop.hbase.regionserver.TestRegionReplicaFailover
-
- after() - Method in class org.apache.hadoop.hbase.regionserver.TestRegionReplicas
-
- after() - Static method in class org.apache.hadoop.hbase.regionserver.TestRegionServerMetrics
-
- after() - Method in class org.apache.hadoop.hbase.regionserver.TestRegionServerNoMaster
-
- after() - Static method in class org.apache.hadoop.hbase.regionserver.TestRowTooBig
-
- after() - Method in class org.apache.hadoop.hbase.regionserver.TestServerCustomProtocol
-
- after() - Static method in class org.apache.hadoop.hbase.regionserver.TestSplitTransactionOnCluster
-
- after() - Static method in class org.apache.hadoop.hbase.regionserver.TestZKLessSplitOnCluster
-
- after() - Method in class org.apache.hadoop.hbase.replication.regionserver.TestRegionReplicaReplicationEndpointNoMaster
-
- after() - Method in class org.apache.hadoop.hbase.rest.client.TestRemoteTable
-
- after() - Method in class org.apache.hadoop.hbase.TestMetaTableAccessorNoCluster
-
- after() - Method in class org.apache.hadoop.hbase.TestMetaTableLocator
-
- after() - Method in class org.apache.hadoop.hbase.TestMovedRegionsCleaner
-
- after() - Method in class org.apache.hadoop.hbase.TestMultiVersions
-
- after() - Method in class org.apache.hadoop.hbase.TestRegionRebalancing
-
- after() - Method in class org.apache.hadoop.hbase.TestZooKeeper
-
- after() - Static method in class org.apache.hadoop.hbase.trace.TestHTraceHooks
-
- afterAllTests() - Static method in class org.apache.hadoop.hbase.master.handler.TestTableDeleteFamilyHandler
-
- afterAllTests() - Static method in class org.apache.hadoop.hbase.master.handler.TestTableDescriptorModification
-
- afterAllTests() - Static method in class org.apache.hadoop.hbase.master.normalizer.TestSimpleRegionNormalizerOnCluster
-
- afterAllTests() - Static method in class org.apache.hadoop.hbase.master.TestAssignmentListener
-
- afterAllTests() - Static method in class org.apache.hadoop.hbase.master.TestMaster
-
- afterAllTests() - Static method in class org.apache.hadoop.hbase.master.TestMasterTransitions
-
- afterAllTests() - Static method in class org.apache.hadoop.hbase.master.TestZKBasedOpenCloseRegion
-
- afterAllTests() - Static method in class org.apache.hadoop.hbase.regionserver.TestEndToEndSplitTransaction
-
- afterAllTests() - Static method in class org.apache.hadoop.hbase.regionserver.TestRegionMergeTransactionOnCluster
-
- afterAllTests() - Static method in class org.apache.hadoop.hbase.regionserver.TestZKLessMergeOnCluster
-
- afterAllTests() - Static method in class org.apache.hadoop.hbase.TestHColumnDescriptorDefaultVersions
-
- afterAllTests() - Static method in class org.apache.hadoop.hbase.zookeeper.lock.TestZKInterProcessReadWriteLock
-
- afterClass() - Static method in class org.apache.hadoop.hbase.client.TestMultiParallel
-
- afterClass() - Static method in class org.apache.hadoop.hbase.client.TestReplicasClient
-
- afterClass() - Static method in class org.apache.hadoop.hbase.client.TestReplicaWithCluster
-
- afterClass() - Static method in class org.apache.hadoop.hbase.io.hfile.TestCacheOnWrite
-
- afterClass() - Static method in class org.apache.hadoop.hbase.mapred.TestTableInputFormat
-
- afterClass() - Static method in class org.apache.hadoop.hbase.mapred.TestTableMapReduceUtil
-
- afterClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestCellCounter
-
- afterClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestCopyTable
-
- afterClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestHRegionPartitioner
-
- afterClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestImportExport
-
- afterClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestMultithreadedTableMapper
-
- afterClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestTableInputFormat
-
- afterClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestTableMapReduceBase
-
- afterClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestTimeRangeMapRed
-
- afterClass() - Static method in class org.apache.hadoop.hbase.mapreduce.TestWALPlayer
-
- afterClass() - Static method in class org.apache.hadoop.hbase.master.TestAssignmentManager
-
- afterClass() - Static method in class org.apache.hadoop.hbase.regionserver.TestRegionReplicas
-
- afterClass() - Static method in class org.apache.hadoop.hbase.regionserver.TestRegionServerNoMaster
-
- afterClass() - Static method in class org.apache.hadoop.hbase.replication.regionserver.TestRegionReplicaReplicationEndpoint
-
- afterClass() - Static method in class org.apache.hadoop.hbase.replication.regionserver.TestRegionReplicaReplicationEndpointNoMaster
-
- afterClass() - Static method in class org.apache.hadoop.hbase.security.access.TestNamespaceCommands
-
- afterClass() - Static method in class org.apache.hadoop.hbase.security.access.TestTablePermissions
-
- afterClass() - Static method in class org.apache.hadoop.hbase.security.access.TestZKPermissionsWatcher
-
- afterClass() - Static method in class org.apache.hadoop.hbase.TestDrainingServer
-
- afterClass() - Static method in class org.apache.hadoop.hbase.TestInfoServers
-
- afterClass() - Static method in class org.apache.hadoop.hbase.TestMetaTableAccessor
-
- afterClass() - Static method in class org.apache.hadoop.hbase.TestMetaTableLocator
-
- afterClass() - Static method in class org.apache.hadoop.hbase.thrift.TestThriftServer
-
- afterClass() - Static method in class org.apache.hadoop.hbase.thrift2.TestThriftHBaseServiceHandler
-
- afterClass() - Static method in class org.apache.hadoop.hbase.thrift2.TestThriftHBaseServiceHandlerWithLabels
-
- afterCreatingZigZagLatch() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
Used to manufacture race condition reliably.
- afterExecute() - Method in class org.apache.hadoop.hbase.regionserver.compactions.CompactionRequest
-
Called after compaction is executed by CompactSplitThread; for use by coproc subclasses.
- afterExecute() - Method in class org.apache.hadoop.hbase.regionserver.TestCompaction.TrackableCompactionRequest
-
- afterLast - Variable in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- afterMethod() - Method in class org.apache.hadoop.hbase.rest.RowResourceBase
-
- afterProcess(EventHandler) - Method in interface org.apache.hadoop.hbase.executor.EventHandler.EventHandlerListener
-
Called after any event is processed
- AGEOFLASTAPPLIEDOP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSink
-
- AGEOFLASTSHIPPEDOP_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClusterStatusProtos.ReplicationLoadSource
-
- AgeSnapshot - Class in org.apache.hadoop.hbase.io.hfile
-
Snapshot of block cache age in cache.
- AggregateImplementation<T,S,P extends Message,Q extends Message,R extends Message> - Class in org.apache.hadoop.hbase.coprocessor
-
A concrete AggregateProtocol implementation.
- AggregateImplementation() - Constructor for class org.apache.hadoop.hbase.coprocessor.AggregateImplementation
-
- AggregateProtos - Class in org.apache.hadoop.hbase.protobuf.generated
-
- AggregateProtos.AggregateRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type AggregateRequest
- AggregateProtos.AggregateRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type AggregateRequest
- AggregateProtos.AggregateRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AggregateProtos.AggregateResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type AggregateResponse
- AggregateProtos.AggregateResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type AggregateResponse
- AggregateProtos.AggregateResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AggregateProtos.AggregateService - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf service AggregateService
- AggregateProtos.AggregateService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AggregateProtos.AggregateService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AggregateProtos.AggregateService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
-
- AggregateService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.AggregateProtos.AggregateService
-
- AggregationClient - Class in org.apache.hadoop.hbase.client.coprocessor
-
This client class is for invoking the aggregate functions deployed on the
Region Server side via the AggregateService.
- AggregationClient(Configuration) - Constructor for class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
Constructor with Conf object
- ALGORITHM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.EncryptionProtos.WrappedKey
-
- align(int) - Static method in class org.apache.hadoop.hbase.util.ClassSize
-
Aligns a number to 8.
- align(long) - Static method in class org.apache.hadoop.hbase.util.ClassSize
-
Aligns a number to 8.
- ALL_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
-
Define for 'return-all-versions'.
- AllFailConstraint - Class in org.apache.hadoop.hbase.constraint
-
Always fail the put.
- AllFailConstraint() - Constructor for class org.apache.hadoop.hbase.constraint.AllFailConstraint
-
- allocate() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
-
Allocate a block in this bucket, return the offset representing the
position in physical space
- allocateBlock(int) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
-
Allocate a block with specified size.
- allocateBytes(int) - Method in class org.apache.hadoop.hbase.regionserver.HeapMemStoreLAB
-
Allocate a slice of the given length.
- allocateBytes(int) - Method in interface org.apache.hadoop.hbase.regionserver.MemStoreLAB
-
Allocate a slice of the given length.
- allocBloom() - Method in interface org.apache.hadoop.hbase.util.BloomFilterWriter
-
Allocate memory for the bloom filter data.
- allocBloom() - Method in class org.apache.hadoop.hbase.util.ByteBloomFilter
-
- allocBloom() - Method in class org.apache.hadoop.hbase.util.CompoundBloomFilterWriter
-
- allow(String, String, User, Permission.Action, String) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- allow(String, String, User, Permission.Action, TableName, byte[], byte[]) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- allow(String, String, User, Permission.Action, TableName, Map<byte[], ? extends Collection<?>>) - Static method in class org.apache.hadoop.hbase.security.access.AuthResult
-
- allowCompactions() - Method in class org.apache.hadoop.hbase.TestIOFencing.CompactionBlockerRegion
-
- AllPassConstraint - Class in org.apache.hadoop.hbase.constraint
-
Simple test constraint that always allows the put to pass
- AllPassConstraint() - Constructor for class org.apache.hadoop.hbase.constraint.AllPassConstraint
-
- allSameType - Variable in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.CellTypeEncoder
-
- allSameType - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- allTableRegions(Configuration, Connection, TableName, boolean) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
-
- allTableRegions(Connection, TableName) - Static method in class org.apache.hadoop.hbase.client.MetaScanner
-
Lists all of the table regions currently in META.
- allTypes - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
- ALREADY_OPENED_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.AdminProtos.OpenRegionResponse.RegionOpeningState
-
ALREADY_OPENED = 1;
- AlreadyExists - Class in org.apache.hadoop.hbase.thrift.generated
-
An AlreadyExists exceptions signals that a table with the specified
name already exists
- AlreadyExists() - Constructor for class org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- AlreadyExists(String) - Constructor for class org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
- AlreadyExists(AlreadyExists) - Constructor for class org.apache.hadoop.hbase.thrift.generated.AlreadyExists
-
Performs a deep copy on other.
- AlreadyExists._Fields - Enum in org.apache.hadoop.hbase.thrift.generated
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- AlsoWorks() - Constructor for class org.apache.hadoop.hbase.constraint.TestConstraints.AlsoWorks
-
- AlwaysDelete() - Constructor for class org.apache.hadoop.hbase.master.cleaner.TestCleanerChore.AlwaysDelete
-
- AlwaysNextColFilter() - Constructor for class org.apache.hadoop.hbase.filter.TestFilterList.AlwaysNextColFilter
-
- ammount - Variable in class org.apache.hadoop.hbase.thrift.generated.TIncrement
-
- amount - Variable in class org.apache.hadoop.hbase.thrift2.generated.TColumnIncrement
-
- And(ClassFinder.ClassFilter...) - Constructor for class org.apache.hadoop.hbase.ClassFinder.And
-
- AND - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
AND Byte Array
- AND_ARRAY - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
AND Array
- AND_BUFFER - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
-
- AND_OPERATOR - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityConstants
-
- AND_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ComparatorProtos.BitComparator.BitwiseOp
-
AND = 1;
- answer(InvocationOnMock) - Method in class org.apache.hadoop.hbase.GenericTestUtils.DelayAnswer
-
- answer(InvocationOnMock) - Method in class org.apache.hadoop.hbase.GenericTestUtils.DelegateAnswer
-
- answer(InvocationOnMock) - Method in class org.apache.hadoop.hbase.GenericTestUtils.SleepAnswer
-
- answer(InvocationOnMock) - Method in class org.apache.hadoop.hbase.regionserver.TestStripeCompactor.StoreFileWritersCapture
-
- ap - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
-
- APP_DIR - Static variable in class org.apache.hadoop.hbase.http.HttpServer
-
- appDir - Variable in class org.apache.hadoop.hbase.http.HttpServer
-
- Append - Class in org.apache.hadoop.hbase.client
-
Performs Append operations on a single row.
- Append(byte[]) - Constructor for class org.apache.hadoop.hbase.client.Append
-
Create a Append operation for the specified row.
- Append(Append) - Constructor for class org.apache.hadoop.hbase.client.Append
-
Copy constructor
- Append(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Append
-
Create a Append operation for the specified row.
- append(Append) - Method in class org.apache.hadoop.hbase.client.HTable
-
Appends values to one or more columns within a single row.
- append(Append) - Method in class org.apache.hadoop.hbase.client.HTableWrapper
-
- append(Append) - Method in interface org.apache.hadoop.hbase.client.Table
-
Appends values to one or more columns within a single row.
- append(LoggingEvent) - Method in class org.apache.hadoop.hbase.http.HttpRequestLogAppender
-
- append(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFile.FileInfo
-
Append the given key/value pair to the file info, optionally checking the
key prefix.
- append(Cell) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
- append(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
Add key/value to file.
- append(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV3
-
Add key/value to file.
- append(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.Compactor.CellSink
-
- append(Append) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- append(Append, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- append(Append, long, long) - Method in interface org.apache.hadoop.hbase.regionserver.Region
-
Perform one or more append operations on a row.
- append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
- append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.BoundaryMultiWriter
-
- append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StripeMultiFileWriter.SizeMultiWriter
-
- append(HTableDescriptor, HRegionInfo, WALKey, WALEdit, AtomicLong, boolean, List<Cell>) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
-
- append(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.InstrumentedLogWriter
-
- append(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
-
- append(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceFileLogWriter
-
- append(Append) - Method in class org.apache.hadoop.hbase.rest.client.RemoteHTable
-
- append - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
The single append operation to apply
- append(TAppend, <any>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- append(TAppend, <any>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- append(TAppend) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- append(TAppend) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Appends values to one or more columns within a single row.
- append() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.append
-
- append(TAppend) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- append - Variable in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
the TAppend to append
- append(ByteBuffer, TAppend, <any>) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- append(ByteBuffer, TAppend, <any>) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncIface
-
- append(ByteBuffer, TAppend) - Method in class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Client
-
- append(ByteBuffer, TAppend) - Method in interface org.apache.hadoop.hbase.thrift2.generated.THBaseService.Iface
-
- append() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.Processor.append
-
- append(ByteBuffer, TAppend) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
-
- append(HTableDescriptor, HRegionInfo, WALKey, WALEdit, AtomicLong, boolean, List<Cell>) - Method in class org.apache.hadoop.hbase.wal.FaultyFSLog
-
- append(HTableDescriptor, HRegionInfo, WALKey, WALEdit, AtomicLong, boolean, List<Cell>) - Method in interface org.apache.hadoop.hbase.wal.WAL
-
Append a set of edits to the WAL.
- append(WAL.Entry) - Method in interface org.apache.hadoop.hbase.wal.WALProvider.Writer
-
- append(WALSplitter.RegionEntryBuffer) - Method in class org.apache.hadoop.hbase.wal.WALSplitter.OutputSink
-
- append_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
- append_args(TAppend) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
- append_args(Hbase.append_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_args
-
Performs a deep copy on other.
- append_args() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
- append_args(ByteBuffer, TAppend) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
- append_args(THBaseService.append_args) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_args
-
Performs a deep copy on other.
- append_call(TAppend, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.append_call
-
- append_call(ByteBuffer, TAppend, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient.append_call
-
- APPEND_COUNT - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- APPEND_COUNT_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- APPEND_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
-
- append_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- append_result(List<TCell>, IOError) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
- append_result(Hbase.append_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.append_result
-
Performs a deep copy on other.
- append_result() - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
- append_result(TResult, TIOError) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
- append_result(THBaseService.append_result) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.append_result
-
Performs a deep copy on other.
- APPEND_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- APPEND_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- APPEND_TIME - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- APPEND_TIME_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.wal.MetricsWALSource
-
- APPEND_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.MutationType
-
APPEND = 0;
- appendCurrentTokenToRowBuffer() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
helper methods
- appendEntry(WALProvider.Writer, TableName, byte[], byte[], byte[], byte[], byte[], long) - Static method in class org.apache.hadoop.hbase.wal.TestWALSplit
-
- appendEntry(WAL.Entry) - Method in class org.apache.hadoop.hbase.wal.WALSplitter.EntryBuffers
-
Append a log entry into the corresponding region buffer.
- appendFileInfo(byte[], byte[]) - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileWriter
-
Add to the file info.
- appendFileInfo(byte[], byte[]) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
Add an element to the file info map.
- appendFileInfo(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
- appendFromThrift(TAppend) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
-
- appendFromThrift(TAppend) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
-
- appendKeyTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
- appendKeyValue(StringBuilder, String, Object) - Static method in class org.apache.hadoop.hbase.util.Strings
-
Append to a StringBuilder a key/value.
- appendKeyValue(StringBuilder, String, Object, String, String) - Static method in class org.apache.hadoop.hbase.util.Strings
-
Append to a StringBuilder a key/value.
- appendMetaBlock(String, Writable) - Method in interface org.apache.hadoop.hbase.io.hfile.HFile.Writer
-
- appendMetaBlock(String, Writable) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterV2
-
Add a meta block to the end of the file.
- appendMetadata(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
Writes meta data.
- appendNodes(List<TokenizerNode>, boolean, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
- appendNodesToExternalList(List<TokenizerNode>, boolean, boolean) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
moving nodes around
- appendOutputArrayOffsets(List<Integer>) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
- appendOutputArrayOffsets(List<Integer>) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.TokenizerNode
-
- appendPeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Append the replicable table-cf config of the specified peer
- appendPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
-
Append the replicable table-cf config of the specified peer
- appendStrings(StringBuilder, String...) - Static method in class org.apache.hadoop.hbase.procedure2.util.StringUtils
-
- appendThreadInfo(StringBuilder, ThreadInfo, String) - Static method in class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
-
Print all of the thread's information and stack traces.
- appendToByteArray(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
copy key and value
- appendToByteBuffer(ByteBuffer, KeyValue, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
-
- appendTokenAndRepointByteRange(ByteRange, int) - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.tokenize.Tokenizer
-
- appendToRowBuffer(byte) - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
- appendToStatus(StringBuilder, String, long) - Static method in class org.apache.hadoop.hbase.util.MultiThreadedAction
-
- appendToStatus(StringBuilder, String, String) - Static method in class org.apache.hadoop.hbase.util.MultiThreadedAction
-
- appendTrackedTimestampsToMetadata() - Method in class org.apache.hadoop.hbase.regionserver.StoreFile.Writer
-
Add TimestampRange and earliest put timestamp to Metadata
- apply(byte) - Method in enum org.apache.hadoop.hbase.util.Order
-
Apply order to the byte val
.
- apply(byte[]) - Method in enum org.apache.hadoop.hbase.util.Order
-
Apply order to the byte array val
.
- apply(byte[], int, int) - Method in enum org.apache.hadoop.hbase.util.Order
-
Apply order to a range within the byte array val
.
- applyBatch(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
-
Convience method to change metrics when a batch of operations are applied.
- applyColumnFamilyOptions(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.util.LoadTestTool
-
Apply column family options such as Bloom filters, compression, and data
block encoding.
- applyCompactionPolicy(List<StoreFile>, boolean, boolean, int, int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.ExploringCompactionPolicy
-
- archiveFamily(FileSystem, Configuration, HRegionInfo, Path, byte[]) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Remove from the specified region the store files of the specified column family,
either by archiving them or outright deletion
- archiveRegion(Configuration, FileSystem, HRegionInfo) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Cleans up all the files for a HRegion by archiving the HFiles to the
archive directory
- archiveRegion(FileSystem, Path, Path, Path) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Remove an entire region from the table directory via archiving the region's hfiles.
- archiveStoreFile(Configuration, FileSystem, HRegionInfo, Path, byte[], Path) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Archive the store file
- archiveStoreFiles(Configuration, FileSystem, HRegionInfo, Path, byte[], Collection<StoreFile>) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
-
Remove the store files, either by archiving them or outright deletion
- areAdjacent(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
-
Check whether two regions are adjacent
- areAllSameType() - Method in class org.apache.hadoop.hbase.codec.prefixtree.encode.other.CellTypeEncoder
-
get/set
- areBuffersBigEnough() - Method in class org.apache.hadoop.hbase.codec.prefixtree.decode.PrefixTreeArrayScanner
-
Call when first accessing a block.
- areDeadServersInProgress() - Method in class org.apache.hadoop.hbase.master.DeadServer
-
Checks if there are currently any dead servers being processed by the
master.
- areDeadServersInProgress() - Method in class org.apache.hadoop.hbase.master.ServerManager
-
Checks if any dead servers are currently in progress.
- areKeyLengthsEqual(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
-
lengths
- arePartsEqual(ByteBuffer, int, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
-
Check whether two parts in the same buffer are equal.
- areRowLengthsEqual(Cell, Cell) - Static method in class org.apache.hadoop.hbase.CellComparator
-
- areSomeRegionReplicasColocated(BaseLoadBalancer.Cluster) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Subclasses should implement this to return true if the cluster has nodes that hosts
multiple replicas for the same region, or, if there are multiple racks and the same
rack hosts replicas of the same region
- areSomeRegionReplicasColocated(BaseLoadBalancer.Cluster) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
-
- areWritesEnabled() - Method in class org.apache.hadoop.hbase.regionserver.HRegion
-
- areWritesEnabled() - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- areWritesEnabled() - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
- Args(TServerTransport, Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer.Args
-
- args - Variable in class org.apache.hadoop.hbase.util.test.LoadTestDataGenerator
-
- ARRAY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Array overhead
- ARRAYLIST - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for ArrayList(0)
- arrayOffset - Variable in class org.apache.hadoop.hbase.codec.prefixtree.PrefixTreeBlockMeta
-
transient fields
- ArraySearcherPool - Class in org.apache.hadoop.hbase.codec.prefixtree.decode
-
Pools PrefixTreeArraySearcher objects.
- ArraySearcherPool() - Constructor for class org.apache.hadoop.hbase.codec.prefixtree.decode.ArraySearcherPool
-
- ArrayUtils - Class in org.apache.hadoop.hbase.util
-
A set of array utility functions that return reasonable values in cases where an array is
allocated or if it is null
- ArrayUtils() - Constructor for class org.apache.hadoop.hbase.util.ArrayUtils
-
- AS_JSON - Variable in class org.apache.hadoop.hbase.rest.model.TestModelBase
-
- AS_PB - Variable in class org.apache.hadoop.hbase.rest.model.TestModelBase
-
- AS_XML - Variable in class org.apache.hadoop.hbase.rest.model.TestModelBase
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlob
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedBlobVar
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat32
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedFloat64
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt16
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt32
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt64
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedInt8
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedNumeric
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.OrderedString
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.RawBytes
-
- ASCENDING - Static variable in class org.apache.hadoop.hbase.types.RawString
-
- asInterrupt(Throwable) - Static method in class org.apache.hadoop.hbase.util.ExceptionUtil
-
- asList(byte[], int, int) - Static method in class org.apache.hadoop.hbase.Tag
-
Creates the list of tags from the byte array b.
- assertArchiveEqualToOriginal(FileStatus[], FileStatus[], FileSystem) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveTestingUtil
-
Compare the archived files to the files in the original directory
- assertArchiveEqualToOriginal(FileStatus[], FileStatus[], FileSystem, boolean) - Static method in class org.apache.hadoop.hbase.util.HFileArchiveTestingUtil
-
Compare the archived files to the files in the original directory
- assertBulkLoadHFileOk(Path) - Method in class org.apache.hadoop.hbase.regionserver.HStore
-
- assertBulkLoadHFileOk(Path) - Method in interface org.apache.hadoop.hbase.regionserver.Store
-
This throws a WrongRegionException if the HFile does not fit in this region, or an
InvalidHFileException if the HFile is not valid.
- assertByteEquals(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
- assertClassesAreBuilderStyle(Class...) - Static method in class org.apache.hadoop.hbase.util.BuilderStyleTest
-
- assertClusterAsBalanced(List<ServerAndLoad>) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerTestBase
-
Invariant is that all servers have between floor(avg) and ceiling(avg)
number of regions.
- assertConnectedPeerStatus(boolean, String) - Method in class org.apache.hadoop.hbase.replication.TestReplicationStateBasic
-
- assertCounter(String, long, BaseSource) - Method in interface org.apache.hadoop.hbase.test.MetricsAssertHelper
-
Assert that a counter exists and that it's value is equal to the expected value.
- assertCounter(String, long, BaseSource) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl
-
- assertCounterGt(String, long, BaseSource) - Method in interface org.apache.hadoop.hbase.test.MetricsAssertHelper
-
Assert that a counter exists and that it's value is greater than the given value.
- assertCounterGt(String, long, BaseSource) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl
-
- assertCounterLt(String, long, BaseSource) - Method in interface org.apache.hadoop.hbase.test.MetricsAssertHelper
-
Assert that a counter exists and that it's value is less than the given value.
- assertCounterLt(String, long, BaseSource) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl
-
- assertEmptyMetaLocation(Table, byte[], int) - Static method in class org.apache.hadoop.hbase.TestMetaTableAccessor
-
- assertEquals(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
- assertErrors(HBaseFsck, HBaseFsck.ErrorReporter.ERROR_CODE[]) - Static method in class org.apache.hadoop.hbase.util.hbck.HbckTestingUtil
-
- assertExceptionContains(String, Throwable) - Static method in class org.apache.hadoop.hbase.GenericTestUtils
-
- assertExists(File) - Static method in class org.apache.hadoop.hbase.GenericTestUtils
-
Assert that a given file exists.
- assertExistsMatchingSnapshot(Admin, String, TableName) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
Make sure that there is only one snapshot returned from the master and its
name and table match the passed in parameters.
- assertGauge(String, long, BaseSource) - Method in interface org.apache.hadoop.hbase.test.MetricsAssertHelper
-
Assert that a gauge exists and that it's value is equal to the expected value.
- assertGauge(String, double, BaseSource) - Method in interface org.apache.hadoop.hbase.test.MetricsAssertHelper
-
Assert that a gauge exists and that it's value is equal to the expected value.
- assertGauge(String, long, BaseSource) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl
-
- assertGauge(String, double, BaseSource) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl
-
- assertGaugeGt(String, long, BaseSource) - Method in interface org.apache.hadoop.hbase.test.MetricsAssertHelper
-
Assert that a gauge exists and it's value is greater than a given value
- assertGaugeGt(String, double, BaseSource) - Method in interface org.apache.hadoop.hbase.test.MetricsAssertHelper
-
Assert that a gauge exists and it's value is greater than a given value
- assertGaugeGt(String, long, BaseSource) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl
-
- assertGaugeGt(String, double, BaseSource) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl
-
- assertGaugeLt(String, long, BaseSource) - Method in interface org.apache.hadoop.hbase.test.MetricsAssertHelper
-
Assert that a gauge exists and it's value is less than a given value
- assertGaugeLt(String, double, BaseSource) - Method in interface org.apache.hadoop.hbase.test.MetricsAssertHelper
-
Assert that a gauge exists and it's value is less than a given value
- assertGaugeLt(String, long, BaseSource) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl
-
- assertGaugeLt(String, double, BaseSource) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl
-
- assertGlobEquals(File, String, String...) - Static method in class org.apache.hadoop.hbase.GenericTestUtils
-
List all of the files in 'dir' that match the regex 'pattern'.
- assertIsAbortException(ProcedureInfo) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureTestingUtility
-
- assertIsIllegalArgumentException(ProcedureInfo) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureTestingUtility
-
- assertIsTimeoutException(ProcedureInfo) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureTestingUtility
-
- assertKey(byte[], ByteBuffer) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluationCommons
-
- assertKey(byte[], Cell) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluationCommons
-
- assertKey(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluationCommons
-
- assertKey(byte[], byte[], int, int) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluationCommons
-
- assertKeyAndValueEqual(Cell, Cell) - Method in class org.apache.hadoop.hbase.codec.prefixtree.row.TestRowEncoder
-
helper
- assertKVListsEqual(String, List<? extends Cell>, List<? extends Cell>) - Static method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
- assertKVListsEqual(String, List<? extends Cell>, List<? extends Cell>) - Method in class org.apache.hadoop.hbase.regionserver.TestSeekOptimizations
-
- assertMatches(String, String) - Static method in class org.apache.hadoop.hbase.GenericTestUtils
-
- assertMetaLocation(Table, byte[], ServerName, long, int, boolean) - Static method in class org.apache.hadoop.hbase.TestMetaTableAccessor
-
- assertNoErrors(HBaseFsck) - Static method in class org.apache.hadoop.hbase.util.hbck.HbckTestingUtil
-
- assertNoSnapshots(Admin) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
Assert that we don't have any snapshots lists
- assertNoThreadsMatching(String) - Static method in class org.apache.hadoop.hbase.GenericTestUtils
-
Assert that there are no threads running whose name matches the
given regular expression.
- assertNumberOfPeers(int) - Method in class org.apache.hadoop.hbase.replication.TestReplicationStateBasic
-
- assertOneSnapshotThatMatches(Admin, HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
Make sure that there is only one snapshot returned from the master
- assertOneSnapshotThatMatches(Admin, String, TableName) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
Make sure that there is only one snapshot returned from the master and its
name and table match the passed in parameters.
- assertOneSnapshotThatMatches(Admin, byte[], TableName) - Static method in class org.apache.hadoop.hbase.snapshot.SnapshotTestingUtils
-
Make sure that there is only one snapshot returned from the master and its
name and table match the passed in parameters.
- assertOnFutures(List<Future<T>>) - Static method in class org.apache.hadoop.hbase.MultithreadedTestUtil
-
Verify that no assertions have failed inside a future.
- assertProcNotFailed(ProcedureExecutor<TEnv>, long) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureTestingUtility
-
- assertProcNotFailed(ProcedureInfo) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureTestingUtility
-
- assertProcNotYetCompleted(ProcedureExecutor<TEnv>, long) - Static method in class org.apache.hadoop.hbase.procedure2.ProcedureTestingUtility
-
- assertRangesEqual(List<MultiRowRangeFilter.RowRange>, List<MultiRowRangeFilter.RowRange>) - Method in class org.apache.hadoop.hbase.filter.TestMultiRowRangeFilter
-
- assertReFind(String, String) - Static method in class org.apache.hadoop.hbase.http.jmx.TestJMXJsonServlet
-
- assertRegionOnlyOnServer(HRegionInfo, ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Check to make sure the region is open on the specified
region server, but not on any other one.
- assertRegionOnServer(HRegionInfo, ServerName, long) - Method in class org.apache.hadoop.hbase.HBaseTestingUtility
-
Due to async racing issue, a region may not be in
the online region list of a region server yet, after
the assignment znode is deleted and the new assignment
is recorded in master.
- assertRegionReplicaPlacement(Map<ServerName, List<HRegionInfo>>, RackManager) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerTestBase
-
Checks whether region replicas are not hosted on the same host.
- assertResultEquals(HRegion, byte[], byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.HBaseTestCase
-
Deprecated.
- assertScanContentTimestamp(HBaseTestCase.Incommon, long) - Static method in class org.apache.hadoop.hbase.TimestampTestBase
-
- assertSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader.Scanner
-
- assertSnapshotRequestIsValid(HBaseProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
-
Check to make sure that the description of the snapshot requested is valid
- assertTag(String, String, BaseSource) - Method in interface org.apache.hadoop.hbase.test.MetricsAssertHelper
-
Assert that a tag exists and has a given value.
- assertTag(String, String, BaseSource) - Method in class org.apache.hadoop.hbase.test.MetricsAssertHelperImpl
-
- assertTColumnValuesEqual(List<TColumnValue>, List<TColumnValue>) - Method in class org.apache.hadoop.hbase.thrift2.TestThriftHBaseServiceHandler
-
- assertTColumnValuesEqual(List<TColumnValue>, List<TColumnValue>) - Method in class org.apache.hadoop.hbase.thrift2.TestThriftHBaseServiceHandlerWithLabels
-
- assertValueNear(long, long, long) - Static method in class org.apache.hadoop.hbase.GenericTestUtils
-
- assertValueSize(int, int) - Static method in class org.apache.hadoop.hbase.PerformanceEvaluationCommons
-
- assertValueWithinRange(long, long, long) - Static method in class org.apache.hadoop.hbase.GenericTestUtils
-
- assertVersions(HBaseTestCase.Incommon, long[]) - Static method in class org.apache.hadoop.hbase.TimestampTestBase
-
- assign(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
-
- assign(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
-
- assign(HRegionInfo, boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Assigns the specified region.
- assign(HRegionInfo, boolean, boolean) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Use care with forceNewPlan.
- assign(Map<HRegionInfo, ServerName>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Assigns specified regions retaining assignments, if any.
- assign(List<HRegionInfo>) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Assigns specified regions round robin, if any.
- ASSIGN_SEQ_NUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.BulkLoadHFileRequest
-
- ASSIGN_SEQ_NUM_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.SecureBulkLoadProtos.SecureBulkLoadHFilesRequest
-
- ASSIGN_TIME_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
-
- AssignCallable - Class in org.apache.hadoop.hbase.master
-
A callable object that invokes the corresponding action that needs to be
taken for assignment of a region in transition.
- AssignCallable(AssignmentManager, HRegionInfo, boolean) - Constructor for class org.apache.hadoop.hbase.master.AssignCallable
-
- assignMasterRegions(Collection<HRegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
-
Assign the regions that should be on master regionserver.
- AssignmentListener - Interface in org.apache.hadoop.hbase.master
-
Get notification of assignment events.
- AssignmentManager - Class in org.apache.hadoop.hbase.master
-
Manages and performs region assignment.
- AssignmentManager(Server, ServerManager, LoadBalancer, ExecutorService, MetricsMaster, TableLockManager) - Constructor for class org.apache.hadoop.hbase.master.AssignmentManager
-
Constructs a new assignment manager.
- AssignmentManager.ServerHostRegion - Enum in org.apache.hadoop.hbase.master
-
- AssignmentVerificationReport - Class in org.apache.hadoop.hbase.master
-
- AssignmentVerificationReport() - Constructor for class org.apache.hadoop.hbase.master.AssignmentVerificationReport
-
- assignmentZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZooKeeperWatcher
-
- assignMeta(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.AssignmentManager
-
Assigns the hbase:meta region or a replica.
- assignRegion(HRegionInfo) - Method in class org.apache.hadoop.hbase.master.HMaster
-
- assignRegion(RpcController, MasterProtos.AssignRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
-
- assignRegion(com.google.protobuf.RpcController, MasterProtos.AssignRegionRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService
-
rpc AssignRegion(.AssignRegionRequest) returns (.AssignRegionResponse);
- assignRegion(com.google.protobuf.RpcController, MasterProtos.AssignRegionRequest) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.BlockingInterface
-
- assignRegion(com.google.protobuf.RpcController, MasterProtos.AssignRegionRequest, <any>) - Method in interface org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Interface
-
rpc AssignRegion(.AssignRegionRequest) returns (.AssignRegionResponse);
- assignRegion(com.google.protobuf.RpcController, MasterProtos.AssignRegionRequest, <any>) - Method in class org.apache.hadoop.hbase.protobuf.generated.MasterProtos.MasterService.Stub
-
- AssignRegionAction(int, int) - Constructor for class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer.Cluster.AssignRegionAction
-
- assignRegions(MasterProcedureEnv, TableName, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
-
- assignRegions(AssignmentManager, List<HRegionInfo>) - Static method in class org.apache.hadoop.hbase.util.ModifyRegionUtils
-
Triggers a bulk assignment of the specified regions
- ASSOCIATED_CELL_COUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AdminProtos.WALEntry
-
- ASSOCIATED_CELL_COUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
- ASSOCIATED_CELL_COUNT_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Result
-
- assumeUncompressed() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
-
An additional sanity-check in case no compression or encryption is being used.
- ASYNC_WAL_VALUE - Static variable in enum org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto.Durability
-
ASYNC_WAL = 2;
- AsyncCall - Class in org.apache.hadoop.hbase.ipc
-
Represents an Async Hbase call and its response.
- AsyncCall(EventLoop, int, Descriptors.MethodDescriptor, Message, PayloadCarryingRpcController, Message) - Constructor for class org.apache.hadoop.hbase.ipc.AsyncCall
-
Constructor
- AsyncClient(org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.async.TAsyncClientManager, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- AsyncClient(org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.async.TAsyncClientManager, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift2.generated.THBaseService.AsyncClient
-
- asyncCreate(ZooKeeperWatcher, String, byte[], AsyncCallback.StringCallback, Object) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
-
Async creates the specified node with the specified data.
- asyncCreateNodeOffline(ZooKeeperWatcher, HRegionInfo, ServerName, AsyncCallback.StringCallback, Object) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKAssign
-
Creates an unassigned node in the OFFLINE state for the specified region.
- AsyncRpcChannel - Class in org.apache.hadoop.hbase.ipc
-
Netty RPC channel
- AsyncRpcChannel(Bootstrap, AsyncRpcClient, User, String, InetSocketAddress) - Constructor for class org.apache.hadoop.hbase.ipc.AsyncRpcChannel
-
Constructor for netty RPC channel
- AsyncRpcClient - Class in org.apache.hadoop.hbase.ipc
-
Netty client for the requests and responses
- AsyncRpcClient(Configuration, String, SocketAddress) - Constructor for class org.apache.hadoop.hbase.ipc.AsyncRpcClient
-
Constructor
- AsyncRpcClient.RpcChannelImplementation - Class in org.apache.hadoop.hbase.ipc
-
Blocking rpc channel that goes via hbase rpc.
- AsyncServerResponseHandler - Class in org.apache.hadoop.hbase.ipc
-
Handles Hbase responses
- AsyncServerResponseHandler(AsyncRpcChannel) - Constructor for class org.apache.hadoop.hbase.ipc.AsyncServerResponseHandler
-
Constructor
- atLeast(WALKey.Version) - Method in enum org.apache.hadoop.hbase.wal.WALKey.Version
-
- ATOMIC_BOOLEAN - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for AtomicBoolean
- ATOMIC_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.RegionAction
-
- ATOMIC_INTEGER - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for AtomicInteger
- ATOMIC_LONG - Static variable in class org.apache.hadoop.hbase.util.ClassSize
-
Overhead for AtomicLong
- AtomicGetReader(MultithreadedTestUtil.TestContext, byte[], byte[][]) - Constructor for class org.apache.hadoop.hbase.TestAcidGuarantees.AtomicGetReader
-
- AtomicHFileLoader(TableName, MultithreadedTestUtil.TestContext, byte[][]) - Constructor for class org.apache.hadoop.hbase.regionserver.TestHRegionServerBulkLoad.AtomicHFileLoader
-
- atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long, <any>) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient
-
- atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long, <any>) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncIface
-
- atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Method in class org.apache.hadoop.hbase.thrift.generated.Hbase.Client
-
- atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Method in interface org.apache.hadoop.hbase.thrift.generated.Hbase.Iface
-
Atomically increment the column value specified.
- atomicIncrement() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.Processor.atomicIncrement
-
- atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
Deprecated.
- atomicIncrement(ByteBuffer, ByteBuffer, byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.ThriftServerRunner.HBaseHandler
-
- atomicIncrement_args() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- atomicIncrement_args(ByteBuffer, ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
- atomicIncrement_args(Hbase.atomicIncrement_args) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_args
-
Performs a deep copy on other.
- atomicIncrement_call(ByteBuffer, ByteBuffer, ByteBuffer, long, <any>, org.apache.thrift.async.TAsyncClient, org.apache.thrift.protocol.TProtocolFactory, org.apache.thrift.transport.TNonblockingTransport) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.AsyncClient.atomicIncrement_call
-
- atomicIncrement_result() - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- atomicIncrement_result(long, IOError, IllegalArgument) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
- atomicIncrement_result(Hbase.atomicIncrement_result) - Constructor for class org.apache.hadoop.hbase.thrift.generated.Hbase.atomicIncrement_result
-
Performs a deep copy on other.
- AtomicityWriter(MultithreadedTestUtil.TestContext, byte[][], byte[][]) - Constructor for class org.apache.hadoop.hbase.TestAcidGuarantees.AtomicityWriter
-
- AtomicOperation(Region, int, AtomicLong, AtomicInteger) - Constructor for class org.apache.hadoop.hbase.regionserver.TestAtomicOperation.AtomicOperation
-
- AtomicScanReader(TableName, MultithreadedTestUtil.TestContext, byte[][]) - Constructor for class org.apache.hadoop.hbase.regionserver.TestHRegionServerBulkLoad.AtomicScanReader
-
- AtomicScanReader(MultithreadedTestUtil.TestContext, byte[][]) - Constructor for class org.apache.hadoop.hbase.TestAcidGuarantees.AtomicScanReader
-
- attemptingUser - Variable in class org.apache.hadoop.hbase.ipc.RpcServer.Connection
-
- attemptToOwnTask(boolean, ZooKeeperWatcher, ServerName, String, ZooKeeperProtos.SplitLogTask.RecoveryMode, int) - Static method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
-
Try to own the task by transitioning the zk node data from UNASSIGNED to OWNED.
- ATTRIBUTE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Get
-
- ATTRIBUTE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.MutationProto
-
- ATTRIBUTE_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.ClientProtos.Scan
-
- ATTRIBUTE_SEPERATOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
-
- Attributes - Interface in org.apache.hadoop.hbase.client
-
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.checkAndPut_args
-
Mutation attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAll_args
-
Delete attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRow_args
-
Delete attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllRowTs_args
-
Delete attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.deleteAllTs_args
-
Delete attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.get_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRow_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRows_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsTs_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumns_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowsWithColumnsTs_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowTs_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumns_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getRowWithColumnsTs_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVer_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.getVerTs_args
-
Get attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRow_args
-
Mutation attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRows_args
-
Mutation attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowsTs_args
-
Mutation attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.mutateRowTs_args
-
Mutation attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpen_args
-
Scan attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenTs_args
-
Scan attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithPrefix_args
-
Scan attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithScan_args
-
Scan attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStop_args
-
Scan attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift.generated.Hbase.scannerOpenWithStopTs_args
-
Scan attributes
- attributes - Variable in class org.apache.hadoop.hbase.thrift2.generated.TAppend
-
- attributes - Variable in class org.apache.hadoop.hbase.thrift2.generated.TDelete
-
- attributes - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- attributes - Variable in class org.apache.hadoop.hbase.thrift2.generated.TIncrement
-
- attributes - Variable in class org.apache.hadoop.hbase.thrift2.generated.TPut
-
- attributes - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- ATTRIBUTES_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
-
- ATTRIBUTES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.ColumnFamilySchema
-
- ATTRIBUTES_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.TableSchema
-
- ATTRS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.ColumnSchemaMessage.ColumnSchema
-
- ATTRS_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.TableSchemaMessage.TableSchema
-
- AUTH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.GetAuthsResponse
-
- AUTH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.SetAuthsRequest
-
- AUTH_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.VisibilityLabelsProtos.UserAuthorizations
-
- AUTH_METHOD_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.WhoAmIResponse
-
- AUTH_TOKEN_TYPE - Static variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- AUTHENTICATION_FAILURES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- AUTHENTICATION_FAILURES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- AUTHENTICATION_SUCCESSES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- AUTHENTICATION_SUCCESSES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- authenticationFailure() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- authenticationFailure() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- AuthenticationKey - Class in org.apache.hadoop.hbase.security.token
-
- AuthenticationKey() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- AuthenticationKey(int, long, SecretKey) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationKey
-
- authenticationMethod - Variable in enum org.apache.hadoop.hbase.security.AuthMethod
-
- AuthenticationProtos - Class in org.apache.hadoop.hbase.protobuf.generated
-
- AuthenticationProtos.AuthenticationKey - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type AuthenticationKey
- AuthenticationProtos.AuthenticationKey.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type AuthenticationKey
- AuthenticationProtos.AuthenticationKeyOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AuthenticationProtos.AuthenticationService - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf service AuthenticationService
- AuthenticationProtos.AuthenticationService.BlockingInterface - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AuthenticationProtos.AuthenticationService.Interface - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AuthenticationProtos.AuthenticationService.Stub - Class in org.apache.hadoop.hbase.protobuf.generated
-
- AuthenticationProtos.GetAuthenticationTokenRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetAuthenticationTokenRequest
- AuthenticationProtos.GetAuthenticationTokenRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetAuthenticationTokenRequest
- AuthenticationProtos.GetAuthenticationTokenRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AuthenticationProtos.GetAuthenticationTokenResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetAuthenticationTokenResponse
- AuthenticationProtos.GetAuthenticationTokenResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type GetAuthenticationTokenResponse
- AuthenticationProtos.GetAuthenticationTokenResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AuthenticationProtos.Token - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Token
- AuthenticationProtos.Token.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type Token
- AuthenticationProtos.TokenIdentifier - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type TokenIdentifier
- AuthenticationProtos.TokenIdentifier.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type TokenIdentifier
- AuthenticationProtos.TokenIdentifier.Kind - Enum in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf enum TokenIdentifier.Kind
- AuthenticationProtos.TokenIdentifierOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AuthenticationProtos.TokenOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AuthenticationProtos.WhoAmIRequest - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type WhoAmIRequest
- AuthenticationProtos.WhoAmIRequest.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type WhoAmIRequest
- AuthenticationProtos.WhoAmIRequestOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AuthenticationProtos.WhoAmIResponse - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type WhoAmIResponse
- AuthenticationProtos.WhoAmIResponse.Builder - Class in org.apache.hadoop.hbase.protobuf.generated
-
Protobuf type WhoAmIResponse
- AuthenticationProtos.WhoAmIResponseOrBuilder - Interface in org.apache.hadoop.hbase.protobuf.generated
-
- AuthenticationService() - Constructor for class org.apache.hadoop.hbase.protobuf.generated.AuthenticationProtos.AuthenticationService
-
- authenticationSuccess() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- authenticationSuccess() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- AuthenticationTokenIdentifier - Class in org.apache.hadoop.hbase.security.token
-
Represents the identity information stored in an HBase authentication token.
- AuthenticationTokenIdentifier() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- AuthenticationTokenIdentifier(String) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- AuthenticationTokenIdentifier(String, int, long, long) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
-
- AuthenticationTokenSecretManager - Class in org.apache.hadoop.hbase.security.token
-
Manages an internal list of secret keys used to sign new authentication
tokens as they are generated, and to valid existing tokens used for
authentication.
- AuthenticationTokenSecretManager(Configuration, ZooKeeperWatcher, String, long, long) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
-
Create a new secret manager instance for generating keys.
- AuthenticationTokenSelector - Class in org.apache.hadoop.hbase.security.token
-
- AuthenticationTokenSelector() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector
-
- AuthFilter - Class in org.apache.hadoop.hbase.rest.filter
-
- AuthFilter() - Constructor for class org.apache.hadoop.hbase.rest.filter.AuthFilter
-
- authManager - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- AuthMethod - Enum in org.apache.hadoop.hbase.security
-
Authentication method
- AUTHORIZATION - Static variable in class org.apache.hadoop.hbase.thrift.ThriftHttpServlet
-
- AUTHORIZATION_FAILURES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- AUTHORIZATION_FAILURES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- AUTHORIZATION_SUCCESSES_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- AUTHORIZATION_SUCCESSES_NAME - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- authorizationFailure() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- authorizationFailure() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- Authorizations - Class in org.apache.hadoop.hbase.security.visibility
-
This class contains visibility labels associated with a Scan/Get deciding which all labeled data
current scan/get can access.
- Authorizations(String...) - Constructor for class org.apache.hadoop.hbase.security.visibility.Authorizations
-
- Authorizations(List<String>) - Constructor for class org.apache.hadoop.hbase.security.visibility.Authorizations
-
- authorizations - Variable in class org.apache.hadoop.hbase.thrift2.generated.TGet
-
- authorizations - Variable in class org.apache.hadoop.hbase.thrift2.generated.TScan
-
- authorizationSuccess() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
-
- authorizationSuccess() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
-
- authorize(UserGroupInformation, RPCProtos.ConnectionHeader, InetAddress) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
-
Authorize the incoming client connection.
- authorize(User, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Authorize a global permission based on ACLs for the given user and the
user's groups.
- authorize(User, TableName, Cell, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Authorize a user for a given KV.
- authorize(User, String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- authorize(User, TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- authorize(User, TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- authorizeGroup(String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Checks global authorization for a given action for a group, based on the stored
permissions.
- authorizeGroup(String, TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Checks authorization to a given table, column family and column for a group, based
on the stored permissions.
- authorizeUser(User, TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
Checks authorization to a given table and column family for a user, based on the
stored user permissions.
- authorizeUser(User, TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.TableAuthManager
-
- AuthResult - Class in org.apache.hadoop.hbase.security.access
-
Represents the result of an authorization check for logging and error
reporting.
- AuthResult(boolean, String, String, User, Permission.Action, TableName, byte[], byte[]) - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult
-
- AuthResult(boolean, String, String, User, Permission.Action, TableName, Map<byte[], ? extends Collection<?>>) - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult
-
- AuthResult(boolean, String, String, User, Permission.Action, String) - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult
-
- AuthResult.Params - Class in org.apache.hadoop.hbase.security.access
-
- authTokenSecretMgr - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
-
- AuthUtil - Class in org.apache.hadoop.hbase
-
Utility methods for helping with security tasks.
- available() - Method in class org.apache.hadoop.hbase.io.ByteBufferInputStream
-
- available() - Method in class org.apache.hadoop.hbase.io.LimitInputStream
-
- AVERAGE_LOAD_DESC - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- AVERAGE_LOAD_NAME - Static variable in interface org.apache.hadoop.hbase.master.MetricsMasterSource
-
- AverageIntervalRateLimiter - Class in org.apache.hadoop.hbase.quotas
-
This limiter will refill resources at every TimeUnit/resources interval.
- AverageIntervalRateLimiter() - Constructor for class org.apache.hadoop.hbase.quotas.AverageIntervalRateLimiter
-
- AVERAGELOAD_FIELD_NUMBER - Static variable in class org.apache.hadoop.hbase.rest.protobuf.generated.StorageClusterStatusMessage.StorageClusterStatus
-
- avg(TableName, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
This is the client side interface/handle for calling the average method for
a given cf-cq combination.
- avg(Table, ColumnInterpreter<R, S, P, Q, T>, Scan) - Method in class org.apache.hadoop.hbase.client.coprocessor.AggregationClient
-
This is the client side interface/handle for calling the average method for
a given cf-cq combination.
- avgKeyLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Average key length read from file info
- AvgOperationSize() - Constructor for class org.apache.hadoop.hbase.quotas.OperationQuota.AvgOperationSize
-
- avgValueLen - Variable in class org.apache.hadoop.hbase.io.hfile.AbstractHFileReader
-
Average value length read from file info
- await() - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
-
- await() - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch.CompatibilityLatch
-