Index

A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

a - Variable in class org.apache.hadoop.hbase.util.ClassSize.UnsafeLayout.HeaderSize
 
A - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for 'A'
aarch64 - Static variable in class org.apache.hadoop.hbase.util.JVM
 
ABNORMALLY_CLOSED - Enum constant in enum org.apache.hadoop.hbase.master.RegionState.State
 
abort - Variable in class org.apache.hadoop.hbase.client.locking.EntityLock
 
abort - Variable in class org.apache.hadoop.hbase.regionserver.handler.CloseRegionHandler
 
abort - Variable in class org.apache.hadoop.hbase.regionserver.handler.UnassignRegionHandler
 
abort() - Method in class org.apache.hadoop.hbase.procedure2.RootProcedureState
 
abort() - Method in class org.apache.hadoop.hbase.regionserver.HStore.StoreFlusherImpl
Abort the snapshot preparation.
abort() - Method in interface org.apache.hadoop.hbase.regionserver.StoreFlushContext
Abort the snapshot preparation.
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 to the specified procedure.
abort(String) - Method in interface org.apache.hadoop.hbase.Abortable
It just calls another abort method and the Throwable parameter is null.
abort(String) - Method in interface org.apache.hadoop.hbase.monitoring.MonitoredTask
 
abort(String) - Method in class org.apache.hadoop.hbase.monitoring.MonitoredTaskImpl
 
abort(String) - Method in class org.apache.hadoop.hbase.monitoring.TaskGroup
 
abort(String) - Method in class org.apache.hadoop.hbase.procedure.ZKProcedureCoordinator
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(String, Throwable) - Method in interface org.apache.hadoop.hbase.Abortable
Abort the server or client.
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.backup.BackupHFileCleaner
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.backup.regionserver.LogRollBackupSubprocedurePool
 
abort(String, Throwable) - Method in interface org.apache.hadoop.hbase.client.Admin
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.master.HMaster
 
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, Throwable) - Method in class org.apache.hadoop.hbase.replication.HBaseReplicationEndpoint
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.regionserver.DumpReplicationQueues.WarnOnlyAbortable
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSyncUp.DummyServer
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.SharedConnection
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
 
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
 
abort(Thread, Throwable) - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MoveRegionProcedure
Deprecated.
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
Deprecated.
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.DeleteTableProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.FlushRegionProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.SnapshotRegionProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.SnapshotVerifyProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALRemoteProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.SwitchRpcThrottleRemoteProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueueRemoteProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.ClaimReplicationQueuesProcedure
 
abort(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.RefreshPeerProcedure
 
abort(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.FailedProcedure
 
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 it, if they want to be abortable.
abort(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureInMemoryChore
 
abort(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
 
ABORT_ON_ERROR_KEY - Static variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
ABORT_TIMEOUT - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
ABORT_TIMEOUT_TASK - Static variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
ABORT_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
abortable - Variable in class org.apache.hadoop.hbase.coprocessor.CoprocessorHost
 
abortable - Variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
abortable - Variable in class org.apache.hadoop.hbase.ipc.RpcHandler
 
abortable - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
 
abortable - Variable in class org.apache.hadoop.hbase.master.DrainingServerTracker
 
abortable - Variable in class org.apache.hadoop.hbase.master.MasterRegionServerList
 
abortable - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
 
abortable - Variable in class org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool
 
abortable - Variable in class org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedurePool
 
abortable - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
abortable - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
 
abortable - Variable in class org.apache.hadoop.hbase.replication.ReplicationEndpoint.Context
 
abortable - Variable in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
 
abortable - Variable in class org.apache.hadoop.hbase.wal.AbstractWALRoller
 
abortable - Variable in class org.apache.hadoop.hbase.wal.WALFactory
 
abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZKClusterId
 
abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZKNodeTracker
Used to abort if a fatal error occurs
abortable - Variable in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
 
Abortable - Interface in org.apache.hadoop.hbase
Interface to support the aborting of a given server or client.
abortAndThrowIOExceptionWhenFail(ReplicationSourceManager.ReplicationQueueOperation) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
 
abortCacheFlush(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
abortCacheFlush(byte[]) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting
 
abortCacheFlush(byte[]) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
 
abortCacheFlush(byte[]) - Method in interface org.apache.hadoop.hbase.wal.WAL
Abort a cache flush.
aborted - Variable in class org.apache.hadoop.hbase.backup.BackupHFileCleaner
 
aborted - Variable in class org.apache.hadoop.hbase.backup.regionserver.LogRollBackupSubprocedurePool
 
aborted - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
 
aborted - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin
 
aborted - Variable in class org.apache.hadoop.hbase.client.HBaseHbck
 
aborted - Variable in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
Deprecated.
 
aborted - Variable in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
 
aborted - Variable in class org.apache.hadoop.hbase.zookeeper.ZKWatcher
 
ABORTED - Enum constant in enum org.apache.hadoop.hbase.monitoring.MonitoredTask.State
 
ABORTED - Enum constant in enum org.apache.hadoop.hbase.ServerTask.State
 
abortMonitor - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
abortOnError - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
abortOperationsInQueue() - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.BufferNode
 
abortPendingOperations(ServerName, Set<RemoteProcedureDispatcher.RemoteProcedure>) - Method in class org.apache.hadoop.hbase.master.procedure.RSProcedureDispatcher
 
abortPendingOperations(TRemote, Set<RemoteProcedureDispatcher.RemoteProcedure>) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
 
abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.1.1 and will be removed in 4.0.0.
abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Deprecated.
since 2.1.1 and will be removed in 4.0.0.
abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
 
abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
 
abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
abortProcedure(long, boolean) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Abort a procedure.
abortProcedure(long, boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
 
abortProcedure(String, ForeignException) - Method in class org.apache.hadoop.hbase.procedure.ProcedureCoordinator
Abort the procedure with the given name
abortProcedure(RpcController, MasterProtos.AbortProcedureRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
abortProcedure(RpcController, MasterProtos.AbortProcedureRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
abortProcedureAsync(long, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
since 2.1.1 and will be removed in 4.0.0.
abortProcedureAsync(long, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
abortProcedureAsync(long, boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
 
AbortProcedureFuture(HBaseAdmin, Long, Boolean) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.AbortProcedureFuture
 
abortProcedureResult(MasterProtos.AbortProcedureRequest) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
abortProcess() - Method in interface org.apache.hadoop.hbase.procedure2.store.ProcedureStore.ProcedureStoreListener
triggered when the store is not able to write out data.
abortRequested - Variable in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
abortServer(E, 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
 
abortWhenFail(ReplicationSourceManager.ReplicationQueueOperation) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
 
abortWriter(AbstractMultiFileWriter) - Method in class org.apache.hadoop.hbase.regionserver.compactions.AbstractMultiOutputCompactor
 
abortWriter(StoreFileWriter) - Method in class org.apache.hadoop.hbase.regionserver.compactions.DefaultCompactor
 
abortWriter(T) - Method in class org.apache.hadoop.hbase.regionserver.compactions.Compactor
 
abortWriters() - Method in class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
Close all writers without throwing any exceptions.
abortZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
ABOVE_HEAP_LOW_WATERMARK_COUNTER_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
ABOVE_HEAP_LOW_WATERMARK_COUNTER_NAME - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSource
 
ABOVE_OFFHEAP_HIGHER_MARK - Enum constant in enum org.apache.hadoop.hbase.regionserver.FlushType
 
ABOVE_OFFHEAP_LOWER_MARK - Enum constant in enum org.apache.hadoop.hbase.regionserver.FlushType
 
ABOVE_ONHEAP_HIGHER_MARK - Enum constant in enum org.apache.hadoop.hbase.regionserver.FlushType
 
ABOVE_ONHEAP_LOWER_MARK - Enum constant in enum org.apache.hadoop.hbase.regionserver.FlushType
 
aboveHeapOccupancyLowWatermarkCounter - Variable in class org.apache.hadoop.hbase.regionserver.MetricsHeapMemoryManagerSourceImpl
 
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
 
AbstractDataBlockEncoder - Class in org.apache.hadoop.hbase.io.encoding
 
AbstractDataBlockEncoder() - Constructor for class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder
 
AbstractDataBlockEncoder.AbstractEncodedSeeker - Class in org.apache.hadoop.hbase.io.encoding
Decorates EncodedSeeker with a HFileBlockDecodingContext
AbstractEncodedSeeker(HFileBlockDecodingContext) - Constructor for class org.apache.hadoop.hbase.io.encoding.AbstractDataBlockEncoder.AbstractEncodedSeeker
 
AbstractFileStatusFilter - Class in org.apache.hadoop.hbase.util
Typical base class for file status filter.
AbstractFileStatusFilter() - Constructor for class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
 
AbstractFSWAL<W extends WALProvider.WriterBase> - Class in org.apache.hadoop.hbase.regionserver.wal
Implementation of WAL to go against FileSystem; i.e.
AbstractFSWAL(FileSystem, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
AbstractFSWAL(FileSystem, Abortable, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
AbstractFSWAL.WALProps - Class in org.apache.hadoop.hbase.regionserver.wal
 
AbstractFSWALProvider<T extends AbstractFSWAL<?>> - Class in org.apache.hadoop.hbase.wal
Base class of a WAL Provider that returns a single thread safe WAL that writes to Hadoop FS.
AbstractFSWALProvider() - Constructor for class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
 
AbstractFSWALProvider.Initializer - Interface in org.apache.hadoop.hbase.wal
 
AbstractFSWALProvider.WALStartTimeComparator - Class in org.apache.hadoop.hbase.wal
Comparator used to compare WAL files together based on their start time.
AbstractHBaseSaslRpcClient - Class in org.apache.hadoop.hbase.security
A utility class that encapsulates SASL logic for RPC client.
AbstractHBaseSaslRpcClient(Configuration, SaslClientAuthenticationProvider, Token<? extends TokenIdentifier>, InetAddress, String, boolean) - Constructor for class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
Create a HBaseSaslRpcClient for an authentication method
AbstractHBaseSaslRpcClient(Configuration, SaslClientAuthenticationProvider, Token<? extends TokenIdentifier>, InetAddress, String, boolean, String) - Constructor for class org.apache.hadoop.hbase.security.AbstractHBaseSaslRpcClient
Create a HBaseSaslRpcClient for an authentication method
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
 
AbstractHBaseTool.OptionsOrderComparator - Class in org.apache.hadoop.hbase.util
 
AbstractMemStore - Class in org.apache.hadoop.hbase.regionserver
An abstract class, which implements the behaviour shared by all concrete memstore instances.
AbstractMemStore(Configuration, CellComparator, RegionServicesForStores) - Constructor for class org.apache.hadoop.hbase.regionserver.AbstractMemStore
 
AbstractMultiFileWriter - Class in org.apache.hadoop.hbase.regionserver
Base class for cell sink that separates the provided cells into multiple files.
AbstractMultiFileWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.AbstractMultiFileWriter
 
AbstractMultiFileWriter.WriterFactory - Interface in org.apache.hadoop.hbase.regionserver
 
AbstractMultiOutputCompactor<T extends AbstractMultiFileWriter> - Class in org.apache.hadoop.hbase.regionserver.compactions
Base class for implementing a Compactor which will generate multiple output files after compaction.
AbstractMultiOutputCompactor(Configuration, HStore) - Constructor for class org.apache.hadoop.hbase.regionserver.compactions.AbstractMultiOutputCompactor
 
AbstractPeerProcedure<TState> - Class in org.apache.hadoop.hbase.master.replication
The base class for all replication peer related procedure.
AbstractPeerProcedure() - Constructor for class org.apache.hadoop.hbase.master.replication.AbstractPeerProcedure
 
AbstractPeerProcedure(String) - Constructor for class org.apache.hadoop.hbase.master.replication.AbstractPeerProcedure
 
AbstractPositionedByteRange - Class in org.apache.hadoop.hbase.util
Extends the basic SimpleByteRange implementation with position support.
AbstractPositionedByteRange() - Constructor for class org.apache.hadoop.hbase.util.AbstractPositionedByteRange
 
AbstractProcedureScheduler - Class in org.apache.hadoop.hbase.procedure2
 
AbstractProcedureScheduler() - Constructor for class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
 
AbstractProtobufLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
Base class for Protobuf log writer.
AbstractProtobufLogWriter() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufLogWriter
 
AbstractProtobufWALReader - Class in org.apache.hadoop.hbase.regionserver.wal
Base class for reading protobuf based wal reader
AbstractProtobufWALReader() - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AbstractProtobufWALReader
 
AbstractRecoveredEditsOutputSink - Class in org.apache.hadoop.hbase.wal
 
AbstractRecoveredEditsOutputSink(WALSplitter, WALSplitter.PipelineController, EntryBuffers, int) - Constructor for class org.apache.hadoop.hbase.wal.AbstractRecoveredEditsOutputSink
 
AbstractRecoveredEditsOutputSink.RecoveredEditsWriter - Class in org.apache.hadoop.hbase.wal
Private data structure that wraps a WALProvider.Writer and its Path, also collecting statistics about the data written to this output.
AbstractResponse - Class in org.apache.hadoop.hbase.client
This class is used to extend AP to process single action request, like delete, get etc.
AbstractResponse() - Constructor for class org.apache.hadoop.hbase.client.AbstractResponse
 
AbstractResponse.ResponseType - Enum in org.apache.hadoop.hbase.client
 
AbstractRpcBasedConnectionRegistry - Class in org.apache.hadoop.hbase.client
Base class for rpc based connection registry implementation.
AbstractRpcBasedConnectionRegistry(Configuration, User, String, String, String, String) - Constructor for class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
 
AbstractRpcBasedConnectionRegistry.Callable<T> - Interface in org.apache.hadoop.hbase.client
For describing the actual asynchronous rpc call.
AbstractRpcChannel(AbstractRpcClient<?>, Address, User, int) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient.AbstractRpcChannel
 
AbstractRpcClient<T extends RpcConnection> - Class in org.apache.hadoop.hbase.ipc
Provides the basics for a RpcClient implementation like configuration and Logging.
AbstractRpcClient(Configuration, String, SocketAddress, MetricsConnection, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.ipc.AbstractRpcClient
Construct an IPC client for the cluster clusterId
AbstractRpcClient.AbstractRpcChannel - Class in org.apache.hadoop.hbase.ipc
 
AbstractRpcClient.BlockingRpcChannelImplementation - Class in org.apache.hadoop.hbase.ipc
Blocking rpc channel that goes via hbase rpc.
AbstractRpcClient.RpcChannelImplementation - Class in org.apache.hadoop.hbase.ipc
Async rpc channel that goes via hbase rpc.
AbstractSaslClientAuthenticationProvider - Class in org.apache.hadoop.hbase.security.provider
Base implementation of SaslClientAuthenticationProvider.
AbstractSaslClientAuthenticationProvider() - Constructor for class org.apache.hadoop.hbase.security.provider.AbstractSaslClientAuthenticationProvider
 
AbstractScreenView - Class in org.apache.hadoop.hbase.hbtop.screen
An abstract class for ScreenView that has the common useful methods and the default implementations for the abstract methods.
AbstractScreenView(Screen, Terminal) - Constructor for class org.apache.hadoop.hbase.hbtop.screen.AbstractScreenView
 
AbstractStateMachineNamespaceProcedure<TState> - Class in org.apache.hadoop.hbase.master.procedure
Base class for all the Namespace procedures that want to use a StateMachineProcedure.
AbstractStateMachineNamespaceProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineNamespaceProcedure
 
AbstractStateMachineNamespaceProcedure(MasterProcedureEnv) - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineNamespaceProcedure
 
AbstractStateMachineNamespaceProcedure(MasterProcedureEnv, ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineNamespaceProcedure
 
AbstractStateMachineRegionProcedure<TState> - Class in org.apache.hadoop.hbase.master.procedure
Base class for all the Region procedures that want to use a StateMachine.
AbstractStateMachineRegionProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineRegionProcedure
 
AbstractStateMachineRegionProcedure(MasterProcedureEnv, RegionInfo) - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineRegionProcedure
 
AbstractStateMachineRegionProcedure(MasterProcedureEnv, RegionInfo, ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineRegionProcedure
 
AbstractStateMachineTableProcedure<TState> - Class in org.apache.hadoop.hbase.master.procedure
Base class for all the Table procedures that want to use a StateMachineProcedure.
AbstractStateMachineTableProcedure() - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
 
AbstractStateMachineTableProcedure(MasterProcedureEnv) - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
 
AbstractStateMachineTableProcedure(MasterProcedureEnv, ProcedurePrepareLatch) - Constructor for class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
 
AbstractViolationPolicyEnforcement - Class in org.apache.hadoop.hbase.quotas.policies
Abstract implementation for SpaceViolationPolicyEnforcement.
AbstractViolationPolicyEnforcement() - Constructor for class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
 
AbstractWALRoller<T extends Abortable> - Class in org.apache.hadoop.hbase.wal
Runs periodically to determine if the WAL should be rolled.
AbstractWALRoller(String, Configuration, T) - Constructor for class org.apache.hadoop.hbase.wal.AbstractWALRoller
 
AbstractWALRoller.RollController - Class in org.apache.hadoop.hbase.wal
Independently control the roll of each wal.
accept(AttributesBuilder) - Method in class org.apache.hadoop.hbase.io.hfile.trace.HFileContextAttributesBuilderConsumer
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.CellSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.KeyValueSerialization
Deprecated.
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.MutationSerialization
 
accept(Class<?>) - Method in class org.apache.hadoop.hbase.mapreduce.ResultSerialization
 
accept(Void, Throwable) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.ProcedureBiConsumer
 
accept(FileStatus) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
 
accept(FileStatus) - Method in interface org.apache.hadoop.hbase.util.FileStatusFilter
Tests whether or not the specified filestatus should be included in a filestatus list.
accept(Path) - Method in class org.apache.hadoop.hbase.backup.impl.IncrementalBackupManager.NewestLogFilter
 
accept(Path) - Method in class org.apache.hadoop.hbase.regionserver.HStore.StoreFileWriterCreationTracker
 
accept(Path) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
 
accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.HFileLinkFilter
 
accept(Path) - Method in class org.apache.hadoop.hbase.util.FSUtils.ReferenceAndLinkFileFilter
 
accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.AbstractFileStatusFilter
Filters out a path.
accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.BlackListDirFilter
 
accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.FamilyDirFilter
 
accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.FileFilter
 
accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.HFileFilter
 
accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.ReferenceFileFilter
 
accept(Path, Boolean) - Method in class org.apache.hadoop.hbase.util.FSUtils.RegionDirFilter
 
accept(Field, List<Field>, EnumMap<Field, Boolean>) - Method in interface org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter.ResultListener
 
ACCEPT_FACTOR_CONFIG_NAME - Static variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
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
acceptableFactor - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
Acceptable size of cache (no evictions if size < acceptable)
acceptableFactor - Variable in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
Acceptable size of cache (no evictions if size < acceptable)
acceptableFactor - Variable in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Acceptable size of cache (no evictions if size < acceptable)
acceptableSize() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
acceptableSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
 
acceptableSize() - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
 
acceptChannel - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener
Deprecated.
 
acceptInboundMessage(Object) - Method in class org.apache.hadoop.hbase.client.ClusterStatusListener.MulticastListener.ClusterStatusHandler
 
acceptPlan(HashMap<RegionInfo, RegionStateNode>, Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
access(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMQueueEntry
 
access(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
Block has been accessed.
access(long) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
Block has been accessed.
access(long) - Method in class org.apache.hadoop.hbase.mob.CachedMobFile
 
access(FileChannel, ByteBuff, long) - Method in interface org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine.FileAccessor
 
access(FileChannel, ByteBuff, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine.FileReadAccessor
 
access(FileChannel, ByteBuff, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine.FileWriteAccessor
 
ACCESS - Enum constant in enum org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation.AclType
 
ACCESS_CONTROL_ALLOW_METHODS - Static variable in class org.apache.hadoop.hbase.http.ProfileServlet
 
ACCESS_CONTROL_ALLOW_ORIGIN - Static variable in class org.apache.hadoop.hbase.http.ProfileServlet
 
accessAclEntries - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation
 
accessChecker - Variable in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
accessChecker - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
accessChecker - Variable in class org.apache.hadoop.hbase.security.access.AccessController
 
AccessChecker - Class in org.apache.hadoop.hbase.security.access
 
AccessChecker(Configuration) - Constructor for class org.apache.hadoop.hbase.security.access.AccessChecker
Constructor with existing configuration
AccessChecker.InputUser - Class in org.apache.hadoop.hbase.security.access
A temporary user class to instantiate User instance based on the name and groups.
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
 
AccessControlFilter - Class in org.apache.hadoop.hbase.security.access
NOTE: for internal use only by AccessController implementation
AccessControlFilter() - Constructor for class org.apache.hadoop.hbase.security.access.AccessControlFilter
For Writable
AccessControlFilter(AuthManager, User, TableName, AccessControlFilter.Strategy, Map<ByteRange, Integer>) - Constructor for class org.apache.hadoop.hbase.security.access.AccessControlFilter
 
AccessControlFilter.Strategy - Enum 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
 
AccessController.OpType - Enum in org.apache.hadoop.hbase.security.access
 
accessControllerAvailable - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
AccessControlUtil - Class in org.apache.hadoop.hbase.security.access
 
AccessControlUtil() - Constructor for class org.apache.hadoop.hbase.security.access.AccessControlUtil
 
accessCount - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
Cache access count (sequential ID)
accessCount - Variable in class org.apache.hadoop.hbase.mob.CachedMobFile
 
accessCounter - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.RAMQueueEntry
 
accessCounter - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
 
accessDeniedClazz - Variable in class org.apache.hadoop.hbase.rest.ResourceBase
 
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
 
accessFile(FileIOEngine.FileAccessor, ByteBuff, long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.FileIOEngine
 
accessTime - Variable in class org.apache.hadoop.hbase.io.hfile.LruCachedBlock
 
accessUserTable(User, TableName, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
Checks if the user has access to the full table or at least a family/qualifier for the specified action.
ack - Variable in class org.apache.hadoop.hbase.util.RegionMover
 
ack - Variable in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
 
ack(boolean) - Method in class org.apache.hadoop.hbase.util.RegionMover.RegionMoverBuilder
Set ack/noAck mode.
ackedBlockLength - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
 
ackedLength - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput.Callback
 
AckHandler(int) - Constructor for class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput.AckHandler
 
ACL_GLOBAL_NAME - Static variable in class org.apache.hadoop.hbase.security.access.PermissionStorage
 
ACL_KEY_DELIMITER - Static variable in class org.apache.hadoop.hbase.security.access.PermissionStorage
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.PermissionStorage
 
ACL_LIST_FAMILY_STR - Static variable in class org.apache.hadoop.hbase.security.access.PermissionStorage
Column family used to store ACL grants
ACL_NODE - Static variable in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
 
ACL_SYNC_TO_HDFS_ENABLE - Static variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
 
ACL_SYNC_TO_HDFS_THREAD_NUMBER - Static variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
 
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.PermissionStorage
Internal storage table for access control lists
ACL_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.security.access.PermissionStorage
KV tag to store per cell access control lists
ACL_TAG_TYPE - Static variable in class org.apache.hadoop.hbase.TagType
 
aclEntry(AclEntryScope, String) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
 
aclRegion - Variable in class org.apache.hadoop.hbase.security.access.AccessController
flags if we are running on a region of the _acl_ table
aclTabAvailable - Variable in class org.apache.hadoop.hbase.security.access.AccessController
if the ACL table is available, only relevant in the master
aclTableInitialized - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController
 
aclType - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation
 
AclType() - Constructor for enum org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation.AclType
 
aclZNode - Variable in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
 
acquire() - Method in class org.apache.hadoop.hbase.coprocessor.example.ZooKeeperScanPolicyObserver.ZKDataHolder
 
acquire() - Method in class org.apache.hadoop.hbase.master.WorkerAssigner
 
acquire(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.RootProcedureState
Called by the ProcedureExecutor to mark the procedure step as running.
acquireBarrier() - Method in class org.apache.hadoop.hbase.backup.regionserver.LogRollBackupSubprocedure
 
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.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
do nothing, core of snapshot is executed in FlushSnapshotSubprocedure.insideBarrier() step.
acquireBufferQuota(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
ACQUIRED_BARRIER_ZNODE_DEFAULT - Static variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
acquiredBarrierLatch - Variable in class org.apache.hadoop.hbase.procedure.Procedure
latch for waiting until all members have acquire in barrier state
acquireDelegationToken(String, FileSystem) - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
Acquire the delegation token for the specified filesystem and token kind.
acquireDelegationToken(FileSystem) - Method in class org.apache.hadoop.hbase.security.token.FsDelegationToken
Acquire the delegation token for the specified filesystem.
acquiredZnode - Variable in class org.apache.hadoop.hbase.procedure.ZKProcedureUtil
 
acquireLock(K) - Method in class org.apache.hadoop.hbase.util.KeyLocker
Return a lock for the given key.
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.GCMultipleMergedRegionsProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.MergeTableRegionsProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure
 
acquireLock(MasterProcedureEnv) - Method in interface org.apache.hadoop.hbase.master.locking.LockProcedure.LockInterface
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure.NamespaceExclusiveLock
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure.RegionExclusiveLock
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure.TableExclusiveLock
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.locking.LockProcedure.TableSharedLock
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineNamespaceProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineRegionProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.AbstractStateMachineTableProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CreateNamespaceProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.FlushTableProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.SnapshotProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.SnapshotRegionProcedure
 
acquireLock(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.replication.AbstractPeerProcedure
 
acquireLock(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
acquireLock(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
The user should override this method if they need a lock on an Entity.
acquireLocks(Set<? extends K>) - Method in class org.apache.hadoop.hbase.util.KeyLocker
Acquire locks for a set of keys.
acquireSlot() - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureStore
Deprecated.
 
acquireSnapshotVerifyWorker(SnapshotVerifyProcedure) - Method in class org.apache.hadoop.hbase.master.snapshot.SnapshotManager
 
acquireSplitWALWorker(Procedure<?>) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
Acquire a split WAL worker
acquireWALEntryBufferQuota(WALEntryBatch, WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Acquire the buffer quota for WAL.Entry which is added to WALEntryBatch.
acquiringMembers - Variable in class org.apache.hadoop.hbase.procedure.Procedure
 
act() - Method in interface org.apache.hadoop.hbase.master.cleaner.CleanerChore.Action
 
action - Variable in class org.apache.hadoop.hbase.client.Action
 
action - Variable in class org.apache.hadoop.hbase.client.CheckAndMutate
 
action - Variable in class org.apache.hadoop.hbase.ipc.BufferCallBeforeInitHandler.BufferCallEvent
 
action - Variable in class org.apache.hadoop.hbase.security.access.AuthResult
 
action(AsyncAdminRequestRetryingCaller.Callable<T>) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder
 
action(AsyncMasterRequestRpcRetryingCaller.Callable<T>) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder
 
action(AsyncServerRequestRpcRetryingCaller.Callable<T>) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder
 
action(AsyncSingleRequestRpcRetryingCaller.Callable<T>) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder
 
Action - Class in org.apache.hadoop.hbase.client
A Get, Put, Increment, Append, or Delete associated with it's region.
Action() - Constructor for enum org.apache.hadoop.hbase.regionserver.MemStoreCompactionStrategy.Action
 
Action(char) - Constructor for enum org.apache.hadoop.hbase.security.access.Permission.Action
 
Action(Action, int) - Constructor for class org.apache.hadoop.hbase.client.Action
Creates an action for a particular replica from original action.
Action(Row, int) - Constructor for class org.apache.hadoop.hbase.client.Action
 
Action(Row, int, int) - Constructor for class org.apache.hadoop.hbase.client.Action
 
ACTION_BY_CODE - Static variable in class org.apache.hadoop.hbase.security.access.Permission
 
action2Errors - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
 
action2Future - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
 
actions - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
 
actions - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller.RegionRequest
 
actions - Variable in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.BatchCallerBuilder
 
actions - Variable in class org.apache.hadoop.hbase.client.BatchErrors
 
actions - Variable in class org.apache.hadoop.hbase.client.DelayingRunner
 
actions - Variable in class org.apache.hadoop.hbase.client.MultiAction
A map of regions to lists of puts/gets/deletes for that region.
actions - Variable in exception org.apache.hadoop.hbase.client.RetriesExhaustedWithDetailsException
 
actions - Variable in class org.apache.hadoop.hbase.security.access.Permission
 
actions - Variable in class org.apache.hadoop.hbase.security.access.Permission.Builder
 
actions(List<? extends Row>) - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.BatchCallerBuilder
 
actionsByRegion - Variable in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller.ServerRequest
 
actionsInProgress - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
 
active - Variable in class org.apache.hadoop.hbase.coprocessor.MetaTableMetrics
 
active - Variable in class org.apache.hadoop.hbase.master.RegionServerTracker
 
active - Variable in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
 
ACTIVE - Enum constant in enum org.apache.hadoop.hbase.Coprocessor.State
 
ACTIVE - Enum constant in enum org.apache.hadoop.hbase.regionserver.wal.WALEventTrackerListener.WalState
 
ACTIVE_SCANNERS - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
ACTIVE_SCANNERS_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
ACTIVE_SESSION_COL - Static variable in class org.apache.hadoop.hbase.backup.impl.BackupSystemTable
 
ACTIVE_SESSION_NO - Static variable in class org.apache.hadoop.hbase.backup.impl.BackupSystemTable
 
ACTIVE_SESSION_ROW - Static variable in class org.apache.hadoop.hbase.backup.impl.BackupSystemTable
 
ACTIVE_SESSION_YES - Static variable in class org.apache.hadoop.hbase.backup.impl.BackupSystemTable
 
ACTIVE_WORKER_COUNT_KEY - Static variable in interface org.apache.hadoop.hbase.thrift.MetricsThriftServerSource
 
activeExecutorCount - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
 
activeFailoverTaskCount() - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
 
activeHandlerCount - Variable in class org.apache.hadoop.hbase.ipc.RpcExecutor
 
activeHandlerCount - Variable in class org.apache.hadoop.hbase.ipc.RpcHandler
 
activeMaster - Variable in class org.apache.hadoop.hbase.master.HMaster
 
activeMasterManager - Variable in class org.apache.hadoop.hbase.master.HMaster
 
ActiveMasterManager - Class in org.apache.hadoop.hbase.master
Handles everything on master-side related to master election.
ActiveMasterManager(ZKWatcher, ServerName, Server) - Constructor for class org.apache.hadoop.hbase.master.ActiveMasterManager
 
activeMasterServerName - Variable in class org.apache.hadoop.hbase.master.ActiveMasterManager
 
ActiveOperation() - Constructor for class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController.ActiveOperation
 
activeOperations - Variable in class org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
 
activePolicies - Variable in class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
 
ActivePolicyEnforcement - Class in org.apache.hadoop.hbase.quotas
A class to ease dealing with tables that have and do not have violation policies being enforced.
ActivePolicyEnforcement(Map<TableName, SpaceViolationPolicyEnforcement>, Map<TableName, SpaceQuotaSnapshot>, RegionServerServices) - Constructor for class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
 
ActivePolicyEnforcement(Map<TableName, SpaceViolationPolicyEnforcement>, Map<TableName, SpaceQuotaSnapshot>, RegionServerServices, SpaceViolationPolicyEnforcementFactory) - Constructor for class org.apache.hadoop.hbase.quotas.ActivePolicyEnforcement
 
activeProcedure - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.WorkerThread
 
activeReadHandlerCount - Variable in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
activeScanHandlerCount - Variable in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
activeTasks(SplitLogManager.TaskBatch) - Method in class org.apache.hadoop.hbase.master.SplitLogManager
Deprecated.
 
activeWorkerCountGauge - Variable in class org.apache.hadoop.hbase.thrift.MetricsThriftServerSourceImpl
 
activeWriteHandlerCount - Variable in class org.apache.hadoop.hbase.ipc.RWQueueRpcExecutor
 
activeZKServerIndex - Variable in class org.apache.hadoop.hbase.zookeeper.MiniZooKeeperCluster
 
actualErrorRate() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
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.BloomFilterUtil
Computes the actual error rate for the given number of elements, number of bits, and number of hash functions.
actualLocalitySummary - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
 
actualPeerId - Variable in class org.apache.hadoop.hbase.replication.regionserver.RecoveredReplicationSource
 
ADAPTIVE - Enum constant in enum org.apache.hadoop.hbase.MemoryCompactionPolicy
Adaptive compaction adapts to the workload.
ADAPTIVE_COMPACTION_THRESHOLD_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
 
ADAPTIVE_COMPACTION_THRESHOLD_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
 
ADAPTIVE_INITIAL_COMPACTION_PROBABILITY_DEFAULT - Static variable in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
 
ADAPTIVE_INITIAL_COMPACTION_PROBABILITY_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
 
ADAPTIVE_PROBABILITY_FACTOR - Static variable in class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
 
AdaptiveLifoCoDelCallQueue - Class in org.apache.hadoop.hbase.ipc
Adaptive LIFO blocking queue utilizing CoDel algorithm to prevent queue overloading.
AdaptiveLifoCoDelCallQueue(int, int, int, double, LongAdder, LongAdder) - Constructor for class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
AdaptiveMemStoreCompactionStrategy - Class in org.apache.hadoop.hbase.regionserver
Adaptive is a heuristic that chooses whether to apply data compaction or not based on the level of redundancy in the data.
AdaptiveMemStoreCompactionStrategy(Configuration, String) - Constructor for class org.apache.hadoop.hbase.regionserver.AdaptiveMemStoreCompactionStrategy
 
add(byte[][]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Concatenate byte arrays.
add(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Concatenate byte arrays.
add(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Append
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Append.addColumn(byte[], byte[], byte[]) instead
add(byte[], byte[], byte[]) - Static method in class org.apache.hadoop.hbase.util.Bytes
Concatenate byte arrays.
add(byte[], int, int) - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
 
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[], long, int) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
 
add(byte[], long, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunkImpl
The same as HFileBlockIndex.BlockIndexChunkImpl.add(byte[], long, int, long) but does not take the key/value into account.
add(byte[], long, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexReader
 
add(byte[], long, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.ByteArrayKeyBlockIndexReader
 
add(byte[], long, int) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.CellBasedKeyBlockIndexReader
Adds a new entry in the root block index.
add(byte[], long, int) - Method in class org.apache.hadoop.hbase.io.hfile.NoOpIndexBlockEncoder.NoOpEncodedSeeker
 
add(byte[], long, int, long) - Method in interface org.apache.hadoop.hbase.io.hfile.BlockIndexChunk
 
add(byte[], long, int, long) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlockIndex.BlockIndexChunkImpl
Adds a new entry to this block index chunk.
add(byte[], List<Action>) - Method in class org.apache.hadoop.hbase.client.MultiAction
Add an Action to this container based on it's regionName.
add(byte[], Action) - Method in class org.apache.hadoop.hbase.client.MultiAction
Add an Action to this container based on it's regionName.
add(int, E) - Method in class org.apache.hadoop.hbase.util.SortedList
 
add(long) - Method in class org.apache.hadoop.hbase.client.HTableMultiplexer.AtomicAverageCounter
Deprecated.
 
add(long) - Method in class org.apache.hadoop.hbase.util.Counter
Deprecated.
 
add(long) - Method in class org.apache.hadoop.hbase.util.Counter.Cell
Deprecated.
 
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(long, long) - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram
Adds a value to the histogram.
add(long, long) - Method in class org.apache.hadoop.hbase.metrics.impl.FastLongHistogram.Bins
Adds a value to the histogram.
add(E) - Method in class org.apache.hadoop.hbase.util.BoundedPriorityBlockingQueue.PriorityQueue
 
add(E) - Method in class org.apache.hadoop.hbase.util.SortedList
 
add(Double, Double) - Method in class org.apache.hadoop.hbase.client.coprocessor.DoubleColumnInterpreter
 
add(Iterable<Cell>, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
 
add(Iterable<Cell>, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Adds the specified value to the memstore
add(Iterable<Cell>, MemStoreSizing) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
Write the updates
add(Long, Long) - Method in class org.apache.hadoop.hbase.client.coprocessor.LongColumnInterpreter
 
add(Runnable) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
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(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(String, long) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
Add sample to a stat metric by name.
add(String, MutableMetric) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
 
add(Throwable, Row, ServerName) - Method in class org.apache.hadoop.hbase.client.BatchErrors
 
add(BigDecimal, BigDecimal) - Method in class org.apache.hadoop.hbase.client.coprocessor.BigDecimalColumnInterpreter
 
add(Collection<StoreFileInfo>) - Method in interface org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTracker
Add new store files.
add(Collection<StoreFileInfo>) - Method in class org.apache.hadoop.hbase.regionserver.storefiletracker.StoreFileTrackerBase
 
add(Iterator<T>) - Method in class org.apache.hadoop.hbase.util.ReservoirSample
 
add(List<? extends Mutation>) - Method in class org.apache.hadoop.hbase.client.RowMutations
Add a list of mutations
add(List<String>) - Method in class org.apache.hadoop.hbase.master.DrainingServerTracker
 
add(Map.Entry<byte[], List<Action>>) - Method in class org.apache.hadoop.hbase.client.DelayingRunner
 
add(Map.Entry<K, V>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntrySet
 
add(Map.Entry<BlockCacheKey, BucketEntry>) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache.BucketEntryGroup
 
add(Map.Entry<BlockCacheKey, BucketEntry>) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.CachedEntryQueue
Attempt to add the specified entry to this queue.
add(Map<byte[], List<Cell>>) - Method in class org.apache.hadoop.hbase.wal.WALEdit
Append the given map of family->edits to a WALEdit data structure.
add(Stream<T>) - Method in class org.apache.hadoop.hbase.util.ReservoirSample
 
add(K) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
 
add(Configuration) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
Add Hadoop Configuration object to config list.
add(Cell) - Method in class org.apache.hadoop.hbase.client.Append
Add column and value to this Append operation.
add(Cell) - Method in class org.apache.hadoop.hbase.client.Delete
Add an existing delete marker to this Delete object.
add(Cell) - Method in class org.apache.hadoop.hbase.client.Increment
Add the specified KeyValue to this operation.
add(Cell) - Method in class org.apache.hadoop.hbase.client.Mutation
 
add(Cell) - Method in class org.apache.hadoop.hbase.client.Put
Add the specified KeyValue to this Put operation.
add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapCollection
 
add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
 
add(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.querymatcher.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.querymatcher.NewVersionBehaviorTracker
 
add(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.ScanDeleteTracker
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.security.visibility.VisibilityNewVersionBehaivorTracker
 
add(Cell) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityScanDeleteTracker
 
add(Cell) - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
 
add(Cell) - Method in class org.apache.hadoop.hbase.wal.WALEdit
 
add(Cell, boolean, MemStoreSizing, boolean) - Method in class org.apache.hadoop.hbase.regionserver.MutableSegment
Adds the given cell into the segment
add(Cell, byte[]) - Method in class org.apache.hadoop.hbase.wal.WALEdit
 
add(Cell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
 
add(Cell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Adds a value to the memstore
add(Cell, MemStoreSizing) - Method in interface org.apache.hadoop.hbase.regionserver.MemStore
Write an update
add(Delete) - Method in class org.apache.hadoop.hbase.client.RowMutations
Deprecated.
since 2.0 version and will be removed in 3.0 version. use RowMutations.add(Mutation)
add(Mutation) - Method in class org.apache.hadoop.hbase.client.RowMutations
Currently only supports Put and Delete mutations.
add(Put) - Method in class org.apache.hadoop.hbase.client.RowMutations
Deprecated.
since 2.0 version and will be removed in 3.0 version. use RowMutations.add(Mutation)
add(Result) - Method in class org.apache.hadoop.hbase.MetaTableAccessor.CollectAllVisitor
 
add(Result) - Method in class org.apache.hadoop.hbase.MetaTableAccessor.CollectingVisitor
 
add(HDFSBlocksDistribution) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
This will add the distribution from input to this object
add(HTableDescriptor, Class<? extends Constraint>...) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
Add configuration-less constraints 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(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(LruCachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache.BlockBucket
 
add(LruCachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache.BlockBucket
 
add(LruCachedBlock) - Method in class org.apache.hadoop.hbase.io.hfile.LruCachedBlockQueue
Attempt to add the specified cached block to this queue.
add(CallRunner) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
add(SimpleServerRpcConnection) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.ConnectionManager
Deprecated.
 
add(Queue<T>) - Method in class org.apache.hadoop.hbase.master.procedure.FairQueue
 
add(InlineChore) - Method in class org.apache.hadoop.hbase.procedure2.TimeoutExecutorThread
 
add(Procedure<?>, boolean) - Method in class org.apache.hadoop.hbase.master.procedure.Queue
 
add(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.TimeoutExecutorThread
 
add(RemoteProcedureDispatcher.RemoteProcedure) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.BufferNode
 
add(RemoteProcedureDispatcher.RemoteProcedure<TEnv, TRemote>) - Method in interface org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.RemoteNode
 
add(DelayedUtil.DelayedWithTimeout) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.TimeoutExecutorThread
 
add(RegionLocations) - Method in class org.apache.hadoop.hbase.client.AsyncRegionLocationCache
Add the given locations to the cache, merging with existing if necessary.
add(TableModel) - Method in class org.apache.hadoop.hbase.rest.model.TableListModel
Add the table name model to the list
add(TableRegionModel) - Method in class org.apache.hadoop.hbase.rest.model.TableInfoModel
Add a region model to the list
add(ProcedureProtos.Procedure) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.WALProcedureMap
Deprecated.
 
add(DataType<?>) - Method in class org.apache.hadoop.hbase.types.StructBuilder
Append field to the sequence of accumulated fields.
add(R) - Method in class org.apache.hadoop.hbase.util.RegionSplitCalculator
Adds an edge to the split calculator
add(S, S) - Method in class org.apache.hadoop.hbase.coprocessor.ColumnInterpreter
Returns sum or non null value among (if either of them is null); otherwise returns a null.
add(T) - Method in class org.apache.hadoop.hbase.util.LossyCounting
 
add(T) - Method in class org.apache.hadoop.hbase.util.ReservoirSample
 
add(V) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueCollection
 
ADD - Enum constant in enum org.apache.hadoop.hbase.master.procedure.PeerProcedureInterface.PeerOperationType
 
addAction(HRegionLocation, Action) - Method in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller.ServerRequest
 
addAction(ServerName, byte[], Action, Map<ServerName, MultiAction>, long) - Static method in class org.apache.hadoop.hbase.client.AsyncProcess
Helper that is used when grouping the actions per region server.
addAll(int, Collection<? extends E>) - Method in class org.apache.hadoop.hbase.util.SortedList
 
addAll(Collection<? extends E>) - Method in class org.apache.hadoop.hbase.util.SortedList
 
addAll(Collection<? extends Runnable>) - Method in class org.apache.hadoop.hbase.thrift.CallQueue
 
addAll(Collection<? extends Map.Entry<K, V>>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntrySet
 
addAll(Collection<? extends K>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
 
addAll(Collection<? extends Cell>) - Method in class org.apache.hadoop.hbase.regionserver.CellFlatMap.CellFlatMapCollection
 
addAll(Collection<? extends Cell>) - Method in class org.apache.hadoop.hbase.regionserver.CellSet
 
addAll(Collection<? extends CallRunner>) - Method in class org.apache.hadoop.hbase.ipc.AdaptiveLifoCoDelCallQueue
 
addAll(Collection<? extends V>) - Method in class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueCollection
 
addAllHFiles() - Method in class org.apache.hadoop.hbase.procedure2.store.region.HFileProcedurePrettyPrinter
 
addAllLogsToSysTable(Connection) - Method in class org.apache.hadoop.hbase.namequeues.SlowLogPersistentService
Poll from queueForSysTable and insert 100 records in hbase:slowlog table in single batch
addAllocation(long) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
 
addAllServers(Collection<Address>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Adds the given servers to the group.
addAllSublists(List<? extends List<T>>) - Method in class org.apache.hadoop.hbase.util.ConcatenatedLists
 
addAllTables(Collection<TableName>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
addAllToCorruptedAndRemoveFromProcMap(ProcedureTree.Entry, Map<Long, ProcedureTree.Entry>) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureTree
 
addAllToValidAndRemoveFromProcMap(ProcedureTree.Entry, Map<Long, ProcedureTree.Entry>) - Method in class org.apache.hadoop.hbase.procedure2.store.ProcedureTree
 
addAncestor(BackupManifest.BackupImage) - Method in class org.apache.hadoop.hbase.backup.impl.BackupManifest.BackupImage
 
addAndGet(Result[], boolean) - Method in class org.apache.hadoop.hbase.client.AllowPartialScanResultCache
 
addAndGet(Result[], boolean) - Method in class org.apache.hadoop.hbase.client.BatchScanResultCache
 
addAndGet(Result[], boolean) - Method in class org.apache.hadoop.hbase.client.CompleteScanResultCache
 
addAndGet(Result[], boolean) - Method in interface org.apache.hadoop.hbase.client.ScanResultCache
Add the given results to cache and get valid results back.
addAndReWatchTable(String) - Method in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
Add this table to the tracker and then read a watch on that node.
addArchivedFiles(Set<Map.Entry<String, Long>>) - Method in interface org.apache.hadoop.hbase.quotas.FileArchiverNotifier
Records a file and its size in bytes being moved to the archive directory.
addArchivedFiles(Set<Map.Entry<String, Long>>) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl
 
addAssignment(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
 
addAttribute(AttributeKey<T>, T) - Method in class org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder
 
addAttribute(AttributeKey<T>, T) - Method in class org.apache.hadoop.hbase.server.trace.IpcServerSpanBuilder
 
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
addAttributes(OperationWithAttributes, Map<ByteBuffer, ByteBuffer>) - Static method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
Adds all the attributes into the Operation object
addAttributes(OperationWithAttributes, Map<ByteBuffer, ByteBuffer>) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
Adds all the attributes into the Operation object
addBack(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
 
addBack(Procedure) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
Inserts the specified element at the end of this queue.
addBack(Procedure, boolean) - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
 
addBack(Procedure, boolean) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
Inserts the specified element at the end of this queue.
addBloomFilter(BloomFilterWriter, BlockType) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
 
addByOne(T) - Method in class org.apache.hadoop.hbase.util.LossyCounting
 
addBytesMap(Map<Bytes, Bytes>) - Method in class org.apache.hadoop.hbase.CompoundConfiguration
Add Bytes map to config list.
addCallsForCurrentReplica(ResultBoundedCompletionService<Pair<Result[], ScannerCallable>>, int) - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
 
addCallsForOtherReplicas(ResultBoundedCompletionService<Pair<Result[], ScannerCallable>>, int, int, int) - Method in class org.apache.hadoop.hbase.client.ScannerCallableWithReplicas
 
addCallsForReplica(ResultBoundedCompletionService<Result>, RegionLocations, int, int) - Method in class org.apache.hadoop.hbase.client.RpcRetryingCallerWithReadReplicas
Creates the calls and submit them
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.
addCatalogReplicationSource(RegionInfo) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Add an hbase:meta Catalog replication source.
addCell(Cell) - Method in class org.apache.hadoop.hbase.wal.WALEdit
 
addCell(CellModel) - Method in class org.apache.hadoop.hbase.rest.model.RowModel
Adds a cell to the list of cells for this row
addCellCount(int) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
 
addCellPermissions(byte[], Map<byte[], List<Cell>>) - Static method in class org.apache.hadoop.hbase.security.access.AccessController
 
addChangedReaderObserver(ChangedReadersObserver) - Method in class org.apache.hadoop.hbase.regionserver.HStore
 
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
 
addChildProcedure(T...) - Method in class org.apache.hadoop.hbase.procedure2.StateMachineProcedure
Add a child procedure to execute
addChore(ProcedureInMemoryChore<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor
Add a chore procedure to the executor
addClickjackingPreventionFilter(ServletContextHandler, Configuration) - Method in class org.apache.hadoop.hbase.rest.RESTServer
 
addClientMetris(UserMetrics.ClientMetrics) - Method in class org.apache.hadoop.hbase.UserMetricsBuilder
 
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.WALKeyImpl
Marks that the cluster with the given clusterId has consumed the change
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
 
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete the latest 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[], byte[]) - Method in class org.apache.hadoop.hbase.client.ImmutableScan
 
addColumn(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Get the column from the specified family with the specified qualifier.
addColumn(byte[], byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.Append
Add the specified column and value to this Append operation.
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) - Method in class org.apache.hadoop.hbase.client.Delete
Delete the specified version of the specified column.
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[], 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(Scan, byte[]) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Parses a combined family and qualifier and adds either both or just the family in case there is no qualifier.
addColumn(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
As of release 2.0.0. This will be removed in HBase 3.0.0. Use Admin.addColumnFamily(TableName, ColumnFamilyDescriptor).
addColumn(TableName, ColumnFamilyDescriptor, long, long) - Method in class org.apache.hadoop.hbase.master.HMaster
 
addColumn(TableName, ColumnFamilyDescriptor, long, long) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Add a new column to an existing table
addColumn(RpcController, MasterProtos.AddColumnRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
addColumn(RpcController, MasterProtos.AddColumnRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
addColumnFamily(ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder.setColumnFamily(ColumnFamilyDescriptor) instead
addColumnFamily(ColumnSchemaModel) - Method in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
Add a column family to the table descriptor
addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a column family to an existing table.
addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Add a column family to an existing table.
addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
 
addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
 
addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
 
addColumnFamily(TTableName, TColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
addColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a column family to an existing table.
addColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
addColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
 
AddColumnFamilyFuture(HBaseAdmin, TableName, MasterProtos.AddColumnResponse) - Constructor for class org.apache.hadoop.hbase.client.HBaseAdmin.AddColumnFamilyFuture
 
AddColumnFamilyProcedureBiConsumer(TableName) - Constructor for class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin.AddColumnFamilyProcedureBiConsumer
 
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(Scan, String) - Static method in class org.apache.hadoop.hbase.mapreduce.TableInputFormat
Convenience method to parse a string representation of an array of column specifiers.
addCompactionResults(Collection<HStoreFile>, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.DefaultStoreFileManager
 
addCompactionResults(Collection<HStoreFile>, Collection<HStoreFile>) - Method in interface org.apache.hadoop.hbase.regionserver.StoreFileManager
Adds only the new compaction results into the structure.
addCompactionResults(Collection<HStoreFile>, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager
 
addConfig(RegionServerStatusProtos.RegionServerStartupResponse.Builder, String) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
addConfiguration(String, String) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
addConfiguration(Map<String, String>) - Method in class org.apache.hadoop.hbase.NamespaceDescriptor.Builder
 
addConnection(SimpleServerRpcConnection) - Method in class org.apache.hadoop.hbase.ipc.SimpleRpcServer.Listener.Reader
Deprecated.
Updating the readSelector while it's being used is not thread-safe, so the connection must be queued.
addConstraint(HTableDescriptor, Class<? extends Constraint>, Configuration, long) - Static method in class org.apache.hadoop.hbase.constraint.Constraints
Write the raw constraint and configuration to the descriptor.
addCoprocessor(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder.setCoprocessor(String) instead
addCoprocessor(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Add a table coprocessor to this table.
addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder.setCoprocessor(CoprocessorDescriptor) instead
addCoprocessor(String, Path, int, Map<String, String>) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Add a table coprocessor to this table.
addCoprocessorWithSpec(String) - Method in class org.apache.hadoop.hbase.client.TableDescriptorBuilder
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use TableDescriptorBuilder.setCoprocessor(CoprocessorDescriptor) instead
addCoprocessorWithSpec(String) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Add a table coprocessor to this table.
addCostFuncInfo(String, double, float) - Method in class org.apache.hadoop.hbase.client.BalancerRejection.Builder
 
addCostFunction(List<CostFunction>, CostFunction) - Method in class org.apache.hadoop.hbase.master.balancer.CacheAwareLoadBalancer
 
addCostFunction(List<CostFunction>, CostFunction) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
addCostumHeader(String, String) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftConnection.HTTPThriftClientBuilder
 
addCounter(String, Counter, MetricsRecordBuilder) - Method in class org.apache.hadoop.hbase.metrics.impl.HBaseMetrics2HadoopMetricsAdapter
 
addCounter(MetricsRecordBuilder, Map<String, Long>, String, String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
addCSRFFilter(ServletContextHandler, Configuration) - Method in class org.apache.hadoop.hbase.rest.RESTServer
 
addCurrentScanners(List<? extends KeyValueScanner>) - Method in class org.apache.hadoop.hbase.regionserver.StoreScanner
 
addDaughtersToPut(Put, RegionInfo, RegionInfo) - 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.
addDefaultApps(ContextHandlerCollection, String, Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer
Add default apps.
addDefaultServlets(ContextHandlerCollection, Configuration) - Method in class org.apache.hadoop.hbase.http.HttpServer
Add default servlets.
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.HFileWriterImpl
 
addDeleteMarker(Cell) - Method in class org.apache.hadoop.hbase.client.Delete
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Delete.add(Cell) instead
addDependencyJars(Configuration, Class<?>...) - Static method in class org.apache.hadoop.hbase.mapreduce.TableMapReduceUtil
Deprecated.
since 1.3.0 and will be removed in 3.0.0. Use TableMapReduceUtil.addDependencyJars(Job) instead.
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.
addDependencyJarsForClasses(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.
addDependentImage(BackupManifest.BackupImage) - Method in class org.apache.hadoop.hbase.backup.impl.BackupManifest
Add dependent backup image for this backup.
addDeprecatedKeys() - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
The hbase.ipc.server.reservoir.initial.max and hbase.ipc.server.reservoir.initial.buffer.size were introduced in HBase2.0.0, while in HBase3.0.0 the two config keys will be replaced by hbase.server.allocator.max.buffer.count and hbase.server.allocator.buffer.size.
addEmptyLocation(Put, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
addend - Static variable in class org.apache.hadoop.hbase.util.Random64
 
addEndpoint(URI) - Method in class org.apache.hadoop.hbase.http.HttpServer.Builder
Add an endpoint that the HTTP server should listen to.
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(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(WAL.Entry, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.WALEntryBatch
 
addEntryInternal(byte[], int, int, boolean) - Method in class org.apache.hadoop.hbase.io.util.LRUDictionary
 
addEntryToBatch(WALEntryBatch, WAL.Entry) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceWALReader
 
addError() - Method in class org.apache.hadoop.hbase.client.ConnectionImplementation.ServerErrorTracker.ServerErrors
 
addError(Iterable<Action>, Throwable, ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
 
addError(Action, Throwable, ServerName) - Method in class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
 
addEstimatedSize(long) - Method in class org.apache.hadoop.hbase.client.ClientAsyncPrefetchScanner
 
addEstimatedSize(long) - Method in class org.apache.hadoop.hbase.client.ClientScanner
 
addException(byte[], Throwable) - Method in class org.apache.hadoop.hbase.CacheEvictionStatsBuilder
 
addException(byte[], Throwable) - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
addExplicitProviders(Configuration, HashMap<Byte, SaslClientAuthenticationProvider>) - Static method in class org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProviders
Extracts and instantiates authentication providers from the configuration.
addExtendedAttribute(String, byte[]) - Method in interface org.apache.hadoop.hbase.wal.WALKey
Add a named String value to this WALKey to be persisted into the WAL
addExtendedAttribute(String, byte[]) - Method in class org.apache.hadoop.hbase.wal.WALKeyImpl
 
addExtraHeader(String, String) - Method in class org.apache.hadoop.hbase.rest.client.Client
Add extra headers.
addExtraParam(String, String) - Method in class org.apache.hadoop.hbase.security.access.AuthResult.Params
 
addExtraProviders(Configuration, HashMap<Byte, SaslServerAuthenticationProvider>) - Static method in class org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders
Adds any providers defined in the configuration.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Delete
Delete all versions of all columns of the specified family.
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.ImmutableScan
 
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.client.Scan
Get all columns from the specified family.
addFamily(byte[]) - Method in class org.apache.hadoop.hbase.wal.WALEdit
 
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(HColumnDescriptor) - Method in class org.apache.hadoop.hbase.HTableDescriptor
Deprecated.
Adds a column family.
addFamilyAndItsHFilePathToTableInMap(byte[], String, List<Pair<byte[], List<String>>>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
 
addFamilyStoreFile(String, String) - Method in class org.apache.hadoop.hbase.quotas.FileArchiverNotifierImpl.StoreFileReference
 
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.
addFile(List<FileStatus>, LocatedFileStatus, long, long) - Static method in class org.apache.hadoop.hbase.mapreduce.WALInputFormat
 
addFilesRecursively(JobContext, FileStatus, List<FileStatus>) - Static method in class org.apache.hadoop.hbase.mapreduce.HFileInputFormat
 
addFilter(String, boolean) - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
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
 
addFilter(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterList
 
addFilter(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterList
Add a filter.
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
addFilterLists(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListBase
 
addFilterLists(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListWithAND
 
addFilterLists(List<Filter>) - Method in class org.apache.hadoop.hbase.filter.FilterListWithOR
 
addFilterPathMapping(String, WebAppContext) - Method in class org.apache.hadoop.hbase.http.HttpServer
Add the path spec to the filter path mapping.
addFirst(ImmutableSegment) - Method in class org.apache.hadoop.hbase.regionserver.CompactionPipeline
 
addFront(Iterator<Procedure>) - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
 
addFront(Iterator<Procedure>) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
Inserts all elements in the iterator at the front of this queue.
addFront(Procedure) - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
 
addFront(Procedure) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
Inserts the specified element at the front of this queue.
addFront(Procedure, boolean) - Method in class org.apache.hadoop.hbase.procedure2.AbstractProcedureScheduler
 
addFront(Procedure, boolean) - Method in interface org.apache.hadoop.hbase.procedure2.ProcedureScheduler
Inserts the specified element at the front of this queue.
addGauge(String, Gauge<?>, MetricsRecordBuilder) - Method in class org.apache.hadoop.hbase.metrics.impl.HBaseMetrics2HadoopMetricsAdapter
 
addGauge(MetricsRecordBuilder, Map<String, Long>, String, String) - Method in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
 
addGaugesToMetricsRecordBuilder(MetricsRecordBuilder) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
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.HFileWriterImpl
 
addGetResult(Result) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
addGetResult(Result) - Method in class org.apache.hadoop.hbase.quotas.NoopOperationQuota
 
addGetResult(Result) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
Add a get result.
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
 
addHFileRefs(String, List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
 
addHFileRefs(String, List<Pair<Path, Path>>) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
Add new hfile references to the queue.
addHFileRefs(String, List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
 
addHFileRefs(TableName, byte[], List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
 
addHFileRefs(TableName, byte[], List<Pair<Path, Path>>) - Method in interface org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceInterface
Add hfile names to the queue to be replicated.
addHFileRefs(TableName, byte[], List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
 
addHFileRefsToQueue(TableName, byte[], List<Pair<Path, Path>>) - Method in class org.apache.hadoop.hbase.replication.regionserver.Replication
 
addHistogram(String, Histogram, MetricsRecordBuilder) - Method in class org.apache.hadoop.hbase.metrics.impl.HBaseMetrics2HadoopMetricsAdapter
Add Histogram value-distribution data to a Hadoop-Metrics2 record building.
addHole(RegionInfo, RegionInfo) - Method in class org.apache.hadoop.hbase.master.janitor.ReportMakingVisitor
 
addHostAndBlockWeight(String, long, long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
add some weight to a specific host
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
addHostsAndBlockWeight(String[], long, StorageType[]) - 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
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Put.add(Cell) and CellBuilder instead
addImmutable(byte[], byte[], long, byte[]) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Put.add(Cell) and CellBuilder instead
addImmutable(byte[], ByteBuffer, long, ByteBuffer) - Method in class org.apache.hadoop.hbase.client.Put
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use Put.add(Cell) and CellBuilder instead
addIncrementalBackupTableSet(Set<TableName>) - Method in class org.apache.hadoop.hbase.backup.impl.BackupManager
Adds set of tables to overall incremental backup table set
addIncrementalBackupTableSet(Set<TableName>, String) - Method in class org.apache.hadoop.hbase.backup.impl.BackupSystemTable
Add tables to global incremental backup set
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.HFileWriterImpl
 
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.
addInternalServlet(String, ServletHolder, 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.
additionalLoadOnOpenData - Variable in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
Additional data items to be written to the "load-on-open" section.
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.util.RetryCounter
 
addKey(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
 
addKeyToZK(AuthenticationKey) - Method in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
 
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
addLabel(Connection, String) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
Utility method for adding label to the system.
addLabels(RpcController, VisibilityLabelsProtos.VisibilityLabelsRequest, RpcCallback<VisibilityLabelsProtos.VisibilityLabelsResponse>) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityController
VisibilityEndpoint service related methods
addLabels(List<byte[]>) - Method in class org.apache.hadoop.hbase.security.visibility.DefaultVisibilityLabelServiceImpl
 
addLabels(List<byte[]>) - Method in interface org.apache.hadoop.hbase.security.visibility.VisibilityLabelService
Adds the set of labels into the system.
addLabels(Configuration, String[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
addLabels(Connection, String[]) - Static method in class org.apache.hadoop.hbase.security.visibility.VisibilityClient
Utility method for adding labels to the system.
addLast(Procedure<?>) - Method in class org.apache.hadoop.hbase.procedure2.LockAndQueue
 
addLastBloomKey(HFile.Writer) - Method in class org.apache.hadoop.hbase.util.BloomContext
Adds the last bloom key to the HFile Writer as part of StorefileWriter close.
addLastBloomKey(HFile.Writer) - Method in class org.apache.hadoop.hbase.util.RowBloomContext
 
addLastBloomKey(HFile.Writer) - Method in class org.apache.hadoop.hbase.util.RowColBloomContext
 
addLastSeqIdsToOps(String, Map<String, Long>, List<ZKUtil.ZKUtilOp>) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
 
addLease(LeaseManager.Lease) - Method in class org.apache.hadoop.hbase.regionserver.LeaseManager
Inserts lease.
addListener(CompletableFuture<T>, BiConsumer<? super T, ? super Throwable>) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
This is method is used when you just want to add a listener to the given future.
addListener(CompletableFuture<T>, BiConsumer<? super T, ? super Throwable>, Executor) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
Almost the same with FutureUtils.addListener(CompletableFuture, BiConsumer) method above, the only exception is that we will call CompletableFuture.whenCompleteAsync(BiConsumer, Executor).
addListener(ForeignExceptionListener) - Method in class org.apache.hadoop.hbase.errorhandling.ForeignExceptionDispatcher
Listen for failures to a given process.
addListener(Future<V>, GenericFutureListener<? extends Future<? super V>>) - Static method in class org.apache.hadoop.hbase.util.NettyFutureUtils
This is method is used when you just want to add a listener to the given netty future.
addLiveNode(String, long, int, int) - Method in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
Add a live node to the cluster representation.
addLocation(Put, ServerName, long, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
addLocationsOrderInterceptor(Configuration) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
 
addLocationsOrderInterceptor(Configuration, HFileSystem.ReorderBlocks) - Static method in class org.apache.hadoop.hbase.fs.HFileSystem
Add an interceptor on the calls to the namenode#getBlockLocations from the DFSClient linked to this FileSystem.
addLocationToCache(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.AsyncMetaRegionLocator
 
addLocationToCache(HRegionLocation) - Method in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
 
addLogFile(String, String) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Add the specified log file to the stats
addManagedListener(ServerConnector) - Method in class org.apache.hadoop.hbase.http.HttpServer
 
addManifest(BackupInfo, BackupManager, BackupType, Configuration) - Method in class org.apache.hadoop.hbase.backup.impl.TableBackupClient
Add manifest for the current backup.
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
 
addMemStoreSize(long, long, long, int) - Method in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
 
addMergeRegions(Put, Collection<RegionInfo>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
addMetaData(ByteBuffer, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
Adds metadata at current position (position is moved forward).
addMetaWALSplit(long, long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
Record a single instance of a split
addMeter(String, Meter, MetricsRecordBuilder) - Method in class org.apache.hadoop.hbase.metrics.impl.HBaseMetrics2HadoopMetricsAdapter
Add Dropwizard-Metrics rate information to a Hadoop-Metrics2 record builder, converting the rates to the appropriate unit.
addMethod(Method) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods
 
addMethod(String, Class<?>...) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods
 
addMethod(String, String...) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorMethods
 
addMethods() - Method in class org.apache.hadoop.hbase.tool.coprocessor.Branch1CoprocessorMethods
 
addMethods(Class<?>) - Method in class org.apache.hadoop.hbase.tool.coprocessor.CurrentCoprocessorMethods
 
addMobRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
addMobRegion(RegionInfo, SnapshotManifest.RegionVisitor) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
addMultiException(MultiException, Exception) - Method in class org.apache.hadoop.hbase.http.HttpServer
 
addMutation(Mutation) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
addMutation(Mutation) - Method in class org.apache.hadoop.hbase.quotas.NoopOperationQuota
 
addMutation(Mutation) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
Add a mutation result.
addMvccToOperationContext(long, long, long) - Method in class org.apache.hadoop.hbase.regionserver.ServerNonceManager
Store the write point in OperationContext when the operation succeed.
addNamespace(String) - Method in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
 
addNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.namespace.NamespaceAuditor
 
addNamespaceQuota(Connection, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
addNamespaceQuotaTable(TableName) - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore.TablesWithQuotas
Adds a table with a namespace quota.
addNewMetricIfAbsent(String, T, Class<T>) - Method in class org.apache.hadoop.metrics2.lib.DynamicMetricsRegistry
 
addNewRegions() - Method in class org.apache.hadoop.hbase.util.compaction.MajorCompactor
 
addNewTableEntryInMap(Map<String, List<Pair<byte[], List<String>>>>, byte[], String, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
 
addNoCacheFilter(ServletContextHandler, Configuration) - Static method in class org.apache.hadoop.hbase.http.HttpServer
 
addNode(TRemote) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
Add a node that will be able to execute remote procedures
addOperationsFromCP(int, Mutation[]) - Method in class org.apache.hadoop.hbase.regionserver.MiniBatchOperationInProgress
Add more Mutations corresponding to the Mutation at the given index to be committed atomically in the same batch.
addOperationToNode(TRemote, RemoteProcedureDispatcher.RemoteProcedure) - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher
Add a remote rpc.
addOption(Option) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
addOptions() - Method in class org.apache.hadoop.hbase.backup.BackupDriver
 
addOptions() - Method in class org.apache.hadoop.hbase.backup.RestoreDriver
 
addOptions() - Method in class org.apache.hadoop.hbase.mapreduce.RowCounter
 
addOptions() - Method in class org.apache.hadoop.hbase.master.http.RegionVisualizer
 
addOptions() - Method in class org.apache.hadoop.hbase.procedure2.store.region.HFileProcedurePrettyPrinter
 
addOptions() - Method in class org.apache.hadoop.hbase.procedure2.store.region.WALProcedurePrettyPrinter
 
addOptions() - Method in class org.apache.hadoop.hbase.snapshot.CreateSnapshot
 
addOptions() - Method in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
addOptions() - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo
 
addOptions() - Method in class org.apache.hadoop.hbase.tool.coprocessor.CoprocessorValidator
 
addOptions() - Method in class org.apache.hadoop.hbase.tool.DataBlockEncodingValidator
 
addOptions() - Method in class org.apache.hadoop.hbase.tool.HFileContentValidator
 
addOptions() - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
Override this to add command-line options using AbstractHBaseTool.addOptWithArg(java.lang.String, java.lang.String) and similar methods.
addOptions() - Method in class org.apache.hadoop.hbase.util.RegionMover
 
addOptions(Options) - Method in class org.apache.hadoop.hbase.thrift.ThriftServer
Add options to command lines
addOptions(Options) - Method in class org.apache.hadoop.hbase.thrift2.ThriftServer
 
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
 
addOverlap(RegionInfo, RegionInfo) - Method in class org.apache.hadoop.hbase.master.janitor.ReportMakingVisitor
 
addParam(QueryStringEncoder, String, Object) - Method in class org.apache.hadoop.hbase.master.http.MetaBrowser
Adds value to encoder under paramName when value is non-null.
addPeer(String) - Method in interface org.apache.hadoop.hbase.replication.regionserver.PeerProcedureHandler
 
addPeer(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.PeerProcedureHandlerImpl
 
addPeer(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
1.
addPeer(String) - Method in class org.apache.hadoop.hbase.replication.ReplicationPeers
Method called after a peer has been connected.
addPeer(String, ReplicationPeerConfig) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
addPeer(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.master.replication.ReplicationPeerManager
 
addPeer(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.replication.FSReplicationPeerStorage
 
addPeer(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.replication.ReplicationPeerStorage
Add a replication peer.
addPeer(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationPeerStorage
 
addPeer(String, ReplicationPeerConfig, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0, use ReplicationAdmin.addPeer(String, ReplicationPeerConfig) instead.
AddPeerProcedure - Class in org.apache.hadoop.hbase.master.replication
The procedure for adding a new replication peer.
AddPeerProcedure() - Constructor for class org.apache.hadoop.hbase.master.replication.AddPeerProcedure
 
AddPeerProcedure(String, ReplicationPeerConfig, boolean) - Constructor for class org.apache.hadoop.hbase.master.replication.AddPeerProcedure
 
addPeerToHFileRefs(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
 
addPeerToHFileRefs(String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
Add a peer to hfile reference queue if peer does not exist.
addPeerToHFileRefs(String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
 
addPrimaryAssignment(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
 
addPrivilegedServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.HttpServer
Adds a servlet in the server that only administrators can access.
addPrivilegedServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.InfoServer
Adds a servlet in the server that any user can access.
addPrivilegedServlet(String, ServletHolder) - Method in class org.apache.hadoop.hbase.http.HttpServer
Adds a servlet in the server that only administrators can access.
addProperty(String, String) - Method in class org.apache.hadoop.hbase.rest.model.NamespacesInstanceModel
Add property to the namespace.
addProviderIfNotExists(SaslClientAuthenticationProvider, HashMap<Byte, SaslClientAuthenticationProvider>) - Static method in class org.apache.hadoop.hbase.security.provider.SaslClientAuthenticationProviders
Adds the given provider to the set, only if an equivalent provider does not already exist in the set.
addProviderIfNotExists(SaslServerAuthenticationProvider, HashMap<Byte, SaslServerAuthenticationProvider>) - Static method in class org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders
Adds the given provider into the map of providers if a mapping for the auth code does not already exist in the map.
addPushSize(long) - 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
 
addQuotas(Connection, byte[], byte[], QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
addQuotas(Connection, byte[], QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
addr - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
Deprecated.
 
addr - Variable in class org.apache.hadoop.hbase.ipc.AbstractRpcClient.AbstractRpcChannel
 
addr - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
 
addr2Stub - Variable in class org.apache.hadoop.hbase.client.ConnectionRegistryRpcStubHolder
 
addr2StubFuture - Variable in class org.apache.hadoop.hbase.client.ConnectionRegistryRpcStubHolder
 
addReadRequestsCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
addRecord(NamedQueuePayload) - Method in class org.apache.hadoop.hbase.namequeues.NamedQueueRecorder
Add various NamedQueue records to ringbuffer.
addReferenceFiles(SnapshotManifest.RegionVisitor, Object, Object, Collection<StoreFileInfo>, boolean) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
addRegion(byte[], int, int, int, int, long, 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(int[], int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
 
addRegion(LinkedList<RegionInfo>, RegionInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
addRegion(Path, RegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
Creates a 'manifest' for the specified region, by reading directly from the disk.
addRegion(Path, RegionInfo, SnapshotManifest.RegionVisitor) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
addRegion(RegionInfo) - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
 
addRegion(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.ServerStateNode
 
addRegion(HRegion) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
addRegion(HRegion) - Method in interface org.apache.hadoop.hbase.regionserver.MutableOnlineRegions
Add to online regions.
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(HRegion, SnapshotManifest.RegionVisitor) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
 
addRegionInfo(Put, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
addRegionInfo(HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HbckTableInfo
 
addRegionPlan(MinMaxPriorityQueue<RegionPlan>, boolean, ServerName, List<RegionPlan>) - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
Add a region from the head or tail to the List of regions to return.
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
 
addRegionServerQuota(Connection, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
addRegionSize(RegionInfo, long, long) - Method in class org.apache.hadoop.hbase.quotas.MasterQuotaManager
 
addRegionSorted(int[], int) - Method in class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
 
addRegionStateToPut(Put, int, RegionState.State) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Set the column value corresponding to this replicaId's RegionState to the provided state.
addRegionsToInMemoryStates(List<RegionInfo>, MasterProcedureEnv, int) - Method in class org.apache.hadoop.hbase.master.procedure.RestoreSnapshotProcedure
Add regions to in-memory states
addRegionsToMeta(Connection, List<RegionInfo>, 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<RegionInfo>, int, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a hbase:meta row for each of the specified new regions.
addRegionsToMeta(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.CloneSnapshotProcedure
Add regions to hbase:meta table.
addRegionsToMeta(MasterProcedureEnv, TableDescriptor, List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
Add the specified set of regions to the hbase:meta table.
addRegionToMap(Map<ServerName, List<RegionInfo>>, RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
 
addRegionToMap(Map<ServerName, List<RegionInfo>>, RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
 
addRegionToMeta(Connection, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds a (single) hbase:meta row for the specified new region and its daughters.
addRegionToRemove(RegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
 
addRegionToRestore(RegionInfo) - Method in class org.apache.hadoop.hbase.snapshot.RestoreSnapshotHelper.RestoreMetaChanges
 
addRegionToServer(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
 
addRegionToSnapshot(SnapshotProtos.SnapshotDescription, ForeignExceptionSnare) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
Complete taking the snapshot on the region.
addReplicaActions(int, Map<ServerName, MultiAction>, List<Action>) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable
Add replica actions to action map by server.
addReplicaActionsAgain(Action, Map<ServerName, MultiAction>) - Method in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable
 
addReplicas(List<RegionInfo>, int, int) - Static method in class org.apache.hadoop.hbase.client.RegionReplicaUtil
Create any replicas for the regions (the default replicas that was already created is passed to the method)
addReplicationBarrier(Put, long) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
See class comment on SerialReplicationChecker
addReplicationParent(Put, List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
addReplicationPeer(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a new replication peer for replicating data to slave cluster.
addReplicationPeer(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Add a new replication peer for replicating data to slave cluster
addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a new replication peer for replicating data to slave cluster.
addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Add a new replication peer for replicating data to slave cluster
addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
 
addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
 
addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.master.MasterServices
Add a new replication peer for replicating data to slave cluster
addReplicationPeer(RpcController, ReplicationProtos.AddReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
addReplicationPeer(RpcController, ReplicationProtos.AddReplicationPeerRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
addReplicationPeerAsync(String, ReplicationPeerConfig) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a new replication peer but does not block and wait for it.
addReplicationPeerAsync(String, ReplicationPeerConfig, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Add a new replication peer but does not block and wait for it.
addReplicationPeerAsync(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
addReplicationPeerAsync(String, ReplicationPeerConfig, boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
 
addRequiredOption(Option) - Method in class org.apache.hadoop.hbase.util.AbstractHBaseTool
 
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
 
addResource(InputStream) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
 
addResource(InputStream, String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
 
addResource(String) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
 
addResource(URL) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
 
addResource(Configuration) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
 
addResource(Path) - Method in class org.apache.hadoop.hbase.coprocessor.ReadOnlyConfiguration
 
address - Variable in class org.apache.hadoop.hbase.ipc.ConnectionId
 
address - Variable in class org.apache.hadoop.hbase.ipc.SimpleRpcServer
Deprecated.
 
address - Variable in class org.apache.hadoop.hbase.ServerName
 
Address - Class in org.apache.hadoop.hbase.net
An immutable type to hold a hostname and port combo, like an Endpoint or java.net.InetSocketAddress (but without danger of our calling resolve -- we do NOT want a resolve happening every time we want to hold a hostname and port combo).
Address(HostAndPort) - Constructor for class org.apache.hadoop.hbase.net.Address
 
ADDRESS_BITS_PER_WORD - Static variable in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
Deprecated.
 
addresses - Variable in class org.apache.hadoop.hbase.client.BatchErrors
 
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
addressIsLocalHost(String) - Static method in class org.apache.hadoop.hbase.zookeeper.HQuorumPeer
 
addResult(int, Object) - Method in class org.apache.hadoop.hbase.client.MultiResponse.RegionResult
 
addResult(ClientProtos.MutateResponse.Builder, Result, HBaseRpcController, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
addResults(ClientProtos.ScanResponse.Builder, List<Result>, HBaseRpcController, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
addRollbackStep(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.RootProcedureState
Called by the ProcedureExecutor after the procedure step is completed, to add the step to the rollback list (or procedure stack).
addRow(RowModel) - Method in class org.apache.hadoop.hbase.rest.model.CellSetModel
Add a row to this cell set
ADDRS_CONF_SEPARATOR - Static variable in class org.apache.hadoop.hbase.client.RpcConnectionRegistry
 
addRSGroup(RpcController, RSGroupAdminProtos.AddRSGroupRequest, RpcCallback<RSGroupAdminProtos.AddRSGroupResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint.RSGroupAdminServiceImpl
 
addRSGroup(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Creates a new RegionServer group with the given name.
addRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
 
addRSGroup(String) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
addRSGroup(RSGroupInfo) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupInfoManager
Add given RSGroupInfo to existing list of group infos.
addRSGroup(RSGroupInfo) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfoManagerImpl
 
addScanner(String, RegionScanner, Shipper, HRegion, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
addScanner(ResultScanner) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
Assigns a unique ID to the scanner and adds the mapping to an internal HashMap.
addScanner(ResultScanner, boolean) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
Assigns a unique ID to the scanner and adds the mapping to an internal hash-map.
addScanner(RegionScanner) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices.RegionScannersCloseCallBack
 
addScannerLeaseBack(LeaseManager.Lease) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
 
addScanResult(List<Result>) - Method in class org.apache.hadoop.hbase.quotas.DefaultOperationQuota
 
addScanResult(List<Result>) - Method in class org.apache.hadoop.hbase.quotas.NoopOperationQuota
 
addScanResult(List<Result>) - Method in interface org.apache.hadoop.hbase.quotas.OperationQuota
Add a scan result.
addSecondaryAssignment(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
 
addSecurityHeadersFilter(ServletContextHandler, Configuration, boolean) - Method in class org.apache.hadoop.hbase.rest.RESTServer
 
addSequenceNum(Put, long, int) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
 
addServer(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.util.HbckRegionInfo
 
addServer(Address) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
Adds the given server to the group.
addServer(ServerName) - Method in class org.apache.hadoop.hbase.util.HbckTableInfo
 
addServerToDrainList(ServerName) - Method in class org.apache.hadoop.hbase.master.ServerManager
Add the server to the drain list.
addServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.InfoServer
Deprecated.
Use InfoServer.addUnprivilegedServlet(String, String, Class) or InfoServer.addPrivilegedServlet(String, String, Class) instead of this method which does not state outwardly what kind of authz rules will be applied to this servlet.
addServletWithAuth(String, String, Class<? extends HttpServlet>, boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer
Internal method to add a servlet to the HTTP server.
addServletWithAuth(String, ServletHolder, boolean) - Method in class org.apache.hadoop.hbase.http.HttpServer
Internal method to add a servlet to the HTTP server.
addShutdownHook(Thread, int) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager
 
addShutdownHook(Thread, int) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager.ShutdownHookManagerV1
 
addShutdownHook(Thread, int) - Method in class org.apache.hadoop.hbase.util.ShutdownHookManager.ShutdownHookManagerV2
 
addSize(RpcCallContext, Result) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Method to account for the size of retained cells.
addSkippedRegion(HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
 
addSlowAckData(DatanodeInfo, long, long) - Method in class org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
 
addSlowLogRecords(List<TooSlowLog.SlowLogPayload>, Connection) - Static method in class org.apache.hadoop.hbase.slowlog.SlowLogTableAccessor
Add slow/large log records to hbase:slowlog table
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
addSource(String) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
Add a normal source for the given peer on this region server.
addSplit(long, long) - Method in class org.apache.hadoop.hbase.master.MetricsMasterFileSystem
Record a single instance of a split
addSplitsToParent(Connection, RegionInfo, RegionInfo, RegionInfo) - Static method in class org.apache.hadoop.hbase.MetaTableAccessor
Adds daughter region infos to hbase:meta row for the specified region.
addStackIndex(int) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Called by the RootProcedureState on procedure execution.
addStatistic(byte[], ClientProtos.RegionLoadStats) - Method in class org.apache.hadoop.hbase.client.MultiResponse
 
addStats(HFilePrettyPrinter.KeyValueStats) - Method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter.SimpleReporter.Builder
Add the given HFilePrettyPrinter.KeyValueStats to be reported
addStoreFile(RegionInfo, String, SnapshotProtos.SnapshotRegionManifest.StoreFile, Map<Path, Integer>) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotInfo.SnapshotStats
Add the specified store file to the stats
addStoreFiles(Collection<HStoreFile>, StoreEngine.IOExceptionRunnable) - Method in class org.apache.hadoop.hbase.regionserver.StoreEngine
Add the store files to store file manager, and also record it in the store file tracker.
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
 
addSubProcedure(Procedure<TEnvironment>) - Method in class org.apache.hadoop.hbase.procedure2.RootProcedureState
 
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.
addTable(TableName) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupInfo
 
addTable(TableName, int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceStateManager
 
addTable(TableName, int) - Method in class org.apache.hadoop.hbase.namespace.NamespaceTableAndRegionInfo
 
addTableAcl(TableName, Set<String>, String) - Method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
Add table user acls
addTableDescriptor(TableDescriptor) - Method in class org.apache.hadoop.hbase.snapshot.SnapshotManifest
Add the table descriptor to the snapshot manifest
addTableQuota(Connection, TableName, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
addTableQuotaTable(TableName) - Method in class org.apache.hadoop.hbase.quotas.QuotaObserverChore.TablesWithQuotas
Adds a table with a table quota.
addTables(TableName[]) - Method in class org.apache.hadoop.hbase.backup.BackupInfo
 
addTableToMeta(MasterProcedureEnv, TableDescriptor, List<RegionInfo>) - Static method in class org.apache.hadoop.hbase.master.procedure.CreateTableProcedure
 
addTarget(RegionInfo, long) - Method in class org.apache.hadoop.hbase.master.normalizer.MergeNormalizationPlan.Builder
 
addTask(String) - Method in class org.apache.hadoop.hbase.monitoring.TaskGroup
 
addTask(String, boolean) - Method in class org.apache.hadoop.hbase.monitoring.TaskGroup
Add a new task to the group, and before that might complete the last task in the group
addTeritiaryAssignment(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
 
addThreadPools(Supplier<ThreadPoolExecutor>, Supplier<ThreadPoolExecutor>) - Method in class org.apache.hadoop.hbase.client.MetricsConnection
Add thread pools of additional connections to the metrics
addTimer(String, Timer, MetricsRecordBuilder) - Method in class org.apache.hadoop.hbase.metrics.impl.HBaseMetrics2HadoopMetricsAdapter
 
addToBackupSet(String, String[]) - Method in class org.apache.hadoop.hbase.backup.impl.BackupSystemTable
Add backup set (list of tables)
addToBackupSet(String, TableName[]) - Method in interface org.apache.hadoop.hbase.backup.BackupAdmin
Add tables to backup set command
addToBackupSet(String, TableName[]) - Method in class org.apache.hadoop.hbase.backup.impl.BackupAdminImpl
 
addToCache(Result) - Method in class org.apache.hadoop.hbase.client.AsyncTableResultScanner
 
addToCachedServers(RegionLocations) - Method in class org.apache.hadoop.hbase.client.MetaCache
 
addToCompactingFiles(Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.HStore
Adds the files to compacting files.
addToCompactionQueue(ServerName, MajorCompactionRequest) - Method in class org.apache.hadoop.hbase.util.compaction.ClusterCompactionQueues
 
addToCounter(String, long) - Method in class org.apache.hadoop.hbase.client.metrics.ServerSideScanMetrics
 
addToFailedOpen(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
 
addToFailedServers(Address, Throwable) - Method in class org.apache.hadoop.hbase.ipc.FailedServers
Add an address to the list of the failed servers list.
addToHashMultiMap(Map<K1, Map<K2, List<V>>>, K1, K2, V) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSink
Simple helper to a map from key to (a list of) values TODO: Make a general utility method * * @return the list of values corresponding to key1 and key2
addToHDFSBlocksDistribution(HDFSBlocksDistribution, BlockLocation[]) - Static method in class org.apache.hadoop.hbase.util.FSUtils
Update blocksDistribution with blockLocations
addToken(Token<? extends TokenIdentifier>) - Method in class org.apache.hadoop.hbase.security.User
Adds the given Token to the user's credentials.
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.
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.
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.
addToList(List<String>, String, ReplicationQueueStorage) - Method in class org.apache.hadoop.hbase.master.replication.UpdatePeerConfigProcedure
 
addToLockedResources(List<LockedResource>, Map<T, LockAndQueue>, Function<T, String>, LockedResourceType) - Method in class org.apache.hadoop.hbase.master.procedure.SchemaLocking
 
addToMap(Map<String, Long>, String, long, ReplicationQueueStorage) - Method in class org.apache.hadoop.hbase.master.replication.ModifyPeerProcedure
 
addToMovedRegions(String, ServerName, long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
addToOfflineRegions(RegionStateNode) - Method in class org.apache.hadoop.hbase.master.assignment.RegionStates
 
addToPendingAssignment(HashMap<RegionInfo, RegionStateNode>, Collection<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
addToQueue(WALEventTrackerPayload) - Method in class org.apache.hadoop.hbase.namequeues.WALEventTrackerQueueService
 
addToQueueForSysTable(TooSlowLog.SlowLogPayload) - Method in class org.apache.hadoop.hbase.namequeues.SlowLogPersistentService
 
addToReplicaLoad(RegionInfo, List<ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodesManager
 
addToRollingStats(HeapMemoryManager.TunerContext) - Method in class org.apache.hadoop.hbase.regionserver.DefaultHeapMemoryTuner
Add the given context to the rolling tuner stats.
addToRunQueue(FairQueue<T>, Queue<T>, Supplier<String>) - Static method in class org.apache.hadoop.hbase.master.procedure.MasterProcedureScheduler
 
addToScanners(List<? extends Segment>, long, List<KeyValueScanner>) - Static method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
 
addToScanners(Segment, long, List<KeyValueScanner>) - Static method in class org.apache.hadoop.hbase.regionserver.AbstractMemStore
 
addToSize(long) - Method in class org.apache.hadoop.hbase.procedure2.store.wal.ProcedureWALFile
Deprecated.
Used to update in-progress log sizes.
addTotalBufferUsed(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSourceManager
 
addTypeFilter(QuotaType) - Method in class org.apache.hadoop.hbase.quotas.QuotaFilter
Add a type to the filter list
addUniqueWeight(long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution
add some weight to the total unique weight
addUnprivilegedServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.HttpServer
Adds a servlet in the server that any user can access.
addUnprivilegedServlet(String, String, Class<? extends HttpServlet>) - Method in class org.apache.hadoop.hbase.http.InfoServer
Adds a servlet in the server that any user can access.
addUnprivilegedServlet(String, String, ServletHolder) - Method in class org.apache.hadoop.hbase.http.InfoServer
Adds a servlet in the server that any user can access.
addUnprivilegedServlet(String, ServletHolder) - Method in class org.apache.hadoop.hbase.http.HttpServer
Adds a servlet in the server that any user can access.
addUsedSplitWALWorker(ServerName) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
When master restart, there will be a new splitWorkerAssigner.
addUsedWorker(ServerName) - Method in class org.apache.hadoop.hbase.master.WorkerAssigner
 
addUserEntry(Table, String, byte[]) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
 
addUserGlobalHdfsAcl(Table, String) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
 
addUserNamespaceHdfsAcl(Table, String, String) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
 
addUserPermission(Configuration, UserPermission, Table) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
 
addUserPermission(Configuration, UserPermission, Table, boolean) - Static method in class org.apache.hadoop.hbase.security.access.PermissionStorage
Stores a new user permission grant in the access control lists table.
addUserQuota(Connection, String, String, QuotaProtos.Quotas) - Static method in class org.apache.hadoop.hbase.quotas.QuotaUtil
 
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
 
addUserTableHdfsAcl(Connection, String, TableName) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
 
addUserTableHdfsAcl(Connection, Set<String>, TableName) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
 
addUserTableHdfsAcl(Table, String, TableName) - Static method in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclController.SnapshotScannerHDFSAclStorage
 
addVersionDelete(Cell) - Method in class org.apache.hadoop.hbase.regionserver.querymatcher.NewVersionBehaviorTracker.DeleteVersionsNode
 
addVersionDelete(Cell) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityNewVersionBehaivorTracker.VisibilityDeleteVersionsNode
 
addWAL(ServerName, String, String) - Method in class org.apache.hadoop.hbase.replication.regionserver.NoopReplicationQueueStorage
 
addWAL(ServerName, String, String) - Method in interface org.apache.hadoop.hbase.replication.ReplicationQueueStorage
Add a new WAL file to the given queue for a given regionserver.
addWAL(ServerName, String, String) - Method in class org.apache.hadoop.hbase.replication.ZKReplicationQueueStorage
 
addWAL(WAL) - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
 
addWALActionsListener(WALActionsListener) - Method in class org.apache.hadoop.hbase.wal.AbstractFSWALProvider
 
addWALActionsListener(WALActionsListener) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider
 
addWALActionsListener(WALActionsListener) - Method in class org.apache.hadoop.hbase.wal.RegionGroupingProvider
 
addWALActionsListener(WALActionsListener) - Method in interface org.apache.hadoop.hbase.wal.WALProvider
addWalEventTrackerRows(Queue<WALEventTrackerPayload>, Connection) - Static method in class org.apache.hadoop.hbase.namequeues.WALEventTrackerTableAccessor
Add wal event tracker rows to hbase:waleventtracker table
addWeight(long, long) - Method in class org.apache.hadoop.hbase.HDFSBlocksDistribution.HostAndWeight
add weight
addWorkerStuckPercentage - Variable in class org.apache.hadoop.hbase.procedure2.ProcedureExecutor.WorkerMonitor
 
addWriteRequestsCount(long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
adjustedBlockSize - Variable in class org.apache.hadoop.hbase.io.hfile.PreviousBlockCompressionRatePredicator
 
adjustFieldLength - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
adjustFieldLength() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
adjustFieldLengthIfNeeded() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
admin - Variable in class org.apache.hadoop.hbase.client.HBaseAdmin.ProcedureFuture
 
admin - Variable in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
 
admin - Variable in class org.apache.hadoop.hbase.hbtop.screen.Screen
 
admin - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
admin - Variable in class org.apache.hadoop.hbase.mapreduce.TableInputFormatBase
The Admin.
admin - Variable in class org.apache.hadoop.hbase.master.http.RegionVisualizer
 
admin - Variable in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
 
admin - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper
 
admin - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
admin - Variable in class org.apache.hadoop.hbase.util.ConnectionCache.ConnectionInfo
 
admin - Variable in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
 
admin - Variable in class org.apache.hadoop.hbase.util.MoveWithAck
 
admin - Variable in class org.apache.hadoop.hbase.util.MoveWithoutAck
 
admin - Variable in class org.apache.hadoop.hbase.util.RegionMover
 
Admin - Interface in org.apache.hadoop.hbase.client
The administrative API for HBase.
ADMIN - Enum constant in enum org.apache.hadoop.hbase.security.access.Permission.Action
 
ADMIN_QOS - Static variable in class org.apache.hadoop.hbase.HConstants
 
AdminAuthorizedFilter - Class in org.apache.hadoop.hbase.http
 
AdminAuthorizedFilter() - Constructor for class org.apache.hadoop.hbase.http.AdminAuthorizedFilter
 
AdminAuthorizedServlet - Class in org.apache.hadoop.hbase.http
General servlet which is admin-authorized.
AdminAuthorizedServlet() - Constructor for class org.apache.hadoop.hbase.http.AdminAuthorizedServlet
 
adminCall(HBaseRpcController, AdminProtos.AdminService.Interface, PREQ, RawAsyncHBaseAdmin.AdminRpcCall<PRESP, PREQ>, RawAsyncHBaseAdmin.Converter<RESP, PRESP>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
 
adminRequest() - Method in class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory
 
AdminRequestCallerBuilder() - Constructor for class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder
 
ADMINS_ACL - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
adminsAcl - Variable in class org.apache.hadoop.hbase.http.AdminAuthorizedFilter
 
adminsAcl - Variable in class org.apache.hadoop.hbase.http.HttpServer
 
adminsAcl - Variable in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
adminSubs - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
 
adoptHdfsOrphan(HbckRegionInfo) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
Orphaned regions are regions without a .regioninfo file in them.
adoptHdfsOrphans(Collection<HbckRegionInfo>) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
Iterates through the list of all orphan/invalid regiondirs.
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.KeyValueCodec.ByteBuffKeyValueDecoder
 
AdvancedScanResultConsumer - Interface in org.apache.hadoop.hbase.client
This is the low level API for asynchronous scan.
AdvancedScanResultConsumer.ScanController - Interface in org.apache.hadoop.hbase.client
Used to suspend or stop a scan, or get a scan cursor if available.
AdvancedScanResultConsumer.ScanResumer - Interface in org.apache.hadoop.hbase.client
Used to resume a scan.
advanceTick() - Static method in class org.apache.hadoop.hbase.regionserver.compactions.CurrentHourProvider
 
advanceTo(long) - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
Step the MVCC forward on to a new read/write basis.
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 - Enum constant in enum org.apache.hadoop.hbase.client.RegionLocateType
 
AFTER - Enum constant in enum org.apache.hadoop.hbase.regionserver.querymatcher.StripeCompactionScanQueryMatcher.DropDeletesInOutput
 
afterCreatingZigZagLatch() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
Used to manufacture race condition reliably.
afterDecodingKeyValue(DataInputStream, ByteBuffer, HFileBlockDefaultDecodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder
 
afterEncodingKeyValue(Cell, DataOutputStream, HFileBlockDefaultEncodingContext) - Method in class org.apache.hadoop.hbase.io.encoding.BufferedDataBlockEncoder
Returns unencoded size added
afterExecute(Runnable, Throwable) - Method in class org.apache.hadoop.hbase.executor.ExecutorService.TrackingThreadPoolExecutor
 
afterExecute(Runnable, Throwable) - Method in class org.apache.hadoop.hbase.thrift.THBaseThreadPoolExecutor
 
afterExecution() - Method in interface org.apache.hadoop.hbase.regionserver.FlushLifeCycleTracker
Called after flush is executed.
afterExecution(Store) - Method in interface org.apache.hadoop.hbase.regionserver.compactions.CompactionLifeCycleTracker
Called after compaction is executed by CompactSplitThread.
afterReplay(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.assignment.RegionRemoteProcedureBase
 
afterReplay(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.FlushTableProcedure
 
afterReplay(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.SnapshotProcedure
 
afterReplay(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.SplitWALProcedure
 
afterReplay(TEnvironment) - Method in class org.apache.hadoop.hbase.procedure2.Procedure
Called when the procedure is ready to be added to the queue after the loading/replay operation.
afterWALArchive(Path, Path) - Method in class org.apache.hadoop.hbase.master.region.MasterRegionWALRoller
 
afterWALArchive(Path, Path) - Method in class org.apache.hadoop.hbase.wal.AbstractWALRoller
 
ageAtEviction - Variable in class org.apache.hadoop.hbase.io.hfile.CacheStats
Keep running age at eviction time
ageHist - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSinkSourceImpl
 
ageHistogram - Variable in class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
 
agentName - Variable in class org.apache.hadoop.hbase.chaos.ChaosAgent
 
ageOfLastAppliedOp - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSink
 
ageOfLastAppliedOp - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSink.ReplicationLoadSinkBuilder
 
ageOfLastShippedOp - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsSource
 
ageOfLastShippedOp - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus
 
ageOfLastShippedOp - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationStatus.ReplicationStatusBuilder
 
ageOfLastShippedOp - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSource
 
ageOfLastShippedOp - Variable in class org.apache.hadoop.hbase.replication.ReplicationLoadSource.ReplicationLoadSourceBuilder
 
ageOfLastShippedOpHist - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationGlobalSourceSourceImpl
 
ageOfLastShippedOpHist - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
ageOfLastShippedOpHist - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
 
ageOfLastShippedOpKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationSourceSourceImpl
 
ageOfLastShippedOpKey - Variable in class org.apache.hadoop.hbase.replication.regionserver.MetricsReplicationTableSourceImpl
 
AgeSnapshot - Class in org.apache.hadoop.hbase.io.hfile
Snapshot of block cache age in cache.
AgeSnapshot(FastLongHistogram) - Constructor for class org.apache.hadoop.hbase.io.hfile.AgeSnapshot
 
agg - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionSourceImpl
 
agg - Variable in class org.apache.hadoop.hbase.regionserver.MetricsTableSourceImpl
 
aggLock - Variable in enum org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceFactoryImpl.FactoryStorage
 
aggregate - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
 
aggregate(HRegionServer, Map<String, ArrayList<Long>>) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl.RegionMetricAggregate
 
aggregateRecords(List<Record>, Field) - Static method in class org.apache.hadoop.hbase.hbtop.mode.ModeStrategyUtils
Group by records on the basis of supplied groupBy field and Aggregate records using Record.combine(Record)
aggregateRecordsAndAddDistinct(List<Record>, Field, Field, Field) - Method in class org.apache.hadoop.hbase.hbtop.mode.ClientModeStrategy
Aggregate the records and count the unique values for the given distinctField
aggregateRequestPerSecond - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
 
aggregateStores(List<HStore>) - Method in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl.RegionMetricAggregate
 
AggregatingCompleteTracker(CompactionLifeCycleTracker, int) - Constructor for class org.apache.hadoop.hbase.regionserver.CompactSplit.AggregatingCompleteTracker
 
aggregationWindow - Variable in class org.apache.hadoop.hbase.regionserver.BusyRegionSplitPolicy
 
alarming - Variable in class org.apache.hadoop.hbase.regionserver.HeapMemoryManager.HeapMemoryTunerChore
 
algorithm - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
Use MessageDigest class's encryption algorithms to check persistent file integrity, default algorithm is MD5
algorithm - Variable in class org.apache.hadoop.hbase.regionserver.wal.CompressionContext.ValueCompressor
 
Algorithm(String, String, String) - Constructor for enum org.apache.hadoop.hbase.io.compress.Compression.Algorithm
 
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.
align(long) - Method in class org.apache.hadoop.hbase.util.ClassSize.MemoryLayout
Aligns a number to 8.
alignDown(long) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
Deprecated.
Returns lower boundary (aligned to multiple of BITS_PER_WORD) of bitmap range x belongs to.
alignUp(long) - Static method in class org.apache.hadoop.hbase.procedure2.store.wal.BitSetNode
Deprecated.
Returns upper boundary (aligned to multiple of BITS_PER_WORD) of bitmap range x belongs to.
ALL - Enum constant in enum org.apache.hadoop.hbase.client.AsyncProcessTask.SubmittedRows
 
ALL - Enum constant in enum org.apache.hadoop.hbase.MetaTableAccessor.QueryType
 
ALL - Enum constant in enum org.apache.hadoop.hbase.monitoring.TaskMonitor.TaskFilter.TaskType
 
ALL_CATEGORIES - Enum constant in enum org.apache.hadoop.hbase.io.hfile.BlockType.BlockCategory
 
ALL_FILES - Enum constant in enum org.apache.hadoop.hbase.regionserver.compactions.CompactionRequestImpl.DisplayCompactionType
 
ALL_FLAG_BITS - Static variable in class org.apache.hadoop.hbase.regionserver.ServerNonceManager.OperationContext
 
ALL_TIME - Static variable in class org.apache.hadoop.hbase.io.TimeRange
 
ALL_VERSIONS - Static variable in class org.apache.hadoop.hbase.HConstants
Define for 'return-all-versions'.
allBufs - Variable in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
 
allCells - Variable in class org.apache.hadoop.hbase.mapreduce.CopyTable
 
allChannels - Variable in class org.apache.hadoop.hbase.ipc.NettyRpcServer
 
allCompactedFilesCached - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.State
 
allFilesCached - Variable in class org.apache.hadoop.hbase.regionserver.StripeStoreFileManager.State
Cached list of all files in the structure, to return from some calls
allFilesExpired(List<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
 
allKeys - Variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
 
allL0FilesExpired(StripeCompactionPolicy.StripeInformationProvider) - Method in class org.apache.hadoop.hbase.regionserver.compactions.StripeCompactionPolicy
 
alloc - Variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutput
 
alloc - Variable in class org.apache.hadoop.hbase.ipc.CellBlockBuilder.ByteBufOutputStreamSupplier
 
alloc(int) - Method in class org.apache.hadoop.hbase.regionserver.Chunk
Try to allocate size bytes from the chunk.
ALLOC - Enum constant in enum org.apache.hadoop.hbase.http.ProfileServlet.Event
 
ALLOC - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
 
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
allocate(int) - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
Allocate size bytes from the ByteBufAllocator, Note to call the ByteBuff.release() if no need any more, otherwise the memory leak happen in NIO ByteBuffer pool.
allocate(int, boolean) - Static method in class org.apache.hadoop.hbase.io.ByteBufferOutputStream
 
allocate(int, boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
 
allocate(long) - Method in interface org.apache.hadoop.hbase.util.ByteBufferAllocator
Allocates a bytebuffer
allocateBlock(int) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator
Allocate a block with specified size.
allocateBlock(int) - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.BucketSizeInfo
Find a bucket to allocate a block
allocateBuffer(ChannelHandlerContext, ByteBuf, boolean) - Method in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputSaslHelper.EncryptHandler
 
allocateBufferForUnpacking() - Method in class org.apache.hadoop.hbase.io.hfile.HFileBlock
Always allocates a new buffer of the correct size.
allocateDataBuffer() - Method in class org.apache.hadoop.hbase.regionserver.Chunk
 
allocateDataBuffer() - Method in class org.apache.hadoop.hbase.regionserver.OffheapChunk
 
allocateDataBuffer() - Method in class org.apache.hadoop.hbase.regionserver.OnheapChunk
 
allocateNewBuffer() - Method in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
 
allocateNewChunk() - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
 
allocateOneBuffer() - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
Allocate an buffer with buffer size from ByteBuffAllocator, Note to call the ByteBuff.release() if no need any more, otherwise the memory leak happen in NIO ByteBuffer pool.
allocateOnHeap(int) - Method in class org.apache.hadoop.hbase.io.ByteBuffAllocator
 
ALLOCATION_FAIL_LOG_TIME_PERIOD - Static variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
allocationFailCount - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
 
allocationFailed() - Method in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCacheStats
 
allocator - Variable in class org.apache.hadoop.hbase.io.ByteBufferListOutputStream
 
allocator - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketEntry
 
allocator - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock
 
allocator - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock.FSReaderImpl
 
allocator - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
 
allocator - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlockBuilder
 
allocator - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl
 
ALLOCATOR_FOR_TEST - Static variable in class org.apache.hadoop.hbase.regionserver.RegionServicesForStores
 
ALLOCATOR_POOL_ENABLED_KEY - Static variable in class org.apache.hadoop.hbase.io.ByteBuffAllocator
 
allocBloom() - Method in class org.apache.hadoop.hbase.util.BloomFilterChunk
 
allocCount - Variable in class org.apache.hadoop.hbase.regionserver.Chunk
Total number of allocations satisfied from this buffer
allocFailLogPrevTs - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
allocIndexChunks(int) - Method in class org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
 
allOf(List<CompletableFuture<T>>) - Static method in class org.apache.hadoop.hbase.util.FutureUtils
Returns a new CompletableFuture that is completed when all of the given CompletableFutures complete.
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
 
allowableError(int) - Method in class org.apache.hadoop.metrics2.util.MetricSampleQuantiles
Specifies the allowable error for this rank, depending on which quantiles are being targeted.
allowCompaction - Variable in class org.apache.hadoop.hbase.regionserver.CompactingMemStore
 
allowCoreThreadTimeout - Variable in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorConfig
 
allowCoreThreadTimeout() - Method in class org.apache.hadoop.hbase.executor.ExecutorService.ExecutorConfig
 
allowed - Variable in class org.apache.hadoop.hbase.security.access.AuthResult
 
ALLOWED_METHODS - Static variable in class org.apache.hadoop.hbase.http.ProfileServlet
 
allowedFailures - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.Monitor
 
allowFallbackToSimpleAuth - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
allowPartialResults - Variable in class org.apache.hadoop.hbase.client.Scan
Partial Results are Results must be combined to form a complete Result.
AllowPartialScanResultCache - Class in org.apache.hadoop.hbase.client
A ScanResultCache that may return partial result.
AllowPartialScanResultCache() - Constructor for class org.apache.hadoop.hbase.client.AllowPartialScanResultCache
 
allowReverseDnsLookup - Variable in class org.apache.hadoop.hbase.io.crypto.tls.HBaseTrustManager
 
allRegions - Variable in class org.apache.hadoop.hbase.tool.CanaryTool.RegionServerMonitor
 
allRequests - Variable in class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator.TableCache
 
allTime - Variable in class org.apache.hadoop.hbase.io.TimeRange
 
allTime() - Static method in class org.apache.hadoop.hbase.io.TimeRange
 
alpha - Variable in class org.apache.hadoop.hbase.util.ExponentialMovingAverage
 
ALPHA_NUMERIC - Static variable in class org.apache.hadoop.hbase.http.ProfileOutputServlet
 
ALREADY_FINISHED - Enum constant in enum org.apache.hadoop.hbase.regionserver.storefiletracker.ModifyStoreFileTrackerProcedure.StoreFileTrackerState
 
alreadyRunning - Variable in class org.apache.hadoop.hbase.master.janitor.CatalogJanitor
 
alt - Variable in class org.apache.hadoop.hbase.hbtop.terminal.KeyPress
 
alternateBufferedMutatorClassName - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
Allow setting an alternate BufferedMutator implementation via config.
ALWAYS_COPY_FILES - Static variable in interface org.apache.hadoop.hbase.tool.BulkLoadHFiles
 
ALWAYS_COPY_FILES - Static variable in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
Deprecated.
 
amd64 - Static variable in class org.apache.hadoop.hbase.util.JVM
 
ampBytes - Static variable in class org.apache.hadoop.hbase.http.HtmlQuoting
 
ancestors - Variable in class org.apache.hadoop.hbase.backup.impl.BackupManifest.BackupImage
 
AND - Enum constant in enum org.apache.hadoop.hbase.client.LogQueryFilter.FilterByOperator
Deprecated.
 
AND - Enum constant in enum org.apache.hadoop.hbase.filter.BitComparator.BitwiseOp
and
AND - Enum constant in enum org.apache.hadoop.hbase.security.visibility.expression.Operator
 
AND - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
AND Byte Array
AND - Static variable in class org.apache.hadoop.hbase.security.visibility.ExpressionParser
 
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
 
annotateBytesRead(AttributesBuilder, long, long) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
Conditionally annotate attributesBuilder with appropriate attributes when values are non-zero.
annotatedQos - Variable in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
 
annotateHeapBytesRead(AttributesBuilder, int) - Static method in class org.apache.hadoop.hbase.io.util.BlockIOUtils
Conditionally annotate span with the appropriate attribute when value is non-zero.
AnnotationReadingPriorityFunction - Class in org.apache.hadoop.hbase.regionserver
Reads special method annotations and table names to figure a priority for use by QoS facility in ipc; e.g: rpcs to hbase:meta get priority.
AnnotationReadingPriorityFunction(RSRpcServices) - Constructor for class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
Calls AnnotationReadingPriorityFunction(RSRpcServices, Class) using the result of rpcServices#getClass() The RPC server implementation
AnnotationReadingPriorityFunction(RSRpcServices, Class<? extends RSRpcServices>) - Constructor for class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
Constructs the priority function given the RPC server implementation and the annotations on the methods in the provided clz.
ANY - Enum constant in enum org.apache.hadoop.hbase.backup.BackupInfo.BackupState
 
ANY - Enum constant in enum org.apache.hadoop.hbase.regionserver.Region.Operation
 
ap - Variable in class org.apache.hadoop.hbase.client.BufferedMutatorImpl
 
ap - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
Deprecated.
 
aposBytes - Static variable in class org.apache.hadoop.hbase.http.HtmlQuoting
 
APP_DIR - Static variable in class org.apache.hadoop.hbase.http.HttpServer
 
appDir - Variable in class org.apache.hadoop.hbase.http.HttpServer
 
appDir - Variable in class org.apache.hadoop.hbase.http.HttpServer.Builder
 
append(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.io.hfile.HFileInfo
Append the given key/value pair to the file info, optionally checking the key prefix.
append(StringBuilder, String) - Method in class org.apache.hadoop.hbase.io.hfile.FixedFileTrailer
 
append(ByteBuffer, TAppend) - Method in class org.apache.hadoop.hbase.thrift2.ThriftHBaseServiceHandler
 
append(CacheEvictionStats) - Method in class org.apache.hadoop.hbase.CacheEvictionStatsAggregator
 
append(CacheEvictionStats) - Method in class org.apache.hadoop.hbase.CacheEvictionStatsBuilder
 
append(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.CompoundBloomFilterWriter
 
append(Cell) - Method in class org.apache.hadoop.hbase.io.hfile.HFileWriterImpl
Add key/value to file.
append(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.CellSink
Append the given cell
append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.DateTieredMultiFileWriter
 
append(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
 
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(Append) - Method in interface org.apache.hadoop.hbase.client.AsyncTable
Appends values to one or more columns within a single row.
append(Append) - Method in class org.apache.hadoop.hbase.client.AsyncTableImpl
 
append(Append) - Method in class org.apache.hadoop.hbase.client.HTable
 
append(Append) - Method in class org.apache.hadoop.hbase.client.RawAsyncTableImpl
 
append(Append) - Method in interface org.apache.hadoop.hbase.client.Table
Appends values to one or more columns within a single row.
append(Append) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
append(Append) - Method in interface org.apache.hadoop.hbase.regionserver.Region
Perform one or more append operations on a row.
append(Append) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftTable
 
append(Append, long, long) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
append(RegionInfo, WALKeyImpl, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
Append a set of edits to the WAL.
append(RegionInfo, WALKeyImpl, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
append(RegionInfo, WALKeyImpl, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog
 
append(RegionInfo, WALKeyImpl, WALEdit, boolean) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
 
append(HRegion, OperationQuota, ClientProtos.MutationProto, CellScanner, long, ActivePolicyEnforcement, RpcCallContext) - Method in class org.apache.hadoop.hbase.regionserver.RSRpcServices
Execute an append mutation.
append(FSWALEntry) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferEventHandler
Append to the WAL.
append(CellSetModel) - Method in class org.apache.hadoop.hbase.rest.RowResource
Validates the input request parameters, parses columns from CellSetModel, and invokes Append on HTable.
append(TableName, byte[], byte[], List<WAL.Entry>) - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaSinkWriter
 
append(TAppend) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
 
append(EntryBuffers.RegionEntryBuffer) - Method in class org.apache.hadoop.hbase.replication.regionserver.RegionReplicaReplicationEndpoint.RegionReplicaOutputSink
 
append(EntryBuffers.RegionEntryBuffer) - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredEditsOutputSink
 
append(EntryBuffers.RegionEntryBuffer) - Method in class org.apache.hadoop.hbase.wal.BoundedRecoveredHFilesOutputSink
 
append(EntryBuffers.RegionEntryBuffer) - Method in class org.apache.hadoop.hbase.wal.OutputSink
 
append(EntryBuffers.RegionEntryBuffer) - Method in class org.apache.hadoop.hbase.wal.RecoveredEditsOutputSink
 
append(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
 
append(WAL.Entry) - Method in class org.apache.hadoop.hbase.regionserver.wal.ProtobufLogWriter
 
append(WAL.Entry) - Method in interface org.apache.hadoop.hbase.wal.WALProvider.AsyncWriter
 
append(WAL.Entry) - Method in interface org.apache.hadoop.hbase.wal.WALProvider.Writer
 
append(TNode, TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
Append a node to the tree
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(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.client.Append
Create a Append operation for the specified row.
Append(byte[], long, NavigableMap<byte[], List<Cell>>) - Constructor for class org.apache.hadoop.hbase.client.Append
Construct the Append with user defined data.
Append(Append) - Constructor for class org.apache.hadoop.hbase.client.Append
Copy constructor
APPEND - Enum constant in enum org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType
 
APPEND - Enum constant in enum org.apache.hadoop.hbase.regionserver.Region.Operation
 
APPEND - Enum constant in enum org.apache.hadoop.hbase.regionserver.wal.RingBufferTruck.Type
 
APPEND - Enum constant in enum org.apache.hadoop.hbase.security.access.AccessController.OpType
 
APPEND - Enum constant in enum org.apache.hadoop.hbase.trace.HBaseSemanticAttributes.Operation
 
APPEND_BLOCK_BYTES_SCANNED_KEY - Variable in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
 
APPEND_BLOCK_BYTES_SCANNED_KEY - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
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_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 class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
 
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
 
appendAndSync() - Method in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
appendBlockBytesScanned - Variable in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
 
appendBlockBytesScanned - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
appendCount - Variable in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
 
appendData(RegionInfo, WALKeyImpl, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
appendData(RegionInfo, WALKeyImpl, WALEdit) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
 
appendData(RegionInfo, WALKeyImpl, WALEdit) - Method in interface org.apache.hadoop.hbase.wal.WAL
Append a set of data edits to the WAL.
appendDeleteFamilyBloomFilter(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
 
appendEntry(WAL.Entry) - Method in class org.apache.hadoop.hbase.wal.EntryBuffers
Append a log entry into the corresponding region buffer.
appendEntry(WAL.Entry) - Method in class org.apache.hadoop.hbase.wal.EntryBuffers.RegionEntryBuffer
 
appendEntry(W, FSWALEntry) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
appendExcludeTableCFsToReplicationPeerConfig(Map<TableName, List<String>>, ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
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.io.hfile.HFileWriterImpl
Add to the file info.
appendFileInfo(byte[], byte[]) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
 
appendFromHBase(Append) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
 
appendFromThrift(TAppend) - Static method in class org.apache.hadoop.hbase.thrift.ThriftUtilities
From a TAppend create an Append.
appendFromThrift(TAppend) - Static method in class org.apache.hadoop.hbase.thrift2.ThriftUtilities
 
appendGeneralBloomfilter(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
 
appendHFileRefsZNodes(ZKWatcher, String, StringBuilder) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKDump
 
appendHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerSourceImpl
 
appendHisto - Variable in class org.apache.hadoop.hbase.regionserver.MetricsUserSourceImpl
 
appendJRuby(StringBuilder, Object) - Static method in class org.apache.hadoop.hbase.util.JRubyFormat
 
appendKeyTo(Cell, byte[], int) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
 
appendKeyTo(Cell, ByteBuffer, 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.
appendList(TNode, TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
Append a list of nodes to the tree
appendMarker(RegionInfo, WALKeyImpl, WALEdit) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
appendMarker(RegionInfo, WALKeyImpl, WALEdit) - Method in class org.apache.hadoop.hbase.wal.DisabledWALProvider.DisabledWAL
 
appendMarker(RegionInfo, WALKeyImpl, WALEdit) - Method in interface org.apache.hadoop.hbase.wal.WAL
Append an operational 'meta' event marker edit to the WAL.
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.HFileWriterImpl
Add a meta block to the end of the file.
appendMetadata(long, boolean) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
Writes meta data.
appendMetadata(long, boolean, long) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
Writes meta data.
appendMetadata(long, boolean, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
Writes meta data.
appendMetaData(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKMetadata
 
appendMobMetadata(SetMultimap<TableName, String>) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
Appends MOB - specific metadata (even if it is empty)
appendPeerState(ZKWatcher, String, StringBuilder) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKDump
 
appendPeersZnodes(ZKWatcher, String, StringBuilder) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKDump
 
appendPeerTableCFs(String, String) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
as release of 2.0.0, and it will be removed in 3.0.0, use ReplicationAdmin.appendPeerTableCFs(String, Map) instead.
appendPeerTableCFs(String, Map<TableName, ? extends Collection<String>>) - Method in class org.apache.hadoop.hbase.client.replication.ReplicationAdmin
Deprecated.
appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.client.Admin
Append the replicable table column family config from the specified peer.
appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Append the replicable table-cf config of the specified peer
appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
 
appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
 
appendRSZnodes(ZKWatcher, String, StringBuilder) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKDump
 
appendSizeHisto - Variable in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
 
appendStrings(StringBuilder, String...) - Static method in class org.apache.hadoop.hbase.procedure2.util.StringUtils
 
appendTableCFsToReplicationPeerConfig(Map<TableName, List<String>>, ReplicationPeerConfig) - Static method in class org.apache.hadoop.hbase.client.replication.ReplicationPeerConfigUtil
 
appendThreadInfo(StringBuilder, ThreadInfo, String) - Static method in class org.apache.hadoop.hbase.monitoring.ThreadMonitoring
Print all of the thread's information and stack traces.
appendTimeHisto - Variable in class org.apache.hadoop.hbase.regionserver.wal.MetricsWALSourceImpl
 
appendTimeHistogram - Variable in class org.apache.hadoop.hbase.regionserver.metrics.MetricsTableRequests
 
appendTo(Cell, ByteBuffer, int, boolean) - Static method in class org.apache.hadoop.hbase.KeyValueUtil
Copy the Cell content into the passed buf in KeyValue serialization format.
appendToByteArray(Cell, byte[], int, boolean) - 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
 
appendTrackedTimestampsToMetadata() - Method in class org.apache.hadoop.hbase.regionserver.StoreFileWriter
Add TimestampRange and earliest put timestamp to Metadata
appendTracker - Variable in class org.apache.hadoop.hbase.client.MetricsConnection
 
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.
apply(FileStatus) - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.FileStatusConverter
 
apply(FileSystem, Path, List<AclEntry>) - Method in interface org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.HDFSAclOperation.Operation
 
apply(BackupInfo) - Method in interface org.apache.hadoop.hbase.backup.BackupInfo.Filter
Filter interface
apply(HStoreFile) - Method in class org.apache.hadoop.hbase.backup.HFileArchiver.StoreToFile
 
apply(HStoreFile) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileComparators.GetPathName
 
applyAsLong(HStoreFile) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileComparators.GetBulkTime
 
applyAsLong(HStoreFile) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileComparators.GetFileSize
 
applyAsLong(HStoreFile) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileComparators.GetMaxTimestamp
 
applyBatch(long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
Convience method to change metrics when a batch of operations are applied.
applyBatch(long, long) - Method in class org.apache.hadoop.hbase.replication.regionserver.MetricsSink
Convience method to change metrics when a batch of operations are applied.
applyClusterKeyToConf(Configuration, String) - Static method in class org.apache.hadoop.hbase.HBaseConfiguration
Apply the settings in the given key to the given configuration, this is used to communicate with distant clusters
applyCompactionPolicy(ArrayList<HStoreFile>, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.ExploringCompactionPolicy
 
applyCompactionPolicy(ArrayList<HStoreFile>, boolean, boolean) - Method in class org.apache.hadoop.hbase.regionserver.compactions.RatioBasedCompactionPolicy
-- Default minor compaction selection algorithm: choose CompactSelection from candidates -- First exclude bulk-load files if indicated in configuration.
applyCompactionPolicy(List<HStoreFile>, boolean, boolean, int, int) - Method in class org.apache.hadoop.hbase.regionserver.compactions.ExploringCompactionPolicy
 
applyCostsChange(Consumer<double[]>) - Method in class org.apache.hadoop.hbase.master.balancer.DoubleArrayCost
We do not want to introduce a getCosts method to let upper layer get the cost array directly, so here we introduce this method to take a Consumer as parameter, where we will pass the actual cost array in, so you can change the element of the cost array in the Consumer implementation.
applyFamilyMapToMemStore(Map<byte[], List<Cell>>, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
Atomically apply the given map of family->edits to the memstore.
applyFilterAndGet(List<Record>, List<RecordFilter>) - Static method in class org.apache.hadoop.hbase.hbtop.mode.ModeStrategyUtils
Filter records as per the supplied filters,
applyToMemStore(HStore, List<Cell>, boolean, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
applyToMemStore(HStore, Cell, MemStoreSizing) - Method in class org.apache.hadoop.hbase.regionserver.HRegion
 
archive - Variable in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer
 
archive(String) - Method in class org.apache.hadoop.hbase.master.SplitWALManager
Archive processed WAL
archive(FileSystem, RegionInfo, byte[], Collection<HStoreFile>, Path) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
 
archive(Path, boolean, Path, FileSystem, Configuration) - Static method in class org.apache.hadoop.hbase.wal.WALSplitUtil
Moves processed logs to a oldLogDir after successful processing Moves corrupted logs (any log that couldn't be successfully parsed to corruptDir (.corrupt) for later investigation
archive(Pair<Path, Long>) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
ARCHIVED_HFILE_SUFFIX - Static variable in class org.apache.hadoop.hbase.master.region.MasterRegionFactory
 
ARCHIVED_WAL_SUFFIX - Static variable in class org.apache.hadoop.hbase.master.region.MasterRegionFactory
 
archiveDataDir - Variable in class org.apache.hadoop.hbase.security.access.SnapshotScannerHDFSAclHelper.PathHelper
 
archivedHFileSuffix - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionFlusherAndCompactor
 
archivedHFileSuffix - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionParams
 
archivedHFileSuffix() - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
 
archivedHFileSuffix(String) - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
 
archivedTables - Variable in class org.apache.hadoop.hbase.backup.example.HFileArchiveTableMonitor
 
archivedWalSuffix - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionParams
 
archivedWalSuffix() - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
 
archivedWalSuffix(String) - Method in class org.apache.hadoop.hbase.master.region.MasterRegionParams
 
archivedWALSuffix - Variable in class org.apache.hadoop.hbase.master.region.MasterRegionWALRoller
 
archiveExecutor - Static variable in class org.apache.hadoop.hbase.backup.HFileArchiver
 
archiveFamily(FileSystem, Configuration, RegionInfo, 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
archiveFamilyByFamilyDir(FileSystem, Configuration, RegionInfo, Path, byte[]) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Removes from the specified region the store files of the specified column family, either by archiving them or outright deletion
archiveHFileZNode - Variable in class org.apache.hadoop.hbase.backup.example.TableHFileArchiveTracker
 
archiveLock - Variable in class org.apache.hadoop.hbase.regionserver.HStore
Lock specific to archiving compacted store files.
archiveLogFile(Path) - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
archiveMetaLog(ServerName) - Method in class org.apache.hadoop.hbase.master.MasterWalManager
The hbase:meta region may OPEN and CLOSE without issue on a server and then move elsewhere.
archiveMobFiles(Configuration, TableName, byte[], List<Path>) - Method in class org.apache.hadoop.hbase.mob.RSMobFileCleanerChore
Archives the mob files.
archiveMobFiles(Configuration, TableName, Admin, byte[], List<Path>) - Static method in class org.apache.hadoop.hbase.mob.MobFileCleanupUtil
Archives the mob files.
archivePath - Variable in class org.apache.hadoop.hbase.io.HFileLink
 
archiveRecoveredEdits(String, Collection<HStoreFile>) - Method in class org.apache.hadoop.hbase.regionserver.HRegionWALFileSystem
Closes and archives the specified store files from the specified family.
archiveRecoveredEdits(Configuration, FileSystem, RegionInfo, byte[], Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Archive recovered edits using existing logic for archiving store files.
archiveRegion(Configuration, FileSystem, RegionInfo) - 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.
archiveRegions(Configuration, FileSystem, Path, Path, List<Path>) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Archive the specified regions in parallel.
archiveRetries - Variable in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
 
archiveStoreFile(Configuration, FileSystem, RegionInfo, Path, byte[], Path) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Archive the store file
archiveStoreFiles(Configuration, FileSystem, RegionInfo, Path, byte[], Collection<HStoreFile>) - Static method in class org.apache.hadoop.hbase.backup.HFileArchiver
Remove the store files, either by archiving them or outright deletion
archiveTracker - Variable in class org.apache.hadoop.hbase.backup.example.LongTermArchivingHFileCleaner
 
archiveZnode - Variable in class org.apache.hadoop.hbase.backup.example.HFileArchiveManager
 
areAdjacent(RegionInfo, RegionInfo) - Static method in interface org.apache.hadoop.hbase.client.RegionInfo
Check whether two regions are adjacent; i.e.
areAdjacent(HRegionInfo, HRegionInfo) - Static method in class org.apache.hadoop.hbase.HRegionInfo
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0 Use RegionInfo.areAdjacent(RegionInfo, RegionInfo).
areAllLower(Map<byte[], Long>) - Method in class org.apache.hadoop.hbase.regionserver.wal.SequenceIdAccounting
See if passed sequenceids are lower -- i.e.
areAllUserRegionsOffline() - Method in class org.apache.hadoop.hbase.regionserver.HRegionServer
 
areCompactionsDisabled() - Method in class org.apache.hadoop.hbase.quotas.policies.AbstractViolationPolicyEnforcement
 
areCompactionsDisabled() - Method in class org.apache.hadoop.hbase.quotas.policies.NoWritesCompactionsViolationPolicyEnforcement
 
areCompactionsDisabled() - Method in interface org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
Returns whether or not compactions on this table should be disabled for this policy.
areCompactionsDisabled(TableName) - Method in class org.apache.hadoop.hbase.quotas.RegionServerSpaceQuotaManager
Returns whether or not compactions should be disabled for the given tableName per a space quota violation policy.
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.
arePartsEqual(ByteBuffer, int, int, int, int) - Static method in class org.apache.hadoop.hbase.util.ByteBufferUtils
Deprecated.
Check whether two parts in the same buffer are equal.
areScanStartRowAndStopRowEqual(byte[], byte[]) - Static method in class org.apache.hadoop.hbase.client.ClientUtil
 
areSerializedFieldsEqual(BigDecimalComparator) - Method in class org.apache.hadoop.hbase.filter.BigDecimalComparator
Returns true if and only if the fields of the comparator that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(ByteArrayComparable) - Method in class org.apache.hadoop.hbase.filter.BinaryComparator
Returns true if and only if the fields of the comparator that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(ByteArrayComparable) - Method in class org.apache.hadoop.hbase.filter.BinaryComponentComparator
Returns true if and only if the fields of the comparator that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(ByteArrayComparable) - Method in class org.apache.hadoop.hbase.filter.BinaryPrefixComparator
Returns true if and only if the fields of the comparator that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(ByteArrayComparable) - Method in class org.apache.hadoop.hbase.filter.BitComparator
Returns true if and only if the fields of the comparator that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(ByteArrayComparable) - Method in class org.apache.hadoop.hbase.filter.ByteArrayComparable
Return true if and only if the fields of the comparator that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(ByteArrayComparable) - Method in class org.apache.hadoop.hbase.filter.NullComparator
Returns true if and only if the fields of the comparator that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(ByteArrayComparable) - Method in class org.apache.hadoop.hbase.filter.RegexStringComparator
Returns true if and only if the fields of the comparator that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(ByteArrayComparable) - Method in class org.apache.hadoop.hbase.filter.SubstringComparator
Returns true if and only if the fields of the comparator that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.ColumnCountGetFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.ColumnPaginationFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.ColumnPrefixFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.ColumnRangeFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.ColumnValueFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.CompareFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.DependentColumnFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.FamilyFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.Filter
Concrete implementers can signal a failure condition in their code by throwing an IOException.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterBase
Default implementation so that writers of custom filters aren't forced to implement.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterList
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.FilterWrapper
 
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.FirstKeyOnlyFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.FirstKeyValueMatchingQualifiersFilter
Deprecated.
 
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.FuzzyRowFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.InclusiveStopFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.KeyOnlyFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.MultipleColumnPrefixFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.MultiRowRangeFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.PageFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.PrefixFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.QualifierFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.RandomRowFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.RowFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueExcludeFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.SingleColumnValueFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.SkipFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.TimestampsFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.ValueFilter
Returns true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(Filter) - Method in class org.apache.hadoop.hbase.filter.WhileMatchFilter
Return true if and only if the fields of the filter that are serialized are equal to the corresponding fields in other.
areSerializedFieldsEqual(LongComparator) - Method in class org.apache.hadoop.hbase.filter.LongComparator
Returns true if and only if the fields of the comparator that are serialized are equal to the corresponding fields in other.
areSomeRegionReplicasColocated(BalancerClusterState) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
 
areSplittersAvailable() - Method in class org.apache.hadoop.hbase.coordination.ZkSplitLogWorkerCoordination
Returns true if more splitters are available, otherwise false.
areSyncFuturesReleased() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.SyncRunner
 
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
 
argClass - Variable in class org.apache.hadoop.hbase.util.ReflectedFunctionCache
 
args - Variable in class org.apache.hadoop.hbase.procedure.Procedure
 
Args(TServerTransport, Configuration) - Constructor for class org.apache.hadoop.hbase.thrift.TBoundedThreadPoolServer.Args
 
argumentToClassMap - Variable in class org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
 
array() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
Returns the byte[] if the underlying BB has single BB and hasArray true
array() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
 
array() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
 
ARRAY - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Array overhead
ARRAY_BYTE_INDEX_SCALE - Static variable in class org.apache.hadoop.hbase.util.ClassSize.UnsafeLayout
 
ARRAY_MAP - Enum constant in enum org.apache.hadoop.hbase.regionserver.CompactingMemStore.IndexType
 
ARRAY_OBJECT_INDEX_SCALE - Static variable in class org.apache.hadoop.hbase.util.ClassSize.UnsafeLayout
 
ArrayBackedTag - Class in org.apache.hadoop.hbase
This is a Tag implementation in which value is backed by an on heap byte array.
ArrayBackedTag(byte[], int) - Constructor for class org.apache.hadoop.hbase.ArrayBackedTag
Creates a Tag from the specified byte array and offset.
ArrayBackedTag(byte[], int, int) - Constructor for class org.apache.hadoop.hbase.ArrayBackedTag
Creates a Tag from the specified byte array, starting at offset, and for length length.
ArrayBackedTag(byte, byte[]) - Constructor for class org.apache.hadoop.hbase.ArrayBackedTag
Format for a tag : <length of tag - 2 bytes><type code - 1 byte><tag> tag length is serialized using 2 bytes only but as this will be unsigned, we can have max tag length of (Short.MAX_SIZE * 2) +1.
ArrayBackedTag(byte, String) - Constructor for class org.apache.hadoop.hbase.ArrayBackedTag
The special tag will write the length of each tag and that will be followed by the type and then the actual tag.
ArrayEntryIterator(CopyOnWriteArrayMap.ArrayHolder<K, V>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntryIterator
 
ArrayEntrySet(CopyOnWriteArrayMap.ArrayHolder<K, V>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayEntrySet
 
arrayHeaderSize() - Method in class org.apache.hadoop.hbase.util.ClassSize.MemoryLayout
 
arrayHeaderSize() - Method in class org.apache.hadoop.hbase.util.ClassSize.UnsafeLayout
 
ArrayHolder(Comparator<? super K>, Comparator<Map.Entry<K, V>>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayHolder
 
ArrayHolder(CopyOnWriteArrayMap.COWEntry[], int, int, Comparator<? super K>, Comparator<Map.Entry<K, V>>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayHolder
 
ArrayKeyIterator(CopyOnWriteArrayMap.ArrayHolder<K, V>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeyIterator
 
ArrayKeySet(CopyOnWriteArrayMap.ArrayHolder<K, V>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayKeySet
 
ARRAYLIST - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for ArrayList(0)
arrayOffset() - Method in class org.apache.hadoop.hbase.nio.ByteBuff
Returns the arrayOffset of the byte[] incase of a single BB backed ByteBuff
arrayOffset() - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
 
arrayOffset() - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
 
ArrayValueCollection(CopyOnWriteArrayMap.ArrayHolder<K, V>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueCollection
 
ArrayValueIterator(CopyOnWriteArrayMap.ArrayHolder<K, V>) - Constructor for class org.apache.hadoop.hbase.types.CopyOnWriteArrayMap.ArrayValueIterator
 
arrowDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
 
arrowDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
 
arrowDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
arrowDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
 
arrowDown() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
ArrowDown - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
arrowLeft() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
arrowLeft() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
ArrowLeft - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
arrowRight() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
arrowRight() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
ArrowRight - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
arrowUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.field.FieldScreenPresenter
 
arrowUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.mode.ModeScreenPresenter
 
arrowUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
arrowUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.Paging
 
arrowUp() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenPresenter
 
ArrowUp - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
ASC - Enum constant in enum org.apache.hadoop.hbase.filter.FuzzyRowFilter.Order
 
ASCENDING - Enum constant in enum org.apache.hadoop.hbase.util.Order
 
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
 
ascendingSort - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.TopScreenModel
 
asFloat() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
asInt() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
asInterrupt(Throwable) - Static method in class org.apache.hadoop.hbase.util.ExceptionUtil
Returns an InterruptedIOException if t was an interruption, null otherwise
asList(byte[], int, int) - Static method in class org.apache.hadoop.hbase.TagUtil
Creates list of tags from given byte array, expected that it is in the expected tag format.
asLong() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
asReferencedHeapBlock(Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
The block cached in LruAdaptiveBlockCache will always be an heap block: on the one side, the heap access will be more faster then off-heap, the small index block or meta block cached in CombinedBlockCache will benefit a lot.
asReferencedHeapBlock(Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
The block cached in LRUBlockCache will always be an heap block: on the one side, the heap access will be more faster then off-heap, the small index block or meta block cached in CombinedBlockCache will benefit a lot.
asReferencedHeapBlock(Cacheable) - Method in class org.apache.hadoop.hbase.io.hfile.TinyLfuBlockCache
The block cached in TinyLfuBlockCache will always be an heap block: on the one side, the heap access will be more faster then off-heap, the small index block or meta block cached in CombinedBlockCache will benefit a lot.
asSeparateLines(String) - Static method in class org.apache.hadoop.hbase.io.hfile.HFilePrettyPrinter
Format a string of the form "k1=v1, k2=v2, ..." into separate lines with a four-space indentation.
assertBulkLoadHFileOk(Path) - Method in class org.apache.hadoop.hbase.regionserver.HStore
This throws a WrongRegionException if the HFile does not fit in this region, or an InvalidHFileException if the HFile is not valid.
assertCounterSanity(long, long) - Static method in class org.apache.hadoop.hbase.io.hfile.LruAdaptiveBlockCache
Sanity-checking for parity between actual block cache content and metrics.
assertCounterSanity(long, long) - Static method in class org.apache.hadoop.hbase.io.hfile.LruBlockCache
Sanity-checking for parity between actual block cache content and metrics.
assertMapEmpty() - Method in class org.apache.hadoop.hbase.util.IdLock
 
assertSeeked() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.HFileScannerImpl
 
assertSnapshotRequestIsValid(SnapshotProtos.SnapshotDescription) - Static method in class org.apache.hadoop.hbase.snapshot.ClientSnapshotDescriptionUtils
Check to make sure that the description of the snapshot requested is valid
assertSplitResultFilesCount(FileSystem, int, Path) - Method in class org.apache.hadoop.hbase.master.assignment.SplitTableRegionProcedure
 
assertValidSeek() - Method in class org.apache.hadoop.hbase.io.hfile.HFileReaderImpl.EncodedScanner
 
assign(byte[]) - Method in interface org.apache.hadoop.hbase.client.Admin
Assign a Region.
assign(byte[]) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Assign an individual region.
assign(byte[]) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
 
assign(byte[]) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
assign(byte[]) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
 
assign(byte[]) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
 
assign(Collection<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.MaintenanceLoadBalancer
 
assign(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
assign(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
assign(MasterProcedureEnv, RegionInfo, boolean, ServerName) - Static method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
 
assign(MasterProcedureEnv, RegionInfo, ServerName) - Static method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
 
ASSIGN - Enum constant in enum org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure.TransitionType
 
ASSIGN_DISPATCH_WAIT_MSEC_CONF_KEY - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
ASSIGN_DISPATCH_WAITQ_MAX_CONF_KEY - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
ASSIGN_MAX_ATTEMPTS - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
ASSIGN_METRIC_PREFIX - Static variable in interface org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
 
ASSIGN_RANDOM_PORTS - Static variable in class org.apache.hadoop.hbase.LocalHBaseCluster
 
ASSIGN_REGION - Enum constant in enum org.apache.hadoop.hbase.master.balancer.BalanceAction.Type
 
ASSIGN_RETRY_IMMEDIATELY_MAX_ATTEMPTS - Static variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
ASSIGN_SEQ_IDS - Static variable in interface org.apache.hadoop.hbase.tool.BulkLoadHFiles
 
ASSIGN_SEQ_IDS - Static variable in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
Deprecated.
 
assignAsync(RegionInfo) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
Submits a procedure that assigns a region without waiting for it to finish
assignAsync(RegionInfo, ServerName) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
Submits a procedure that assigns a region to a target server without waiting for it to finish
assignCandidate - Variable in class org.apache.hadoop.hbase.master.assignment.CloseRegionProcedure
 
assignCandidate - Variable in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
 
assignDispatchWaitMillis - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
assignDispatchWaitQueueMaxSize - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
assignMasterSystemRegions(Collection<RegionInfo>, List<ServerName>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
Deprecated.
since 2.4.0, will be removed in 3.0.0.
assignMaxAttempts - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
assignmentManager - Variable in class org.apache.hadoop.hbase.master.HMaster
 
AssignmentManager - Class in org.apache.hadoop.hbase.master.assignment
The AssignmentManager is the coordinator for region assign/unassign operations.
AssignmentManager(MasterServices, MasterRegion) - Constructor for class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
AssignmentManager(MasterServices, MasterRegion, RegionStateStore) - Constructor for class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
AssignmentManager.DeadServerMetricRegionChore - Class in org.apache.hadoop.hbase.master.assignment
 
AssignmentManager.RegionInTransitionChore - Class in org.apache.hadoop.hbase.master.assignment
 
AssignmentManager.RegionInTransitionStat - Class in org.apache.hadoop.hbase.master.assignment
 
AssignmentManager.RegionMetaLoadingVisitor - Class in org.apache.hadoop.hbase.master.assignment
 
assignmentManagerSource - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
 
AssignmentManagerUtil - Class in org.apache.hadoop.hbase.master.assignment
Utility for this assignment package only.
AssignmentManagerUtil() - Constructor for class org.apache.hadoop.hbase.master.assignment.AssignmentManagerUtil
 
AssignmentProcedureEvent(RegionInfo) - Constructor for class org.apache.hadoop.hbase.master.assignment.RegionStateNode.AssignmentProcedureEvent
 
assignments - Variable in class org.apache.hadoop.hbase.util.MunkresAssignment
 
AssignmentVerificationReport - Class in org.apache.hadoop.hbase.master
Helper class that is used by RegionPlacementMaintainer to print information for favored nodes
AssignmentVerificationReport() - Constructor for class org.apache.hadoop.hbase.master.AssignmentVerificationReport
 
assignMetaReplica(int) - Method in class org.apache.hadoop.hbase.util.HBaseFsck
Deprecated.
 
assignMetrics - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
 
assignNewReplicasIfNeeded(MasterProcedureEnv) - Method in class org.apache.hadoop.hbase.master.procedure.ModifyTableProcedure
 
AssignProcedure - Class in org.apache.hadoop.hbase.master.assignment
Deprecated.
Do not use any more.
AssignProcedure() - Constructor for class org.apache.hadoop.hbase.master.assignment.AssignProcedure
Deprecated.
 
assignProcMetrics - Variable in class org.apache.hadoop.hbase.master.MetricsAssignmentManager
 
assignQueueFullCond - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
assignQueueLock - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
assignQueueSignal() - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
assignRegion(RpcController, MasterProtos.AssignRegionRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
assignRegion(RpcController, MasterProtos.AssignRegionRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
AssignRegionAction - Class in org.apache.hadoop.hbase.master.balancer
 
AssignRegionAction(int, int) - Constructor for class org.apache.hadoop.hbase.master.balancer.AssignRegionAction
 
AssignRegionHandler - Class in org.apache.hadoop.hbase.regionserver.handler
Handles opening of a region on a region server.
AssignRegionHandler(HRegionServer, RegionInfo, long, TableDescriptor, long, EventType) - Constructor for class org.apache.hadoop.hbase.regionserver.handler.AssignRegionHandler
 
assignRegions(MasterProcedureEnv, List<RegionInfo>) - Method in class org.apache.hadoop.hbase.master.procedure.ServerCrashProcedure
Assign the regions on the crashed RS to other Rses.
assignRegionToAvailableFavoredNode(Map<ServerName, List<RegionInfo>>, RegionInfo, ServerName, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
 
assignRegionToAvailableFavoredNode(Map<ServerName, List<RegionInfo>>, RegionInfo, ServerName, ServerName, ServerName) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
 
assignRetryImmediatelyMaxAttempts - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
assigns(List<String>) - Method in interface org.apache.hadoop.hbase.client.Hbck
 
assigns(List<String>, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseHbck
 
assigns(List<String>, boolean) - Method in interface org.apache.hadoop.hbase.client.Hbck
Like Admin.assign(byte[]) but 'raw' in that it can do more than one Region at a time -- good if many Regions to online -- and it will schedule the assigns even in the case where Master is initializing (as long as the ProcedureExecutor is up).
assigns(RpcController, MasterProtos.AssignsRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
A 'raw' version of assign that does bulk and can skirt Master state checks if override is set; i.e.
assignSecondaryAndTertiaryNodesForRegion(FavoredNodeAssignmentHelper, List<RegionInfo>, Map<RegionInfo, ServerName>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
 
assignSeqIds - Variable in class org.apache.hadoop.hbase.tool.LoadIncrementalHFiles
Deprecated.
 
assignTableToGroup(TableDescriptor) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint
 
assignThread - Variable in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
asSize() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
asString() - Method in class org.apache.hadoop.hbase.hbtop.field.FieldValue
 
asSubByteBuffer(int) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
Returns bytes from current position till length specified, as a single ByteBuffer.
asSubByteBuffer(int) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
Returns bytes from current position till length specified, as a single ByteBuffer.
asSubByteBuffer(int) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
 
asSubByteBuffer(int, int, ObjectIntPair<ByteBuffer>) - Method in class org.apache.hadoop.hbase.nio.ByteBuff
Returns bytes from given offset till length specified, as a single ByteBuffer.
asSubByteBuffer(int, int, ObjectIntPair<ByteBuffer>) - Method in class org.apache.hadoop.hbase.nio.MultiByteBuff
Returns bytes from given offset till length specified, as a single ByteBuffer.
asSubByteBuffer(int, int, ObjectIntPair<ByteBuffer>) - Method in class org.apache.hadoop.hbase.nio.SingleByteBuff
 
asSubByteBuffers(long, int) - Method in class org.apache.hadoop.hbase.util.ByteBufferArray
Creates a sub-array from a given array of ByteBuffers from the given offset to the length specified.
ASTERICK - Static variable in class org.apache.hadoop.hbase.util.JSONBean
 
ASYNC - Enum constant in enum org.apache.hadoop.hbase.master.MasterRpcServices.BalanceSwitchMode
 
ASYNC_DFS_OUTPUT_CREATE_MAX_RETRIES - Static variable in class org.apache.hadoop.hbase.io.asyncfs.FanOutOneBlockAsyncDFSOutputHelper
 
ASYNC_PROFILER_HOME_ENV - Static variable in class org.apache.hadoop.hbase.http.ProfileServlet
 
ASYNC_PROFILER_HOME_SYSTEM_PROPERTY - Static variable in class org.apache.hadoop.hbase.http.ProfileServlet
 
ASYNC_WAL - Enum constant in enum org.apache.hadoop.hbase.client.Durability
Write the Mutation to the WAL asynchronously
ASYNC_WAL_USE_SHARED_EVENT_LOOP - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
ASYNC_WAL_WAIT_ON_SHUTDOWN_IN_SECONDS - Static variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
asyncAdmin - Variable in class org.apache.hadoop.hbase.master.http.RegionVisualizer
 
AsyncAdmin - Interface in org.apache.hadoop.hbase.client
The asynchronous administrative API for HBase.
AsyncAdminBuilder - Interface in org.apache.hadoop.hbase.client
For creating AsyncAdmin.
AsyncAdminBuilderBase - Class in org.apache.hadoop.hbase.client
Base class for all asynchronous admin builders.
AsyncAdminBuilderBase(AsyncConnectionConfiguration) - Constructor for class org.apache.hadoop.hbase.client.AsyncAdminBuilderBase
 
AsyncAdminClientUtils - Class in org.apache.hadoop.hbase.client
Additional Asynchronous Admin capabilities for clients.
AsyncAdminClientUtils() - Constructor for class org.apache.hadoop.hbase.client.AsyncAdminClientUtils
 
AsyncAdminRequestRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
 
AsyncAdminRequestRetryingCaller(Timer, AsyncConnectionImpl, int, long, long, int, long, long, int, ServerName, AsyncAdminRequestRetryingCaller.Callable<T>) - Constructor for class org.apache.hadoop.hbase.client.AsyncAdminRequestRetryingCaller
 
AsyncAdminRequestRetryingCaller.Callable<T> - Interface in org.apache.hadoop.hbase.client
 
AsyncBatchRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
Retry caller for batch.
AsyncBatchRpcRetryingCaller(Timer, AsyncConnectionImpl, TableName, List<? extends Row>, long, long, int, long, long, int, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.client.AsyncBatchRpcRetryingCaller
 
AsyncBatchRpcRetryingCaller.RegionRequest - Class in org.apache.hadoop.hbase.client
 
AsyncBatchRpcRetryingCaller.ServerRequest - Class in org.apache.hadoop.hbase.client
 
AsyncBufferedMutator - Interface in org.apache.hadoop.hbase.client
Used to communicate with a single HBase table in batches.
AsyncBufferedMutatorBuilder - Interface in org.apache.hadoop.hbase.client
For creating AsyncBufferedMutator.
AsyncBufferedMutatorBuilderImpl - Class in org.apache.hadoop.hbase.client
The implementation of AsyncBufferedMutatorBuilder.
AsyncBufferedMutatorBuilderImpl(AsyncConnectionConfiguration, AsyncTableBuilder<?>, HashedWheelTimer) - Constructor for class org.apache.hadoop.hbase.client.AsyncBufferedMutatorBuilderImpl
 
AsyncBufferedMutatorImpl - Class in org.apache.hadoop.hbase.client
The implementation of AsyncBufferedMutator.
AsyncBufferedMutatorImpl(HashedWheelTimer, AsyncTable<?>, long, long, int) - Constructor for class org.apache.hadoop.hbase.client.AsyncBufferedMutatorImpl
 
AsyncClientExample - Class in org.apache.hadoop.hbase.client.example
A simple example shows how to use asynchronous client.
AsyncClientExample() - Constructor for class org.apache.hadoop.hbase.client.example.AsyncClientExample
 
AsyncClientScanner - Class in org.apache.hadoop.hbase.client
The asynchronous client scanner implementation.
AsyncClientScanner(Scan, AdvancedScanResultConsumer, TableName, AsyncConnectionImpl, Timer, long, long, int, long, long, int, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.client.AsyncClientScanner
 
AsyncClientScanner.OpenScannerResponse - Class in org.apache.hadoop.hbase.client
 
AsyncConnection - Interface in org.apache.hadoop.hbase.client
The asynchronous version of Connection.
AsyncConnectionConfiguration - Class in org.apache.hadoop.hbase.client
Timeout configs.
AsyncConnectionConfiguration(Configuration) - Constructor for class org.apache.hadoop.hbase.client.AsyncConnectionConfiguration
 
AsyncConnectionImpl - Class in org.apache.hadoop.hbase.client
The implementation of AsyncConnection.
AsyncConnectionImpl(Configuration, ConnectionRegistry, String, User) - Constructor for class org.apache.hadoop.hbase.client.AsyncConnectionImpl
 
AsyncConnectionImpl(Configuration, ConnectionRegistry, String, User, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.client.AsyncConnectionImpl
 
asyncCreate(ZKWatcher, String, byte[], AsyncCallback.StringCallback, Object) - Static method in class org.apache.hadoop.hbase.zookeeper.ZKUtil
Async creates the specified node with the specified data.
asyncDecode(CachedData) - Method in class org.apache.hadoop.hbase.io.hfile.MemcachedBlockCache.HFileBlockTranscoder
 
asyncfs - Enum constant in enum org.apache.hadoop.hbase.wal.WALFactory.Providers
 
AsyncFSOutput - Interface in org.apache.hadoop.hbase.io.asyncfs
Interface for asynchronous filesystem output stream.
AsyncFSOutputHelper - Class in org.apache.hadoop.hbase.io.asyncfs
Helper class for creating AsyncFSOutput.
AsyncFSOutputHelper() - Constructor for class org.apache.hadoop.hbase.io.asyncfs.AsyncFSOutputHelper
 
AsyncFSWAL - Class in org.apache.hadoop.hbase.regionserver.wal
An asynchronous implementation of FSWAL.
AsyncFSWAL(FileSystem, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String, EventLoopGroup, Class<? extends Channel>) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
AsyncFSWAL(FileSystem, Abortable, Path, String, String, Configuration, List<WALActionsListener>, boolean, String, String, EventLoopGroup, Class<? extends Channel>, StreamSlowMonitor) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AsyncFSWAL
 
AsyncFSWALProvider - Class in org.apache.hadoop.hbase.wal
A WAL provider that use AsyncFSWAL.
AsyncFSWALProvider() - Constructor for class org.apache.hadoop.hbase.wal.AsyncFSWALProvider
 
AsyncFSWALProvider.AsyncWriter - Interface in org.apache.hadoop.hbase.wal
 
asyncGetBlockDistribution(RegionInfo) - Method in class org.apache.hadoop.hbase.master.balancer.RegionLocationFinder
 
AsyncHBaseAdmin - Class in org.apache.hadoop.hbase.client
Just a wrapper of RawAsyncHBaseAdmin.
AsyncHBaseAdmin(RawAsyncHBaseAdmin, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
 
AsyncMasterRequestRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
Retry caller for a request call to master.
AsyncMasterRequestRpcRetryingCaller(Timer, AsyncConnectionImpl, AsyncMasterRequestRpcRetryingCaller.Callable<T>, int, long, long, int, long, long, int) - Constructor for class org.apache.hadoop.hbase.client.AsyncMasterRequestRpcRetryingCaller
 
AsyncMasterRequestRpcRetryingCaller.Callable<T> - Interface in org.apache.hadoop.hbase.client
 
AsyncMetaRegionLocator - Class in org.apache.hadoop.hbase.client
The asynchronous locator for meta region.
AsyncMetaRegionLocator(ConnectionRegistry) - Constructor for class org.apache.hadoop.hbase.client.AsyncMetaRegionLocator
 
AsyncMetaTableAccessor - Class in org.apache.hadoop.hbase
The asynchronous meta table accessor.
AsyncMetaTableAccessor() - Constructor for class org.apache.hadoop.hbase.AsyncMetaTableAccessor
 
AsyncMetaTableAccessor.MetaTableScanResultConsumer - Class in org.apache.hadoop.hbase
 
AsyncNonMetaRegionLocator - Class in org.apache.hadoop.hbase.client
The asynchronous locator for regions other than meta.
AsyncNonMetaRegionLocator(AsyncConnectionImpl) - Constructor for class org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
 
AsyncNonMetaRegionLocator.LocateRequest - Class in org.apache.hadoop.hbase.client
 
AsyncNonMetaRegionLocator.RegionLocationsFutureResult - Class in org.apache.hadoop.hbase.client
 
AsyncNonMetaRegionLocator.TableCache - Class in org.apache.hadoop.hbase.client
 
asyncOutputWrapper - Variable in class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
 
asyncPrefetch - Variable in class org.apache.hadoop.hbase.client.Scan
 
asyncProcess - Variable in class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
 
asyncProcess - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
 
AsyncProcess - Class in org.apache.hadoop.hbase.client
This class allows a continuous flow of requests.
AsyncProcess(ClusterConnection, Configuration, RpcRetryingCallerFactory, RpcControllerFactory) - Constructor for class org.apache.hadoop.hbase.client.AsyncProcess
 
AsyncProcess(ClusterConnection, Configuration, RpcRetryingCallerFactory, RpcControllerFactory, int) - Constructor for class org.apache.hadoop.hbase.client.AsyncProcess
 
asyncProcessNodeUpdate(Runnable) - Method in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
 
AsyncProcessTask<T> - Class in org.apache.hadoop.hbase.client
Contains the attributes of a task which will be executed by AsyncProcess.
AsyncProcessTask(ExecutorService, TableName, RowAccess<? extends Row>, AsyncProcessTask.SubmittedRows, Batch.Callback<T>, CancellableRegionServerCallable, boolean, int, int, Object[], Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.client.AsyncProcessTask
 
AsyncProcessTask(AsyncProcessTask<T>) - Constructor for class org.apache.hadoop.hbase.client.AsyncProcessTask
 
AsyncProcessTask.Builder<T> - Class in org.apache.hadoop.hbase.client
 
AsyncProcessTask.ListRowAccess<T> - Class in org.apache.hadoop.hbase.client
 
AsyncProcessTask.SubmittedRows - Enum in org.apache.hadoop.hbase.client
The number of processed rows.
asyncProfilerHome - Variable in class org.apache.hadoop.hbase.http.ProfileServlet
 
AsyncProtobufLogWriter - Class in org.apache.hadoop.hbase.regionserver.wal
AsyncWriter for protobuf-based WAL.
AsyncProtobufLogWriter(EventLoopGroup, Class<? extends Channel>) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.AsyncProtobufLogWriter
 
AsyncProtobufLogWriter.OutputStreamWrapper - Class in org.apache.hadoop.hbase.regionserver.wal
 
AsyncRegionLocationCache - Class in org.apache.hadoop.hbase.client
Cache of RegionLocations for use by AsyncNonMetaRegionLocator.
AsyncRegionLocationCache(TableName) - Constructor for class org.apache.hadoop.hbase.client.AsyncRegionLocationCache
 
AsyncRegionLocator - Class in org.apache.hadoop.hbase.client
The asynchronous region locator.
AsyncRegionLocator(AsyncConnectionImpl, HashedWheelTimer) - Constructor for class org.apache.hadoop.hbase.client.AsyncRegionLocator
 
AsyncRegionLocatorHelper - Class in org.apache.hadoop.hbase.client
Helper class for asynchronous region locator.
AsyncRegionLocatorHelper() - Constructor for class org.apache.hadoop.hbase.client.AsyncRegionLocatorHelper
 
AsyncRequestFuture - Interface in org.apache.hadoop.hbase.client
The context used to wait for results from one submit call.
AsyncRequestFutureImpl<CResult> - Class in org.apache.hadoop.hbase.client
The context, and return value, for a single submit/submitAll call.
AsyncRequestFutureImpl(AsyncProcessTask, List<Action>, long, AsyncProcess) - Constructor for class org.apache.hadoop.hbase.client.AsyncRequestFutureImpl
 
AsyncRequestFutureImpl.ReplicaCallIssuingRunnable - Class in org.apache.hadoop.hbase.client
Runnable (that can be submitted to thread pool) that waits for when it's time to issue replica calls, finds region replicas, groups the requests by replica and issues the calls (on separate threads, via sendMultiAction).
AsyncRequestFutureImpl.ReplicaResultState - Class in org.apache.hadoop.hbase.client
Sync point for calls to multiple replicas for the same user request (Get).
AsyncRequestFutureImpl.Retry - Enum in org.apache.hadoop.hbase.client
AsyncRequestFutureImpl.SingleServerRequestRunnable - Class in org.apache.hadoop.hbase.client
Runnable (that can be submitted to thread pool) that submits MultiAction to a single server.
AsyncRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
 
AsyncRpcRetryingCaller(Timer, AsyncConnectionImpl, int, long, long, int, long, long, int, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.client.AsyncRpcRetryingCaller
 
AsyncRpcRetryingCallerFactory - Class in org.apache.hadoop.hbase.client
Factory to create an AsyncRpcRetryCaller.
AsyncRpcRetryingCallerFactory(AsyncConnectionImpl, Timer) - Constructor for class org.apache.hadoop.hbase.client.AsyncRpcRetryingCallerFactory
 
AsyncRpcRetryingCallerFactory.AdminRequestCallerBuilder<T> - Class in org.apache.hadoop.hbase.client
 
AsyncRpcRetryingCallerFactory.BatchCallerBuilder - Class in org.apache.hadoop.hbase.client
 
AsyncRpcRetryingCallerFactory.BuilderBase - Class in org.apache.hadoop.hbase.client
 
AsyncRpcRetryingCallerFactory.MasterRequestCallerBuilder<T> - Class in org.apache.hadoop.hbase.client
 
AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder - Class in org.apache.hadoop.hbase.client
 
AsyncRpcRetryingCallerFactory.ServerRequestCallerBuilder<T> - Class in org.apache.hadoop.hbase.client
 
AsyncRpcRetryingCallerFactory.SingleRequestCallerBuilder<T> - Class in org.apache.hadoop.hbase.client
 
AsyncScanSingleRegionRpcRetryingCaller - Class in org.apache.hadoop.hbase.client
Retry caller for scanning a region.
AsyncScanSingleRegionRpcRetryingCaller(Timer, AsyncConnectionImpl, Scan, ScanMetrics, long, ScanResultCache, AdvancedScanResultConsumer, ClientProtos.ClientService.Interface, HRegionLocation, boolean, int, long, long, long, int, long, long, int, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.client.AsyncScanSingleRegionRpcRetryingCaller
 
AsyncScanSingleRegionRpcRetryingCaller.ScanControllerImpl - Class in org.apache.hadoop.hbase.client
 
AsyncScanSingleRegionRpcRetryingCaller.ScanControllerState - Enum in org.apache.hadoop.hbase.client
 
AsyncScanSingleRegionRpcRetryingCaller.ScanResumerImpl - Class in org.apache.hadoop.hbase.client
 
AsyncScanSingleRegionRpcRetryingCaller.ScanResumerState - Enum in org.apache.hadoop.hbase.client
 
AsyncServerRequestRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
Retry caller for a request call to region server.
AsyncServerRequestRpcRetryingCaller(Timer, AsyncConnectionImpl, long, long, int, long, long, int, ServerName, AsyncServerRequestRpcRetryingCaller.Callable<T>) - Constructor for class org.apache.hadoop.hbase.client.AsyncServerRequestRpcRetryingCaller
 
AsyncServerRequestRpcRetryingCaller.Callable<T> - Interface in org.apache.hadoop.hbase.client
 
AsyncSingleRequestRpcRetryingCaller<T> - Class in org.apache.hadoop.hbase.client
Retry caller for a single request, such as get, put, delete, etc.
AsyncSingleRequestRpcRetryingCaller(Timer, AsyncConnectionImpl, TableName, byte[], int, RegionLocateType, AsyncSingleRequestRpcRetryingCaller.Callable<T>, int, long, long, int, long, long, int, Map<String, byte[]>) - Constructor for class org.apache.hadoop.hbase.client.AsyncSingleRequestRpcRetryingCaller
 
AsyncSingleRequestRpcRetryingCaller.Callable<T> - Interface in org.apache.hadoop.hbase.client
 
asyncSnapshot(SnapshotProtos.SnapshotDescription) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
AsyncTable<C extends ScanResultConsumerBase> - Interface in org.apache.hadoop.hbase.client
The interface for asynchronous version of Table.
AsyncTable.CheckAndMutateBuilder - Interface in org.apache.hadoop.hbase.client
Deprecated.
Since 2.4.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
AsyncTable.CheckAndMutateWithFilterBuilder - Interface in org.apache.hadoop.hbase.client
Deprecated.
Since 2.4.0, will be removed in 4.0.0. For internal test use only, do not use it any more.
AsyncTable.CoprocessorCallback<R> - Interface in org.apache.hadoop.hbase.client
The callback when we want to execute a coprocessor call on a range of regions.
AsyncTable.CoprocessorServiceBuilder<S,R> - Interface in org.apache.hadoop.hbase.client
Helper class for sending coprocessorService request that executes a coprocessor call on regions which are covered by a range.
AsyncTableBuilder<C extends ScanResultConsumerBase> - Interface in org.apache.hadoop.hbase.client
For creating AsyncTable.
AsyncTableBuilderBase<C extends ScanResultConsumerBase> - Class in org.apache.hadoop.hbase.client
Base class for all asynchronous table builders.
AsyncTableBuilderBase(TableName, AsyncConnectionConfiguration) - Constructor for class org.apache.hadoop.hbase.client.AsyncTableBuilderBase
 
AsyncTableImpl - Class in org.apache.hadoop.hbase.client
Just a wrapper of RawAsyncTableImpl.
AsyncTableImpl(RawAsyncTableImpl, ExecutorService) - Constructor for class org.apache.hadoop.hbase.client.AsyncTableImpl
 
AsyncTableRegionLocator - Interface in org.apache.hadoop.hbase.client
The asynchronous version of RegionLocator.
AsyncTableRegionLocatorImpl - Class in org.apache.hadoop.hbase.client
The implementation of AsyncRegionLocator.
AsyncTableRegionLocatorImpl(TableName, AsyncConnectionImpl) - Constructor for class org.apache.hadoop.hbase.client.AsyncTableRegionLocatorImpl
 
AsyncTableResultScanner - Class in org.apache.hadoop.hbase.client
The ResultScanner implementation for RawAsyncTableImpl.
AsyncTableResultScanner(TableName, Scan, long) - Constructor for class org.apache.hadoop.hbase.client.AsyncTableResultScanner
 
at(long) - Static method in class org.apache.hadoop.hbase.io.TimeRange
 
AT_LEAST_ONE - Enum constant in enum org.apache.hadoop.hbase.client.AsyncProcessTask.SubmittedRows
 
atCapacity() - Method in class org.apache.hadoop.hbase.util.compaction.ClusterCompactionQueues
 
atHeadOfRingBufferEventHandlerAppend() - Method in class org.apache.hadoop.hbase.regionserver.wal.AbstractFSWAL
Exposed for testing only.
atLeast(TableSplit.Version) - Method in enum org.apache.hadoop.hbase.mapreduce.TableSplit.Version
 
atomic - Variable in class org.apache.hadoop.hbase.regionserver.HRegion.BatchOperation
 
ATOMIC_BOOLEAN - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for AtomicBoolean
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
ATOMIC_REFERENCE - Static variable in class org.apache.hadoop.hbase.util.ClassSize
Overhead for AtomicReference
AtomicAverageCounter() - Constructor for class org.apache.hadoop.hbase.client.HTableMultiplexer.AtomicAverageCounter
Deprecated.
 
atomicIncrement(ByteBuffer, ByteBuffer, byte[], byte[], long) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
 
atomicIncrement(ByteBuffer, ByteBuffer, ByteBuffer, long) - Method in class org.apache.hadoop.hbase.thrift.ThriftHBaseServiceHandler
 
AtomicUtils - Class in org.apache.hadoop.hbase.util
Utilities related to atomic operations.
AtomicUtils() - Constructor for class org.apache.hadoop.hbase.util.AtomicUtils
 
attachRemoteProc(RegionRemoteProcedureBase) - Method in class org.apache.hadoop.hbase.master.assignment.TransitRegionStateProcedure
 
attainSafePoint() - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferEventHandler
 
attainSafePoint(long) - Method in class org.apache.hadoop.hbase.regionserver.wal.FSHLog.RingBufferEventHandler
Check if we should attain safe point.
attempt - Variable in class org.apache.hadoop.hbase.master.assignment.RegionTransitionProcedure
Deprecated.
 
attemptFetch() - Method in class org.apache.hadoop.hbase.master.CachedClusterId
Attempts to fetch the cluster ID from the file system.
attemptingUser - Variable in class org.apache.hadoop.hbase.security.provider.DigestSaslServerAuthenticationProvider
 
attemptingUser - Variable in class org.apache.hadoop.hbase.security.provider.DigestSaslServerAuthenticationProvider.SaslDigestCallbackHandler
 
attemptingUser - Variable in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslServerAuthenticationProvider
 
attemptingUser - Variable in class org.apache.hadoop.hbase.security.provider.example.ShadeSaslServerAuthenticationProvider.ShadeSaslServerCallbackHandler
 
AttemptingUserProvidingSaslServer - Class in org.apache.hadoop.hbase.security.provider
Wrapper around a SaslServer which provides the last user attempting to authenticate via SASL, if the server/mechanism allow figuring that out.
AttemptingUserProvidingSaslServer(SaslServer, Supplier<UserGroupInformation>) - Constructor for class org.apache.hadoop.hbase.security.provider.AttemptingUserProvidingSaslServer
 
attempts - Variable in class org.apache.hadoop.hbase.ipc.BlockingRpcConnection
 
attempts - Variable in class org.apache.hadoop.hbase.util.RetryCounter
 
attemptToOwnTask(boolean, ZKWatcher, ServerName, String, 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_SEPERATOR_CONF_KEY - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv
 
attributes - Variable in class org.apache.hadoop.hbase.client.OperationWithAttributes
 
attributes - Variable in class org.apache.hadoop.hbase.client.trace.ConnectionSpanBuilder
 
attributes - Variable in class org.apache.hadoop.hbase.client.trace.IpcClientSpanBuilder
 
attributes - Variable in class org.apache.hadoop.hbase.client.trace.TableOperationSpanBuilder
 
attributes - Variable in class org.apache.hadoop.hbase.client.trace.TableSpanBuilder
 
attributes - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.Cell
 
attributes - Variable in class org.apache.hadoop.hbase.hbtop.terminal.impl.TerminalPrinterImpl
 
attributes - Variable in class org.apache.hadoop.hbase.ipc.Call
 
attributes - Variable in class org.apache.hadoop.hbase.server.trace.IpcServerSpanBuilder
 
Attributes - Class in org.apache.hadoop.hbase.hbtop.terminal
The attributes of text in the terminal.
Attributes - Interface in org.apache.hadoop.hbase.client
 
Attributes() - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
Attributes(Attributes) - Constructor for class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
ATTRIBUTES_COLUMN_SPEC - Static variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
attrKeyColumnIndex - Variable in class org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser
 
attrs - Variable in class org.apache.hadoop.hbase.rest.model.ColumnSchemaModel
 
attrs - Variable in class org.apache.hadoop.hbase.rest.model.TableSchemaModel
 
AUDITLOG - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
AUDITLOG - Static variable in class org.apache.hadoop.hbase.master.MasterRpcServices
 
AUDITLOG - Static variable in class org.apache.hadoop.hbase.security.access.AccessChecker
 
AUDITLOG - Static variable in class org.apache.hadoop.hbase.security.access.AccessController
 
AUDITLOG - Static variable in class org.apache.hadoop.hbase.security.visibility.VisibilityController
 
AUTH_COOKIE - Static variable in class org.apache.hadoop.hbase.rest.client.Client
 
AUTH_COOKIE_EQ - Static variable in class org.apache.hadoop.hbase.rest.client.Client
 
AUTH_FAILED_FOR - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
AUTH_SUCCESSFUL_FOR - Static variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
AUTH_TOKEN_TYPE - Static variable in class org.apache.hadoop.hbase.security.provider.AbstractSaslClientAuthenticationProvider
 
AUTH_TOKEN_TYPE - Static variable in class org.apache.hadoop.hbase.security.provider.BuiltInSaslAuthenticationProvider
 
AUTH_TOKEN_TYPE - Static variable in class org.apache.hadoop.hbase.security.token.AuthenticationTokenIdentifier
 
authenticatedWithFallback - Variable in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
 
AUTHENTICATION - Enum constant in enum org.apache.hadoop.hbase.security.SaslUtil.QualityOfProtection
 
AUTHENTICATION - Static variable in class org.apache.hadoop.hbase.HBaseInterfaceAudience
Denotes classes that can be used to build custom authentication solutions.
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_FALLBACKS_DESC - Static variable in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
AUTHENTICATION_FALLBACKS_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
 
authenticationEnabled - Variable in class org.apache.hadoop.hbase.http.HttpServer
 
authenticationFailure() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
 
authenticationFailure() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authenticationFailure() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
authenticationFailures - Variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
authenticationFallback() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
 
authenticationFallback() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authenticationFallback() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
authenticationFallbacks - Variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
AuthenticationKey - Class in org.apache.hadoop.hbase.security.token
Represents a secret key used for signing and verifying authentication tokens by AuthenticationTokenSecretManager.
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
 
AuthenticationProviderSelector - Interface in org.apache.hadoop.hbase.security.provider
 
authenticationSuccess() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
 
authenticationSuccess() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authenticationSuccess() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
authenticationSuccesses - Variable 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, ZKWatcher, String, long, long) - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenSecretManager
Create a new secret manager instance for generating keys.
AuthenticationTokenSecretManager.LeaderElector - Class in org.apache.hadoop.hbase.security.token
 
AuthenticationTokenSelector - Class in org.apache.hadoop.hbase.security.token
 
AuthenticationTokenSelector() - Constructor for class org.apache.hadoop.hbase.security.token.AuthenticationTokenSelector
 
authFailedFailedOpCount - Variable in class org.apache.hadoop.hbase.zookeeper.MetricsZooKeeperSourceImpl
 
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
 
authManager - Variable in class org.apache.hadoop.hbase.security.access.AccessChecker
 
authManager - Variable in class org.apache.hadoop.hbase.security.access.AccessControlFilter
 
authManager - Variable in class org.apache.hadoop.hbase.security.access.ZKPermissionWatcher
 
AuthManager - Class in org.apache.hadoop.hbase.security.access
Performs authorization checks for a given user's assigned permissions.
AuthManager(Configuration) - Constructor for class org.apache.hadoop.hbase.security.access.AuthManager
 
AuthManager.PermissionCache<T extends Permission> - Class in org.apache.hadoop.hbase.security.access
Cache of permissions, it is thread safe.
AuthMethod - Enum in org.apache.hadoop.hbase.security
Authentication method
AuthMethod(byte, String, UserGroupInformation.AuthenticationMethod) - Constructor for enum org.apache.hadoop.hbase.security.AuthMethod
 
AUTHORIZATION - Enum constant in enum org.apache.hadoop.hbase.client.security.SecurityCapability
 
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
 
authorizationEnabled - Variable in class org.apache.hadoop.hbase.security.access.AccessController
if we are active, usually false, only true if "hbase.security.authorization" has been set to true in site configuration
authorizationEnabled - Variable in class org.apache.hadoop.hbase.security.visibility.VisibilityController
if we are active, usually false, only true if "hbase.security.authorization" has been set to true in site configuration
authorizationFailure() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
 
authorizationFailure() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authorizationFailure() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
authorizationFailures - Variable 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
 
authorizationSuccess() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServer
 
authorizationSuccess() - Method in interface org.apache.hadoop.hbase.ipc.MetricsHBaseServerSource
 
authorizationSuccess() - Method in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
authorizationSuccesses - Variable in class org.apache.hadoop.hbase.ipc.MetricsHBaseServerSourceImpl
 
authorize - Variable in class org.apache.hadoop.hbase.ipc.RpcServer
 
authorize(UserGroupInformation, RPCProtos.ConnectionHeader, InetAddress) - Method in class org.apache.hadoop.hbase.ipc.RpcServer
Authorize the incoming client connection.
authorizeCell(User, TableName, Cell, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
Check if user has given action privilige in cell scope.
authorizeConnection() - Method in class org.apache.hadoop.hbase.ipc.ServerRpcConnection
 
authorizeFamily(Set<TablePermission>, TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
 
authorizeGlobal(GlobalPermission, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
 
authorizeNamespace(Set<NamespacePermission>, String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
 
authorizeTable(Set<TablePermission>, TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
 
authorizeUserFamily(User, TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
Check if user has given action privilige in table:family scope.
authorizeUserGlobal(User, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
Check if user has given action privilige in global scope.
authorizeUserNamespace(User, String, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
Check if user has given action privilige in namespace scope.
authorizeUserTable(User, TableName, byte[], byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
Check if user has given action privilige in table:family:qualifier scope.
authorizeUserTable(User, TableName, byte[], Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
Check if user has given action privilige in table:family scope.
authorizeUserTable(User, TableName, Permission.Action) - Method in class org.apache.hadoop.hbase.security.access.AuthManager
Check if user has given action privilige in table scope.
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, String) - Constructor for class org.apache.hadoop.hbase.security.access.AuthResult
 
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.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
Deprecated.
since 2.2.0, to be marked as InterfaceAudience.Private in 4.0.0.
AuthUtil() - Constructor for class org.apache.hadoop.hbase.AuthUtil
Deprecated.
 
authz - Variable in class org.apache.hadoop.hbase.security.provider.example.SaslPlainServer
 
autoAdjust - Variable in enum org.apache.hadoop.hbase.hbtop.field.Field
 
avail - Variable in class org.apache.hadoop.hbase.quotas.RateLimiter
 
AVAIL_PROCESSORS - Static variable in class org.apache.hadoop.hbase.master.cleaner.CleanerChore
 
available() - Method in class org.apache.hadoop.hbase.io.ByteBufferInputStream
 
available() - Method in class org.apache.hadoop.hbase.io.ByteBuffInputStream
 
available() - Method in class org.apache.hadoop.hbase.io.FileLink.FileLinkInputStream
 
available() - Method in class org.apache.hadoop.hbase.regionserver.wal.WALDecompressionBoundedDelegatingInputStream
 
available(Configuration) - Static method in class org.apache.hadoop.hbase.client.HBaseAdmin
Is HBase available? Throw an exception if not.
availableServersContains(List<ServerName>, ServerName) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
 
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
 
AVERAGE_REGION_SIZE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
AVERAGE_REGION_SIZE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
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
 
averageLatency - Variable in class org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker
Deprecated.
 
averageLoad - Variable in class org.apache.hadoop.hbase.hbtop.screen.top.Summary
 
averageLoad - Variable in class org.apache.hadoop.hbase.rest.model.StorageClusterStatusModel
 
averageRegionSize - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl.RegionMetricAggregate
 
averageRegionSizeMb - Variable in class org.apache.hadoop.hbase.master.normalizer.SimpleRegionNormalizer.NormalizeContext
 
averageTime - Variable in class org.apache.hadoop.hbase.util.SimpleMovingAverage
 
AVG_KEY_LEN - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
 
AVG_STORE_FILE_AGE - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
AVG_STORE_FILE_AGE_DESC - Static variable in interface org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource
 
AVG_VALUE_LEN - Static variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
 
avgAgeNumerator - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl.RegionMetricAggregate.StoreFileStats
 
avgDispersionNum - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
 
avgDispersionScore - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
 
avgKeyLen - Variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
Average key length read from file info
avgLoadOverall - Variable in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
 
avgRegionsOnRS - Variable in class org.apache.hadoop.hbase.master.AssignmentVerificationReport
 
avgStoreFileAge - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionServerWrapperImpl.RegionMetricAggregate
 
avgStoreFileAge - Variable in class org.apache.hadoop.hbase.regionserver.MetricsRegionWrapperImpl
 
avgValueLen - Variable in class org.apache.hadoop.hbase.io.hfile.HFileInfo
Average value length read from file info
avlHeight - Variable in class org.apache.hadoop.hbase.util.AvlUtil.AvlNode
 
AvlIterableList() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlIterableList
 
avlLeft - Variable in class org.apache.hadoop.hbase.util.AvlUtil.AvlNode
 
AvlLinkedNode() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlLinkedNode
 
AvlNode() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlNode
 
avlRight - Variable in class org.apache.hadoop.hbase.util.AvlUtil.AvlNode
 
AvlTree() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
 
AvlTreeIterator() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
 
AvlTreeIterator(TNode) - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
Create the iterator starting from the first (min) node of the tree
AvlTreeIterator(TNode, Object, AvlUtil.AvlKeyComparator<TNode>) - Constructor for class org.apache.hadoop.hbase.util.AvlUtil.AvlTreeIterator
Create the iterator starting from the specified key
AvlUtil - Class in org.apache.hadoop.hbase.util
Helper class that allows to create and manipulate an AvlTree.
AvlUtil() - Constructor for class org.apache.hadoop.hbase.util.AvlUtil
 
AvlUtil.AvlInsertOrReplace<TNode extends AvlUtil.AvlNode> - Interface in org.apache.hadoop.hbase.util
 
AvlUtil.AvlIterableList - Class in org.apache.hadoop.hbase.util
Helper class that allows to create and manipulate a linked list of AvlLinkedNodes
AvlUtil.AvlKeyComparator<TNode extends AvlUtil.AvlNode> - Interface in org.apache.hadoop.hbase.util
The AvlTree allows to lookup an object using a custom key.
AvlUtil.AvlLinkedNode<TNode extends AvlUtil.AvlLinkedNode> - Class in org.apache.hadoop.hbase.util
This class extends the AvlNode and adds two links that will be used in conjunction with the AvlIterableList class.
AvlUtil.AvlNode<TNode extends AvlUtil.AvlNode> - Class in org.apache.hadoop.hbase.util
This class represent a node that will be used in an AvlTree.
AvlUtil.AvlNodeVisitor<TNode extends AvlUtil.AvlNode> - Interface in org.apache.hadoop.hbase.util
Visitor that allows to traverse a set of AvlNodes.
AvlUtil.AvlTree - Class in org.apache.hadoop.hbase.util
Helper class that allows to create and manipulate an AVL Tree
AvlUtil.AvlTreeIterator<TNode extends AvlUtil.AvlNode> - Class in org.apache.hadoop.hbase.util
Iterator for the AvlTree
AVOID_COST - Static variable in class org.apache.hadoop.hbase.master.RegionPlacementMaintainer
 
await() - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
 
await() - Method in class org.apache.hadoop.hbase.master.procedure.InitMetaProcedure
 
await() - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch
 
await() - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch.CompatibilityLatch
 
await() - Method in class org.apache.hadoop.hbase.master.procedure.ProcedurePrepareLatch.NoopLatch
 
await() - Method in class org.apache.hadoop.hbase.regionserver.MultiVersionConcurrencyControl
Wait until the read point catches up to the write point; i.e.
await(long, TimeUnit) - Method in class org.apache.hadoop.hbase.client.locking.EntityLock
 
awaitRunning() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
Waits for the ReplicationEndpoint to be up and running.
awaitRunning() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
awaitRunning(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
Waits for the ReplicationEndpoint to to be up and running for no more than the given time.
awaitRunning(long, TimeUnit) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
awaitTerminated() - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
Waits for the ReplicationEndpoint to reach the terminated (internal) state.
awaitTerminated() - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
awaitTerminated(long, TimeUnit) - Method in interface org.apache.hadoop.hbase.replication.ReplicationEndpoint
Waits for the ReplicationEndpoint to reach a terminal state for no more than the given time.
awaitTerminated(long, TimeUnit) - Method in class org.apache.hadoop.hbase.security.visibility.VisibilityReplicationEndpoint
 
awaitTermination() - Method in class org.apache.hadoop.hbase.procedure2.RemoteProcedureDispatcher.TimeoutExecutorThread
 
awaitTermination() - Method in class org.apache.hadoop.hbase.procedure2.StoppableThread
 

B

b - Variable in class org.apache.hadoop.hbase.util.ImmutableByteArray
 
BACK_REFERENCES_DIRECTORY_PREFIX - Static variable in class org.apache.hadoop.hbase.io.FileLink
Define the Back-reference directory name prefix: .links-<hfile>/
backedFile - Variable in class org.apache.hadoop.hbase.regionserver.storefiletracker.FileBasedStoreFileTracker
 
backgroundColor - Variable in class org.apache.hadoop.hbase.hbtop.terminal.Attributes
 
backingMap - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
backingMapValidated - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketCache
 
backingStore - Variable in class org.apache.hadoop.hbase.io.util.LRUDictionary
 
BACKLOG_CONF_DEAFULT - Static variable in class org.apache.hadoop.hbase.thrift.Constants
 
BACKLOG_CONF_KEY - Static variable in class org.apache.hadoop.hbase.thrift.Constants
 
BACKOFF_POLICY_CLASS - Static variable in interface org.apache.hadoop.hbase.client.backoff.ClientBackoffPolicy
 
backoffPolicy - Variable in class org.apache.hadoop.hbase.client.AsyncConnectionImpl
 
backoffPolicy - Variable in class org.apache.hadoop.hbase.client.ConnectionImplementation
 
backoffPolicy - Variable in class org.apache.hadoop.hbase.util.RetryCounter.RetryConfig
 
BackoffPolicy() - Constructor for class org.apache.hadoop.hbase.util.RetryCounter.BackoffPolicy
 
BACKSLASH - Static variable in class org.apache.hadoop.hbase.filter.ParseConstants
ASCII code for Backslash
backspace() - Method in class org.apache.hadoop.hbase.hbtop.screen.top.InputModeScreenPresenter
 
Backspace - Enum constant in enum org.apache.hadoop.hbase.hbtop.terminal.KeyPress.Type
 
BACKUP_ATTEMPTS_PAUSE_MS_KEY - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_CLIENT_IMPL_CLASS - Static variable in class org.apache.hadoop.hbase.backup.impl.TableBackupClient
 
BACKUP_CONFIG_STRING - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_ENABLE_DEFAULT - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_ENABLE_KEY - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_EXCLUSIVE_OPERATION_TIMEOUT_SECONDS_KEY - Static variable in class org.apache.hadoop.hbase.backup.impl.BackupManager
 
BACKUP_INFO_PREFIX - Static variable in class org.apache.hadoop.hbase.backup.impl.BackupSystemTable
 
BACKUP_MASTERS - Enum constant in enum org.apache.hadoop.hbase.ClusterMetrics.Option
metrics about backup masters name
BACKUP_MAX_ATTEMPTS_KEY - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_POOL_THREAD_NUMBER_DEFAULT - Static variable in class org.apache.hadoop.hbase.backup.master.LogRollMasterProcedureManager
 
BACKUP_POOL_THREAD_NUMBER_KEY - Static variable in class org.apache.hadoop.hbase.backup.master.LogRollMasterProcedureManager
 
BACKUP_REQUEST_THREADS_DEFAULT - Static variable in class org.apache.hadoop.hbase.backup.regionserver.LogRollRegionServerProcedureManager
# of threads for backup work on the rs.
BACKUP_REQUEST_THREADS_KEY - Static variable in class org.apache.hadoop.hbase.backup.regionserver.LogRollRegionServerProcedureManager
Conf key for number of request threads to start backup on region servers
BACKUP_REQUEST_WAKE_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.hbase.backup.regionserver.LogRollRegionServerProcedureManager
Default amount of time to check for errors while regions finish backup work
BACKUP_REQUEST_WAKE_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.backup.regionserver.LogRollRegionServerProcedureManager
Conf key for millis between checks to see if backup work completed or if there are errors
BACKUP_SYSTEM_TABLE_NAME_DEFAULT - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_SYSTEM_TABLE_NAME_KEY - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_SYSTEM_TTL_DEFAULT - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_SYSTEM_TTL_KEY - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
BACKUP_TEST_MODE_STAGE - Static variable in class org.apache.hadoop.hbase.backup.impl.TableBackupClient
 
BACKUP_TIMEOUT_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.hbase.backup.master.LogRollMasterProcedureManager
 
BACKUP_TIMEOUT_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.hbase.backup.regionserver.LogRollRegionServerProcedureManager
 
BACKUP_TIMEOUT_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.backup.master.LogRollMasterProcedureManager
 
BACKUP_TIMEOUT_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.backup.regionserver.LogRollRegionServerProcedureManager
 
BACKUP_WAKE_MILLIS_DEFAULT - Static variable in class org.apache.hadoop.hbase.backup.master.LogRollMasterProcedureManager
 
BACKUP_WAKE_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.backup.master.LogRollMasterProcedureManager
 
BackupAdmin - Interface in org.apache.hadoop.hbase.backup
The administrative API for HBase Backup.
BackupAdminImpl - Class in org.apache.hadoop.hbase.backup.impl
 
BackupAdminImpl(Connection) - Constructor for class org.apache.hadoop.hbase.backup.impl.BackupAdminImpl
 
BackupClientFactory - Class in org.apache.hadoop.hbase.backup
 
BackupClientFactory() - Constructor for class org.apache.hadoop.hbase.backup.BackupClientFactory
 
BackupCommand() - Constructor for enum org.apache.hadoop.hbase.backup.BackupRestoreConstants.BackupCommand
 
BackupCommands - Class in org.apache.hadoop.hbase.backup.impl
General backup commands, options and usage messages
BackupCommands() - Constructor for class org.apache.hadoop.hbase.backup.impl.BackupCommands
 
BackupCommands.BackupSetCommand - Class in org.apache.hadoop.hbase.backup.impl
 
BackupCommands.Command - Class in org.apache.hadoop.hbase.backup.impl
 
BackupCommands.CreateCommand - Class in org.apache.hadoop.hbase.backup.impl
 
BackupCommands.DeleteCommand - Class in org.apache.hadoop.hbase.backup.impl
 
BackupCommands.DescribeCommand - Class in org.apache.hadoop.hbase.backup.impl
 
BackupCommands.HelpCommand - Class in org.apache.hadoop.hbase.backup.impl
 
BackupCommands.HistoryCommand - Class in org.apache.hadoop.hbase.backup.impl
 
BackupCommands.MergeCommand - Class in org.apache.hadoop.hbase.backup.impl
 
BackupCommands.ProgressCommand - Class in org.apache.hadoop.hbase.backup.impl
 
BackupCommands.RepairCommand - Class in org.apache.hadoop.hbase.backup.impl
 
BackupCopyJob - Interface in org.apache.hadoop.hbase.backup
Backup copy job is a part of a backup process.
BackupDistCp(Configuration, DistCpOptions, BackupInfo, BackupManager) - Constructor for class org.apache.hadoop.hbase.backup.mapreduce.MapReduceBackupCopyJob.BackupDistCp
 
BackupDriver - Class in org.apache.hadoop.hbase.backup
Command-line entry point for backup operation
BackupDriver() - Constructor for class org.apache.hadoop.hbase.backup.BackupDriver
 
BackupException - Exception in org.apache.hadoop.hbase.backup.impl
Backup exception
BackupException(String) - Constructor for exception org.apache.hadoop.hbase.backup.impl.BackupException
Some exception happened for a backup and don't even know the backup that it was about
BackupException(String, Exception) - Constructor for exception org.apache.hadoop.hbase.backup.impl.BackupException
Exception when the description of the backup cannot be determined, due to some other root cause
BackupException(String, Throwable, BackupInfo) - Constructor for exception org.apache.hadoop.hbase.backup.impl.BackupException
Exception for the given backup due to another exception
BackupException(String, BackupInfo) - Constructor for exception org.apache.hadoop.hbase.backup.impl.BackupException
Exception for the given backup that has no previous root cause
BackupException(Throwable) - Constructor for exception org.apache.hadoop.hbase.backup.impl.BackupException
Some exception happened for a backup with a cause
BackupHFileCleaner - Class in org.apache.hadoop.hbase.backup
Implementation of a file cleaner that checks if an hfile is still referenced by backup before deleting it from hfile archive directory.
BackupHFileCleaner() - Constructor for class org.apache.hadoop.hbase.backup.BackupHFileCleaner
 
backupId - Variable in class org.apache.hadoop.hbase.backup.BackupInfo
Backup id
backupId - Variable in class org.apache.hadoop.hbase.backup.impl.BackupManifest.BackupImage
 
backupId - Variable in class org.apache.hadoop.hbase.backup.impl.BackupSystemTable.WALItem
 
backupId - Variable in class org.apache.hadoop.hbase.backup.impl.RestoreTablesClient
 
backupId - Variable in class org.apache.hadoop.hbase.backup.impl.TableBackupClient
 
backupId - Variable in class org.apache.hadoop.hbase.backup.RestoreRequest
 
backupId - Variable in class org.apache.hadoop.hbase.backup.util.RestoreTool
 
BACKUPID_PREFIX - Static variable in interface org.apache.hadoop.hbase.backup.BackupRestoreConstants
 
backupImage - Variable in class org.apache.hadoop.hbase.backup.impl.BackupManifest
 
BackupImage() - Constructor for class org.apache.hadoop.hbase.backup.impl.BackupManifest.BackupImage
 
BackupImage(String, BackupType, String, List<TableName>, long, long) - Constructor for class org.apache.hadoop.hbase.backup.impl.BackupManifest.BackupImage
 
backupInfo - Variable in class org.apache.hadoop.hbase.backup.impl.BackupManager
 
backupInfo - Variable in class org.apache.hadoop.hbase.backup.impl.TableBackupClient
 
backupInfo - Variable in class org.apache.hadoop.hbase.backup.mapreduce.MapReduceBackupCopyJob.BackupDistCp
 
backupInfo - Variable in class org.apache.hadoop.hbase.backup.mapreduce.MapReduceBackupCopyJob.SnapshotCopy
 
BackupInfo - Class in org.apache.hadoop.hbase.backup
An object to encapsulate the information for each backup session
BackupInfo() - Constructor for class org.apache.hadoop.hbase.backup.BackupInfo
 
BackupInfo(String, BackupType, TableName[], String) - Constructor for class org.apache.hadoop.hbase.backup.BackupInfo
 
BackupInfo.BackupPhase - Enum in org.apache.hadoop.hbase.backup
BackupPhase - phases of an ACTIVE backup session (running), when state of a backup session is BackupState.RUNNING
BackupInfo.BackupState - Enum in org.apache.hadoop.hbase.backup
Backup session states
BackupInfo.Filter - Interface in org.apache.hadoop.hbase.backup
 
BackupLogCleaner - Class in org.apache.hadoop.hbase.backup.master
Implementation of a log cleaner that checks if a log is still scheduled for incremental backup before deleting it when its TTL is over.
BackupLogCleaner() - Constructor for class org.apache.hadoop.hbase.backup.master.BackupLogCleaner
 
backupManager - Variable in class org.apache.hadoop.hbase.backup.impl.TableBackupClient
 
backupManager - Variable in class org.apache.hadoop.hbase.backup.mapreduce.MapReduceBackupCopyJob.BackupDistCp
 
BackupManager - Class in org.apache.hadoop.hbase.backup.impl
Handles backup requests, creates backup info records in backup system table to keep track of backup sessions, dispatches backup request.
BackupManager(Connection, Configuration) - Constructor for class org.apache.hadoop.hbase.backup.impl.BackupManager
Backup manager constructor.
BackupManifest - Class in org.apache.hadoop.hbase.backup.impl
Backup manifest contains all the meta data of a backup image.
BackupManifest(Configuration, Path) - Constructor for class org.apache.hadoop.hbase.backup.impl.BackupManifest
Construct manifest from a backup directory.
BackupManifest(FileSystem, Path) - Constructor for class org.apache.hadoop.hbase.backup.impl.BackupManifest
Construct manifest from a backup directory.
BackupManifest(BackupInfo) - Constructor for class org.apache.hadoop.hbase.backup.impl.BackupManifest
Construct manifest for a ongoing backup.
BackupManifest(BackupInfo, TableName) - Constructor for class org.apache.hadoop.hbase.backup.impl.BackupManifest
Construct a table level manifest for a backup of the named table.
BackupManifest.BackupImage - Class in org.apache.hadoop.hbase.backup.impl
Backup image, the dependency graph is made up by series of backup images BackupImage contains all the relevant information to restore the backup and is used during restore operation
BackupManifest.BackupImage.Builder - Class in org.apache.hadoop.hbase.backup.impl
 
backupMasterAddressesZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
 
backupMasterNames - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder
 
backupMasterNames - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
 
backupMasterNames - Variable in class org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.model.ClusterMetrics
 
backupMasters - Variable in class org.apache.hadoop.hbase.master.ActiveMasterManager
 
backupMasters - Variable in class org.apache.hadoop.hbase.zookeeper.MasterAddressTracker
 
BackupMergeJob - Interface in org.apache.hadoop.hbase.backup
Backup merge operation job interface.
BackupObserver - Class in org.apache.hadoop.hbase.backup
An Observer to facilitate backup operations
BackupObserver() - Constructor for class org.apache.hadoop.hbase.backup.BackupObserver
 
BackupPhase() - Constructor for enum org.apache.hadoop.hbase.backup.BackupInfo.BackupPhase
 
BackupRequest - Class in org.apache.hadoop.hbase.backup
POJO class for backup request
BackupRequest() - Constructor for class org.apache.hadoop.hbase.backup.BackupRequest
 
BackupRequest.Builder - Class in org.apache.hadoop.hbase.backup
 
BackupRestoreConstants - Interface in org.apache.hadoop.hbase.backup
BackupRestoreConstants holds a bunch of HBase Backup and Restore constants
BackupRestoreConstants.BackupCommand - Enum in org.apache.hadoop.hbase.backup
 
BackupRestoreFactory - Class in org.apache.hadoop.hbase.backup
Factory implementation for backup/restore related jobs
BackupRestoreFactory() - Constructor for class org.apache.hadoop.hbase.backup.BackupRestoreFactory
 
backupRoot - Variable in class org.apache.hadoop.hbase.backup.impl.BackupSystemTable.WALItem
 
backupRoot - Variable in class org.apache.hadoop.hbase.backup.regionserver.LogRollBackupSubprocedure
 
backupRootDir - Variable in class org.apache.hadoop.hbase.backup.BackupInfo
Target root directory for storing the backup files
backupRootDir - Variable in class org.apache.hadoop.hbase.backup.impl.RestoreTablesClient
 
backupRootDir - Variable in class org.apache.hadoop.hbase.backup.RestoreRequest
 
backupRootPath - Variable in class org.apache.hadoop.hbase.backup.util.RestoreTool
 
BackupSet - Class in org.apache.hadoop.hbase.backup.util
Backup set is a named group of HBase tables, which are managed together by Backup/Restore framework.
BackupSet(String, List<TableName>) - Constructor for class org.apache.hadoop.hbase.backup.util.BackupSet
 
BackupSetCommand(Configuration, CommandLine) - Constructor for class org.apache.hadoop.hbase.backup.impl.BackupCommands.BackupSetCommand
 
backupSetName - Variable in class org.apache.hadoop.hbase.backup.BackupRequest
 
BackupState() - Constructor for enum org.apache.hadoop.hbase.backup.BackupInfo.BackupState
 
BackupSubprocedureBuilder() - Constructor for class org.apache.hadoop.hbase.backup.regionserver.LogRollRegionServerProcedureManager.BackupSubprocedureBuilder
 
BackupSystemTable - Class in org.apache.hadoop.hbase.backup.impl
This class provides API to access backup system table
Backup system table schema:
BackupSystemTable(Connection) - Constructor for class org.apache.hadoop.hbase.backup.impl.BackupSystemTable
 
BackupSystemTable.WALItem - Class in org.apache.hadoop.hbase.backup.impl
 
BackupTableInfo - Class in org.apache.hadoop.hbase.backup
Backup related information encapsulated for a table.
BackupTableInfo() - Constructor for class org.apache.hadoop.hbase.backup.BackupTableInfo
 
BackupTableInfo(TableName, String, String) - Constructor for class org.apache.hadoop.hbase.backup.BackupTableInfo
 
backupTableInfoMap - Variable in class org.apache.hadoop.hbase.backup.BackupInfo
Backup status map for all tables
backupTables(BackupRequest) - Method in interface org.apache.hadoop.hbase.backup.BackupAdmin
Backup given list of tables fully.
backupTables(BackupRequest) - Method in class org.apache.hadoop.hbase.backup.impl.BackupAdminImpl
 
BackupType - Enum in org.apache.hadoop.hbase.backup
 
BackupType() - Constructor for enum org.apache.hadoop.hbase.backup.BackupType
 
BackupUtils - Class in org.apache.hadoop.hbase.backup.util
A collection for methods used by multiple classes to backup HBase tables.
BackupUtils() - Constructor for class org.apache.hadoop.hbase.backup.util.BackupUtils
 
backwards - Variable in class org.apache.hadoop.hbase.util.HbckTableInfo
 
backwardSeek(Cell) - Method in interface org.apache.hadoop.hbase.regionserver.KeyValueScanner
Seek the scanner at or before the row of specified Cell, it firstly tries to seek the scanner at or after the specified Cell, return if peek KeyValue of scanner has the same row with specified Cell, otherwise seek the scanner at the first Cell of the row which is the previous row of specified KeyValue
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.NonReversedNonLazyKeyValueScanner
 
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedKeyValueHeap
 
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.ReversedStoreScanner
 
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.SegmentScanner
Seek the scanner at or before the row of specified Cell, it firstly tries to seek the scanner at or after the specified Cell, return if peek KeyValue of scanner has the same row with specified Cell, otherwise seek the scanner at the first Cell of the row which is the previous row of specified KeyValue
backwardSeek(Cell) - Method in class org.apache.hadoop.hbase.regionserver.StoreFileScanner
 
BAD_FAMILY - Enum constant in enum org.apache.hadoop.hbase.HConstants.OperationStatusCode
 
BAD_JVM_VERSIONS - Static variable in class org.apache.hadoop.hbase.util.JvmVersion
 
BadAuthException - Exception in org.apache.hadoop.hbase.ipc
 
BadAuthException() - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
 
BadAuthException(String) - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
 
BadAuthException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.ipc.BadAuthException
 
BadFormatException(String) - Constructor for exception org.apache.hadoop.hbase.http.conf.ConfServlet.BadFormatException
 
badLineCount - Variable in class org.apache.hadoop.hbase.mapreduce.TextSortReducer
 
badLineCount - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterMapper
 
badLineCount - Variable in class org.apache.hadoop.hbase.mapreduce.TsvImporterTextMapper
 
BadProcedureException - Exception in org.apache.hadoop.hbase.procedure2
 
BadProcedureException() - Constructor for exception org.apache.hadoop.hbase.procedure2.BadProcedureException
 
BadProcedureException(String) - Constructor for exception org.apache.hadoop.hbase.procedure2.BadProcedureException
 
BadProcedureException(String, Throwable) - Constructor for exception org.apache.hadoop.hbase.procedure2.BadProcedureException
 
BadProcedureException(Throwable) - Constructor for exception org.apache.hadoop.hbase.procedure2.BadProcedureException
 
badReportCounts - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
 
badResponse(String) - Method in class org.apache.hadoop.hbase.client.AbstractRpcBasedConnectionRegistry
 
BADROWS - Enum constant in enum org.apache.hadoop.hbase.mapreduce.replication.VerifyReplication.Verifier.Counters
 
badSinkThreshold - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSinkManager
 
BadTsvLineException(String) - Constructor for exception org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.BadTsvLineException
 
balance() - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke the balancer.
balance() - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Invoke the balancer.
balance() - Method in class org.apache.hadoop.hbase.master.HMaster
 
balance() - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
 
balance(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.5.0. Will be removed in 4.0.0. Use Admin.balance(BalanceRequest) instead.
balance(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Deprecated.
Since 2.5.0. Will be removed in 4.0.0. Use AsyncAdmin.balance(BalanceRequest) instead.
balance(boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
 
balance(BalanceRequest) - Method in interface org.apache.hadoop.hbase.client.Admin
Invoke the balancer with the given balance request.
balance(BalanceRequest) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Invoke the balancer with the given balance request.
balance(BalanceRequest) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
 
balance(BalanceRequest) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
balance(BalanceRequest) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
 
balance(BalanceRequest) - Method in class org.apache.hadoop.hbase.master.HMaster
 
balance(BalanceRequest) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
 
balance(RegionPlan) - Method in class org.apache.hadoop.hbase.master.assignment.AssignmentManager
 
balance(RpcController, MasterProtos.BalanceRequest) - Method in class org.apache.hadoop.hbase.client.ShortCircuitMasterConnection
 
balance(RpcController, MasterProtos.BalanceRequest) - Method in class org.apache.hadoop.hbase.master.MasterRpcServices
 
balance(TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
 
BALANCE_CLUSTER - Static variable in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
 
BALANCE_DECISION - Enum constant in enum org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
 
BALANCE_REJECTION - Enum constant in enum org.apache.hadoop.hbase.namequeues.NamedQueuePayload.NamedQueueEvent
 
BalanceAction - Class in org.apache.hadoop.hbase.master.balancer
An action to move or swap a region
BalanceAction(BalanceAction.Type) - Constructor for class org.apache.hadoop.hbase.master.balancer.BalanceAction
 
BalanceAction.Type - Enum in org.apache.hadoop.hbase.master.balancer
 
balanceCluster(long) - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancer
 
balanceCluster(long) - Method in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancer
 
balanceCluster(Map<TableName, Map<ServerName, List<RegionInfo>>>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
Perform the major balance operation for cluster, will invoke BaseLoadBalancer.balanceTable(TableName, Map) to do actual balance.
balanceCluster(Map<TableName, Map<ServerName, List<RegionInfo>>>) - Method in class org.apache.hadoop.hbase.master.balancer.MaintenanceLoadBalancer
 
balanceCluster(Map<TableName, Map<ServerName, List<RegionInfo>>>) - Method in interface org.apache.hadoop.hbase.master.LoadBalancer
Perform the major balance operation for cluster.
balanceCluster(Map<TableName, Map<ServerName, List<RegionInfo>>>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
Balance by RSGroup.
BalancedQueueRpcExecutor - Class in org.apache.hadoop.hbase.ipc
An RpcExecutor that will balance requests evenly across all its queues, but still remains efficient with a single queue via an inlinable queue balancing mechanism.
BalancedQueueRpcExecutor(String, int, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
 
BalancedQueueRpcExecutor(String, int, String, int, PriorityFunction, Configuration, Abortable) - Constructor for class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
 
balanceFactor(TNode) - Static method in class org.apache.hadoop.hbase.util.AvlUtil.AvlTree
 
BalanceInfo(int, int, List<RegionInfo>) - Constructor for class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer.BalanceInfo
 
balanceMasterRegions(Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
Deprecated.
since 2.4.0, will be removed in 3.0.0.
balanceOrUpdateMetrics() - Method in class org.apache.hadoop.hbase.master.HMaster
Trigger a normal balance, see HMaster.balance() .
balanceOverall(List<RegionPlan>, Map<ServerName, SimpleLoadBalancer.BalanceInfo>, boolean, MinMaxPriorityQueue<RegionPlan>, int, int) - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
If we need to balanceoverall, we need to add one more round to peel off one region from each max.
balancer - Variable in class org.apache.hadoop.hbase.ipc.BalancedQueueRpcExecutor
 
balancer - Variable in class org.apache.hadoop.hbase.master.balancer.ClusterStatusChore
 
balancer - Variable in class org.apache.hadoop.hbase.master.HMaster
 
balancer() - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.balance() instead.
balancer(boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Deprecated.
Since 2.0.0. Will be removed in 3.0.0. Use Admin.balance(BalanceRequest) instead.
BALANCER_DECISION_BUFFER_ENABLED - Static variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
BALANCER_DECISION_EVENT - Static variable in class org.apache.hadoop.hbase.namequeues.BalancerDecisionDetails
 
BALANCER_DECISION_QUEUE_SIZE - Static variable in class org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
 
BALANCER_ON - Enum constant in enum org.apache.hadoop.hbase.ClusterMetrics.Option
metrics about balancer is on or not
BALANCER_REJECTION_BUFFER_ENABLED - Static variable in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
 
BALANCER_REJECTION_EVENT - Static variable in class org.apache.hadoop.hbase.namequeues.BalancerRejectionDetails
 
BALANCER_REJECTION_QUEUE_SIZE - Static variable in class org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService
 
BALANCER_STATUS - Static variable in interface org.apache.hadoop.hbase.master.balancer.MetricsBalancerSource
 
balancerChore - Variable in class org.apache.hadoop.hbase.master.HMaster
 
BalancerChore - Class in org.apache.hadoop.hbase.master.balancer
Chore that will call HMaster.balanceHMaster.balance() when needed.
BalancerChore(HMaster) - Constructor for class org.apache.hadoop.hbase.master.balancer.BalancerChore
 
BalancerClusterState - Class in org.apache.hadoop.hbase.master.balancer
An efficient array based implementation similar to ClusterState for keeping the status of the cluster in terms of region assignment and distribution.
BalancerClusterState(Collection<RegionInfo>, Map<ServerName, List<RegionInfo>>, Map<String, Deque<BalancerRegionLoad>>, RegionLocationFinder, RackManager, Map<String, Pair<ServerName, Float>>) - Constructor for class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
 
BalancerClusterState(Map<ServerName, List<RegionInfo>>, Map<String, Deque<BalancerRegionLoad>>, RegionLocationFinder, RackManager) - Constructor for class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
 
BalancerClusterState(Map<ServerName, List<RegionInfo>>, Map<String, Deque<BalancerRegionLoad>>, RegionLocationFinder, RackManager, Map<String, Pair<ServerName, Float>>) - Constructor for class org.apache.hadoop.hbase.master.balancer.BalancerClusterState
 
BalancerClusterState.DefaultRackManager - Class in org.apache.hadoop.hbase.master.balancer
 
BalancerClusterState.LocalityType - Enum in org.apache.hadoop.hbase.master.balancer
 
balancerDecision - Variable in class org.apache.hadoop.hbase.namequeues.BalancerDecisionDetails
 
BalancerDecision - Class in org.apache.hadoop.hbase.client
History of balancer decisions taken for region movements.
BalancerDecision(String, String, double, double, List<String>, long) - Constructor for class org.apache.hadoop.hbase.client.BalancerDecision
 
BalancerDecision.Builder - Class in org.apache.hadoop.hbase.client
 
BalancerDecisionDetails - Class in org.apache.hadoop.hbase.namequeues
Balancer decision details that would be passed on to ring buffer for history
BalancerDecisionDetails(BalancerDecision) - Constructor for class org.apache.hadoop.hbase.namequeues.BalancerDecisionDetails
 
balancerDecisionQueue - Variable in class org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
 
BalancerDecisionQueueService - Class in org.apache.hadoop.hbase.namequeues.impl
In-memory Queue service provider for Balancer Decision events
BalancerDecisionQueueService(Configuration) - Constructor for class org.apache.hadoop.hbase.namequeues.impl.BalancerDecisionQueueService
 
balancerDecisions - Variable in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
 
balancerDecisionsRequest - Variable in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
 
BalanceRequest - Class in org.apache.hadoop.hbase.client
Encapsulates options for executing a run of the Balancer.
BalanceRequest(boolean, boolean) - Constructor for class org.apache.hadoop.hbase.client.BalanceRequest
 
BalanceRequest.Builder - Class in org.apache.hadoop.hbase.client
Builder for constructing a BalanceRequest
BalanceResponse - Class in org.apache.hadoop.hbase.client
Response returned from a balancer invocation
BalanceResponse(boolean, int, int) - Constructor for class org.apache.hadoop.hbase.client.BalanceResponse
 
BalanceResponse.Builder - Class in org.apache.hadoop.hbase.client
Used in HMaster to build a BalanceResponse for returning results of a balance invocation to callers
balancerOn - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder
 
balancerOn - Variable in class org.apache.hadoop.hbase.ClusterMetricsBuilder.ClusterMetricsImpl
 
balancerRan - Variable in class org.apache.hadoop.hbase.client.BalanceResponse
 
balancerRan - Variable in class org.apache.hadoop.hbase.client.BalanceResponse.Builder
 
BalancerRegionLoad - Class in org.apache.hadoop.hbase.master.balancer
Wrapper class for the few fields required by the StochasticLoadBalancer from the full RegionMetrics.
BalancerRegionLoad(RegionMetrics) - Constructor for class org.apache.hadoop.hbase.master.balancer.BalancerRegionLoad
 
balancerRejection - Variable in class org.apache.hadoop.hbase.namequeues.BalancerRejectionDetails
 
BalancerRejection - Class in org.apache.hadoop.hbase.client
History of detail information that balancer movements was rejected
BalancerRejection(String, List<String>) - Constructor for class org.apache.hadoop.hbase.client.BalancerRejection
 
BalancerRejection.Builder - Class in org.apache.hadoop.hbase.client
 
BalancerRejectionDetails - Class in org.apache.hadoop.hbase.namequeues
Balancer rejection details that would be passed on to ring buffer for history
BalancerRejectionDetails(BalancerRejection) - Constructor for class org.apache.hadoop.hbase.namequeues.BalancerRejectionDetails
 
balancerRejectionQueue - Variable in class org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService
 
BalancerRejectionQueueService - Class in org.apache.hadoop.hbase.namequeues.impl
In-memory Queue service provider for Balancer Rejection events
BalancerRejectionQueueService(Configuration) - Constructor for class org.apache.hadoop.hbase.namequeues.impl.BalancerRejectionQueueService
 
balancerRejections - Variable in class org.apache.hadoop.hbase.namequeues.response.NamedQueueGetResponse
 
balancerRejectionsRequest - Variable in class org.apache.hadoop.hbase.namequeues.request.NamedQueueGetRequest
 
balanceRSGroup(RpcController, RSGroupAdminProtos.BalanceRSGroupRequest, RpcCallback<RSGroupAdminProtos.BalanceRSGroupResponse>) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminEndpoint.RSGroupAdminServiceImpl
 
balanceRSGroup(String) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Balance regions in the given RegionServer group.
balanceRSGroup(String, BalanceRequest) - Method in interface org.apache.hadoop.hbase.rsgroup.RSGroupAdmin
Balance regions in the given RegionServer group, running based on the given BalanceRequest.
balanceRSGroup(String, BalanceRequest) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminClient
 
balanceRSGroup(String, BalanceRequest) - Method in class org.apache.hadoop.hbase.rsgroup.RSGroupAdminServer
 
balancerStatus(boolean) - Method in class org.apache.hadoop.hbase.master.balancer.MetricsBalancer
 
balancerStatus(boolean) - Method in class org.apache.hadoop.hbase.master.balancer.MetricsStochasticBalancer
Updates the balancer status tag reported to JMX
balancerSwitch(boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Turn the load balancer on or off.
balancerSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.Admin
Turn the load balancer on or off.
balancerSwitch(boolean, boolean) - Method in interface org.apache.hadoop.hbase.client.AsyncAdmin
Turn the load balancer on or off.
balancerSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.AsyncHBaseAdmin
 
balancerSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.HBaseAdmin
 
balancerSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.RawAsyncHBaseAdmin
 
balancerSwitch(boolean, boolean) - Method in class org.apache.hadoop.hbase.thrift2.client.ThriftAdmin
 
balancerZNode - Variable in class org.apache.hadoop.hbase.zookeeper.ZNodePaths
Deprecated.
Since 2.6.0, will be removed in 4.0.0. We use master local region to store this state.
balanceSwitch(boolean) - Method in class org.apache.hadoop.hbase.master.HMaster
 
BalanceSwitchMode() - Constructor for enum org.apache.hadoop.hbase.master.MasterRpcServices.BalanceSwitchMode
 
balanceTable(TableName, Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
 
balanceTable(TableName, Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
Perform the major balance operation for table, all sub classes should override this method.
balanceTable(TableName, Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.FavoredStochasticBalancer
 
balanceTable(TableName, Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.SimpleLoadBalancer
Generate a global load balancing plan according to the specified map of server information to the most loaded regions of each server.
balanceTable(TableName, Map<ServerName, List<RegionInfo>>) - Method in class org.apache.hadoop.hbase.master.balancer.StochasticLoadBalancer
Given the cluster state this will try and approach an optimal balance.
balanceThrottling(long, int, long) - Method in class org.apache.hadoop.hbase.master.HMaster
It first sleep to the next balance plan start time.
bandwidth - Variable in class org.apache.hadoop.hbase.backup.BackupInfo
Bandwidth per worker in MB per sec.
bandwidth - Variable in class org.apache.hadoop.hbase.backup.BackupRequest
 
bandwidth - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationThrottler
 
bandwidth - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig
 
bandwidth - Variable in class org.apache.hadoop.hbase.replication.ReplicationPeerConfig.ReplicationPeerConfigBuilderImpl
 
BANDWIDTH - Static variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot.Options
 
bandwidthMB - Variable in class org.apache.hadoop.hbase.snapshot.ExportSnapshot
 
baos - Variable in class org.apache.hadoop.hbase.ipc.CellBlockBuilder.ByteBufferOutputStreamSupplier
 
BaosAndCompressor(CompressionContext) - Constructor for class org.apache.hadoop.hbase.regionserver.wal.WALCellCodec.BaosAndCompressor
 
baosInMemory - Variable in class org.apache.hadoop.hbase.io.hfile.HFileBlock.Writer
The stream we use to accumulate data into a block in an uncompressed format.
barrierAcquiredByMember(String) - Method in class org.apache.hadoop.hbase.procedure.Procedure
Call back triggered by an individual member upon successful local barrier acquisition
barrierName - Variable in class org.apache.hadoop.hbase.procedure.Subprocedure
 
barrierReleasedByMember(String, byte[]) - Method in class org.apache.hadoop.hbase.procedure.Procedure
Call back triggered by a individual member upon successful local in-barrier execution and release
barriers - Variable in class org.apache.hadoop.hbase.MetaTableAccessor.ReplicationBarrierResult
 
base - Variable in class org.apache.hadoop.hbase.types.FixedLengthWrapper
 
BASE_NAMESPACE_DIR - Static variable in class org.apache.hadoop.hbase.HConstants
 
BASE_USAGE - Static variable in class org.apache.hadoop.hbase.monitoring.MemoryBoundedLogMessageBuffer.LogMessage
Completely non-scientific estimate of how much one of these objects takes, along with the LinkedList overhead.
BASE_WINDOW_MILLIS_KEY - Static variable in class org.apache.hadoop.hbase.regionserver.compactions.ExponentialCompactionWindowFactory
 
base64 - Variable in class org.apache.hadoop.hbase.mob.mapreduce.MobRefReporter.MobRefReducer
 
base64Decode(String) - Static method in class org.apache.hadoop.hbase.io.crypto.tls.PemReader
 
base64Urldecoder - Static variable in class org.apache.hadoop.hbase.rest.MultiRowResource
 
base64Urldecoder - Static variable in class org.apache.hadoop.hbase.rest.TableResource
 
baseClass - Variable in class org.apache.hadoop.hbase.util.ReflectedFunctionCache
 
baseConf - Variable in class org.apache.hadoop.hbase.regionserver.HRegion
 
baseConfig - Variable in class org.apache.hadoop.hbase.zookeeper.ZKAuthentication.JaasConfiguration
 
BaseConfigurable - Class in org.apache.hadoop.hbase
HBase version of Hadoop's Configured class that doesn't initialize the configuration via BaseConfigurable.setConf(Configuration) in the constructor, but only sets the configuration through the BaseConfigurable.setConf(Configuration) method
BaseConfigurable() - Constructor for class org.apache.hadoop.hbase.BaseConfigurable
 
BaseConstraint - Class in org.apache.hadoop.hbase.constraint
Base class to use when actually implementing a Constraint.
BaseConstraint() - Constructor for class org.apache.hadoop.hbase.constraint.BaseConstraint
 
BaseDecoder - Class in org.apache.hadoop.hbase.codec
TODO javadoc
BaseDecoder(InputStream) - Constructor for class org.apache.hadoop.hbase.codec.BaseDecoder
 
BaseDecoder.PBIS - Class in org.apache.hadoop.hbase.codec
 
BaseEncoder - Class in org.apache.hadoop.hbase.codec
TODO javadoc
BaseEncoder(OutputStream) - Constructor for class org.apache.hadoop.hbase.codec.BaseEncoder
 
BaseEnvironment<C extends Coprocessor> - Class in org.apache.hadoop.hbase.coprocessor
Encapsulation of the environment of each coprocessor
BaseEnvironment(C, int, int, Configuration) - Constructor for class org.apache.hadoop.hbase.coprocessor.BaseEnvironment
Constructor
BaseFileCleanerDelegate - Class in org.apache.hadoop.hbase.master.cleaner
Base class for file cleaners which allows subclasses to implement a simple isFileDeletable method (which used to be the FileCleanerDelegate contract).
BaseFileCleanerDelegate() - Constructor for class org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
 
baseFilterOutWALEntries - Variable in class org.apache.hadoop.hbase.replication.regionserver.ReplicationSource
Base WALEntry filters for this class.
BaseHFileCleanerDelegate - Class in org.apache.hadoop.hbase.master.cleaner
Base class for the hfile cleaning function inside the master.
BaseHFileCleanerDelegate() - Constructor for class org.apache.hadoop.hbase.master.cleaner.BaseHFileCleanerDelegate
 
baseKeyZNode - Variable in class org.apache.hadoop.hbase.security.token.ZKSecretWatcher
 
BaseLoadBalancer - Class in org.apache.hadoop.hbase.master.balancer
The base class for load balancers.
BaseLoadBalancer() - Constructor for class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
The constructor that uses the basic MetricsBalancer
BaseLoadBalancer(MetricsBalancer) - Constructor for class org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
This Constructor accepts an instance of MetricsBalancer, which will be used instead of creating a new one
BaseLogCleanerDelegate - Class in org.apache.hadoop.hbase.master.cleaner
Base class for the log cleaning function inside the master.
BaseLogCleanerDelegate() - Constructor for class org.apache.hadoop.hbase.master.cleaner.BaseLogCleanerDelegate
 
baseNamespaceDir - Variable in class org.apache.hadoop.hbase.replication.regionserver.HBaseInterClusterReplicationEndpoint
 
baseOffset - Variable in class org.apache.hadoop.hbase.io.hfile.bucket.BucketAllocator.Bucket
 
BaseReplicationEndpoint - Class in org.apache.hadoop.hbase.replication
A Base implementation for ReplicationEndpoints.
BaseReplicationEndpoint() - Constructor for class org.apache.hadoop.hbase.replication.BaseReplicationEndpoint
 
BaseRowProcessor<S extends com.google.protobuf.Message,T extends com.google.protobuf.Message> - Class in org.apache.hadoop.hbase.regionserver
Base class for RowProcessor with some default implementations.
BaseRowProcessor() - Constructor for class org.apache.hadoop.hbase.regionserver.BaseRowProcessor
 
BaseRowProcessorEndpoint<S extends com.google.protobuf.Message,T extends com.google.protobuf.Message> - Class in org.apache.hadoop.hbase.coprocessor
This class demonstrates how to implement atomic read-modify-writes using Region.processRowsWithLocks(org.apache.hadoop.hbase.regionserver.RowProcessor<?, ?>) and Coprocessor endpoints.
BaseRowProcessorEndpoint() - Constructor for class org.apache.hadoop.hbase.coprocessor.BaseRowProcessorEndpoint
 
BaseRSProcedureCallable - Class in org.apache.hadoop.hbase.procedure2
 
BaseRSProcedureCallable() - Constructor for class org.apache.hadoop.hbase.procedure2.BaseRSProcedureCallable
 
baseSleepBeforeRetries - Variable in class org.apache.hadoop.hbase.regionserver.HRegionFileSystem
 
BaseSource - Interface in org.apache.hadoop.hbase.metrics
BaseSource for dynamic metrics to announce to Metrics2.
BaseSourceImpl - Class in